Skip navigation links

Back to Flink Website

$ A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 

$

$greater(A) - Static method in class org.apache.flink.ml.math.distributed.IndexedRow
 
$greater$eq(A) - Static method in class org.apache.flink.ml.math.distributed.IndexedRow
 
$less(A) - Static method in class org.apache.flink.ml.math.distributed.IndexedRow
 
$less$eq(A) - Static method in class org.apache.flink.ml.math.distributed.IndexedRow
 
$minus$greater() - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
$minus$greater() - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
$minus$greater() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
$minus$greater() - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 

A

A - Variable in class org.apache.flink.graph.generator.RMatGraph
 
abort() - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
 
abort() - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
 
abort() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
 
abort() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
abort() - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstHashJoinIterator
 
abort() - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondHashJoinIterator
 
abort() - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildFirstHashJoinIterator
 
abort() - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildSecondHashJoinIterator
 
abort() - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
abort() - Method in interface org.apache.flink.runtime.operators.util.JoinTaskIterator
Aborts the matching process.
abortCheckpointOnBarrier(long, Throwable) - Method in interface org.apache.flink.runtime.jobgraph.tasks.StatefulTask
Aborts a checkpoint as the result of receiving possibly some checkpoint barriers, but at least one CancelCheckpointMarker.
abortCheckpointOnBarrier(long, Throwable) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
abortDeclined() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
abortError(Throwable) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
Aborts the pending checkpoint due to an error.
abortExpired() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
Aborts a checkpoint because it expired (took too long).
abortSubsumed() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
Aborts the pending checkpoint because a newer completed checkpoint subsumed it.
ABS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
abs() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Calculates the absolute value of given value.
ABS() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
ABS() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
Abs - Class in org.apache.flink.table.expressions
 
Abs(Expression) - Constructor for class org.apache.flink.table.expressions.Abs
 
Abs$ - Class in org.apache.flink.table.expressions
 
Abs$() - Constructor for class org.apache.flink.table.expressions.Abs$
 
ABS_DEC() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
ABS_DEC() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
absoluteTimeMillis() - Method in class org.apache.flink.runtime.util.clock.Clock
 
absoluteTimeMillis() - Method in class org.apache.flink.runtime.util.clock.SystemClock
 
AbstractAlignedProcessingTimeWindowOperator<KEY,IN,OUT,STATE,F extends Function> - Class in org.apache.flink.streaming.runtime.operators.windowing
Deprecated.
Deprecated in favour of the generic WindowOperator. This was an optimized implementation used for aligned windows.
AbstractAlignedProcessingTimeWindowOperator(F, KeySelector<IN, KEY>, TypeSerializer<KEY>, TypeSerializer<STATE>, long, long) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
Deprecated.
 
AbstractAsyncIOCallable<V,D extends Closeable> - Class in org.apache.flink.runtime.io.async
The abstract class encapsulates the lifecycle and execution strategy for asynchronous IO operations
AbstractAsyncIOCallable() - Constructor for class org.apache.flink.runtime.io.async.AbstractAsyncIOCallable
 
AbstractAsyncSnapshotIOCallable<H extends StateObject> - Class in org.apache.flink.runtime.checkpoint
Abstract base class for async IO operations of snapshots against a CheckedOutputStream.
AbstractAsyncSnapshotIOCallable(long, long, CheckpointStreamFactory, CloseableRegistry) - Constructor for class org.apache.flink.runtime.checkpoint.AbstractAsyncSnapshotIOCallable
 
AbstractBoltSink - Class in org.apache.flink.storm.util
Implements a sink that write the received data so some external output.
AbstractBoltSink(OutputFormatter) - Constructor for class org.apache.flink.storm.util.AbstractBoltSink
 
AbstractCachedBuildSideJoinDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
 
AbstractCachedBuildSideJoinDriver(int, int) - Constructor for class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
 
AbstractCheckpointMessage - Class in org.apache.flink.runtime.messages.checkpoint
The base class of all checkpoint messages.
AbstractCheckpointMessage(JobID, ExecutionAttemptID, long) - Constructor for class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
 
AbstractCheckpointStats - Class in org.apache.flink.runtime.checkpoint
Base class for checkpoint statistics.
AbstractCloseableHandle - Class in org.apache.flink.migration.runtime.state
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
AbstractCloseableHandle() - Constructor for class org.apache.flink.migration.runtime.state.AbstractCloseableHandle
Deprecated.
 
AbstractCloseableRegistry<C extends Closeable,T> - Class in org.apache.flink.util
This is the abstract base class for registries that allow to register instances of Closeable, which are all closed if this registry is closed.
AbstractCloseableRegistry(Map<Closeable, T>) - Constructor for class org.apache.flink.util.AbstractCloseableRegistry
 
AbstractDataSetAnalytic<T,R> - Class in org.apache.flink.graph.asm.dataset
Base class for DataSetAnalytic.
AbstractDataSetAnalytic() - Constructor for class org.apache.flink.graph.asm.dataset.AbstractDataSetAnalytic
 
AbstractDeserializationSchema<T> - Class in org.apache.flink.streaming.util.serialization
The deserialization schema describes how to turn the byte messages delivered by certain data sources (for example Apache Kafka) into data types (Java/Scala objects) that are processed by Flink.
AbstractDeserializationSchema() - Constructor for class org.apache.flink.streaming.util.serialization.AbstractDeserializationSchema
 
AbstractEvent - Class in org.apache.flink.runtime.event
This type of event can be used to exchange notification messages between different TaskManager objects at runtime using the communication channels.
AbstractEvent() - Constructor for class org.apache.flink.runtime.event.AbstractEvent
 
AbstractExecutionGraphRequestHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Base class for request handlers whose response depends on an ExecutionGraph that can be retrieved via "jobid" parameter.
AbstractExecutionGraphRequestHandler(ExecutionGraphHolder) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.AbstractExecutionGraphRequestHandler
 
AbstractFetcher<T,KPH> - Class in org.apache.flink.streaming.connectors.kafka.internals
Base class for all fetchers, which implement the connections to Kafka brokers and pull records from Kafka partitions.
AbstractFetcher(SourceFunction.SourceContext<T>, Map<KafkaTopicPartition, Long>, SerializedValue<AssignerWithPeriodicWatermarks<T>>, SerializedValue<AssignerWithPunctuatedWatermarks<T>>, ProcessingTimeService, long, ClassLoader, boolean) - Constructor for class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
 
AbstractFileIOChannel - Class in org.apache.flink.runtime.io.disk.iomanager
 
AbstractFileIOChannel(FileIOChannel.ID, boolean) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
Creates a new channel to the path indicated by the given ID.
AbstractFileStateHandle - Class in org.apache.flink.migration.runtime.state.filesystem
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
AbstractFileStateHandle(Path) - Constructor for class org.apache.flink.migration.runtime.state.filesystem.AbstractFileStateHandle
Deprecated.
Creates a new file state for the given file path.
AbstractFsStateSnapshot<K,N,SV,S extends State,SD extends StateDescriptor<S,?>> - Class in org.apache.flink.migration.runtime.state.filesystem
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
AbstractFsStateSnapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<SV>, SD, Path) - Constructor for class org.apache.flink.migration.runtime.state.filesystem.AbstractFsStateSnapshot
Deprecated.
 
AbstractGeneratorFactory<T extends org.apache.commons.math3.random.RandomGenerator> - Class in org.apache.flink.graph.generator.random
This base class handles the task of dividing the requested work into the appropriate number of blocks of near-equal size.
AbstractGeneratorFactory() - Constructor for class org.apache.flink.graph.generator.random.AbstractGeneratorFactory
 
AbstractGraphAnalytic<K,VV,EV,T> - Class in org.apache.flink.graph
Base class for GraphAnalytic.
AbstractGraphAnalytic() - Constructor for class org.apache.flink.graph.AbstractGraphAnalytic
 
AbstractGraphGenerator<K,VV,EV> - Class in org.apache.flink.graph.generator
 
AbstractGraphGenerator() - Constructor for class org.apache.flink.graph.generator.AbstractGraphGenerator
 
AbstractHashTableProber<PT,BT> - Class in org.apache.flink.runtime.operators.hash
 
AbstractHashTableProber(TypeComparator<PT>, TypePairComparator<PT, BT>) - Constructor for class org.apache.flink.runtime.operators.hash.AbstractHashTableProber
 
AbstractHeapMergingState<K,N,IN,OUT,SV,S extends State,SD extends StateDescriptor<S,?>> - Class in org.apache.flink.runtime.state.heap
Base class for MergingState (InternalMergingState) that is stored on the heap.
AbstractHeapMergingState(SD, StateTable<K, N, SV>, TypeSerializer<K>, TypeSerializer<N>) - Constructor for class org.apache.flink.runtime.state.heap.AbstractHeapMergingState
Creates a new key/value state for the given hash map of key/value pairs.
AbstractHeapState<K,N,SV,S extends State,SD extends StateDescriptor<S,?>> - Class in org.apache.flink.runtime.state.heap
Base class for partitioned ListState implementations that are backed by a regular heap hash map.
AbstractHeapState(SD, StateTable<K, N, SV>, TypeSerializer<K>, TypeSerializer<N>) - Constructor for class org.apache.flink.runtime.state.heap.AbstractHeapState
Creates a new key/value state for the given hash map of key/value pairs.
AbstractID - Class in org.apache.flink.util
A statistically unique identification number.
AbstractID(byte[]) - Constructor for class org.apache.flink.util.AbstractID
Constructs a new ID with a specific bytes value.
AbstractID(long, long) - Constructor for class org.apache.flink.util.AbstractID
Constructs a new abstract ID.
AbstractID(AbstractID) - Constructor for class org.apache.flink.util.AbstractID
Copy constructor: Creates a new abstract ID from the given one.
AbstractID() - Constructor for class org.apache.flink.util.AbstractID
Constructs a new random ID from a uniform distribution.
AbstractInvokable - Class in org.apache.flink.runtime.jobgraph.tasks
This is the abstract base class for every task that can be executed by a TaskManager.
AbstractInvokable() - Constructor for class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
 
AbstractIterativeTask<S extends Function,OT> - Class in org.apache.flink.runtime.iterative.task
The abstract base class for all tasks able to participate in an iteration.
AbstractIterativeTask() - Constructor for class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
AbstractJobVertexRequestHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Base class for request handlers whose response depends on a specific job vertex (defined via the "vertexid" parameter) in a specific job, defined via (defined voa the "jobid" parameter).
AbstractJobVertexRequestHandler(ExecutionGraphHolder) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.AbstractJobVertexRequestHandler
 
AbstractJoinDescriptor - Class in org.apache.flink.optimizer.operators
Defines the possible global properties for a join.
AbstractJoinDescriptor(FieldList, FieldList) - Constructor for class org.apache.flink.optimizer.operators.AbstractJoinDescriptor
 
AbstractJoinDescriptor(FieldList, FieldList, boolean, boolean, boolean) - Constructor for class org.apache.flink.optimizer.operators.AbstractJoinDescriptor
 
AbstractJsonRequestHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Base class for most request handlers.
AbstractJsonRequestHandler() - Constructor for class org.apache.flink.runtime.webmonitor.handlers.AbstractJsonRequestHandler
 
AbstractKeyedCEPPatternOperator<IN,KEY,OUT> - Class in org.apache.flink.cep.operator
Abstract CEP pattern operator for a keyed input stream.
AbstractKeyedCEPPatternOperator(TypeSerializer<IN>, boolean, TypeSerializer<KEY>, NFACompiler.NFAFactory<IN>, boolean) - Constructor for class org.apache.flink.cep.operator.AbstractKeyedCEPPatternOperator
 
AbstractKeyedStateBackend<K> - Class in org.apache.flink.runtime.state
Base implementation of KeyedStateBackend.
AbstractKeyedStateBackend(TaskKvStateRegistry, TypeSerializer<K>, ClassLoader, int, KeyGroupRange, ExecutionConfig) - Constructor for class org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
AbstractKeyedTimePanes<Type,Key,Aggregate,Result> - Class in org.apache.flink.streaming.runtime.operators.windowing
Base class for a multiple key/value maps organized in panes.
AbstractKeyedTimePanes() - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
 
AbstractLineSpout - Class in org.apache.flink.storm.util
Base class for Spouts that read data line by line from an arbitrary source.
AbstractLineSpout() - Constructor for class org.apache.flink.storm.util.AbstractLineSpout
 
AbstractMemStateSnapshot<K,N,SV,S extends State,SD extends StateDescriptor<S,?>> - Class in org.apache.flink.migration.runtime.state.memory
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
AbstractMemStateSnapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<SV>, SD, byte[]) - Constructor for class org.apache.flink.migration.runtime.state.memory.AbstractMemStateSnapshot
Deprecated.
Creates a new heap memory state snapshot.
AbstractMergeInnerJoinIterator<T1,T2,O> - Class in org.apache.flink.runtime.operators.sort
An implementation of the JoinTaskIterator that realizes the joining through a sort-merge join strategy.
AbstractMergeInnerJoinIterator(MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>, MemoryManager, IOManager, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.sort.AbstractMergeInnerJoinIterator
 
AbstractMergeIterator<T1,T2,O> - Class in org.apache.flink.runtime.operators.sort
 
AbstractMergeIterator(MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>, MemoryManager, IOManager, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
AbstractMergeOuterJoinIterator<T1,T2,O> - Class in org.apache.flink.runtime.operators.sort
An implementation of the JoinTaskIterator that realizes the outer join through a sort-merge join strategy.
AbstractMergeOuterJoinIterator(OuterJoinOperatorBase.OuterJoinType, MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>, MemoryManager, IOManager, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.sort.AbstractMergeOuterJoinIterator
 
AbstractMetricGroup<A extends AbstractMetricGroup<?>> - Class in org.apache.flink.runtime.metrics.groups
Abstract MetricGroup that contains key functionality for adding metrics and groups.
AbstractMetricGroup(MetricRegistry, String[], A) - Constructor for class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
AbstractMetricsHandler - Class in org.apache.flink.runtime.webmonitor.metrics
Abstract request handler that returns a list of all available metrics or the values for a set of metrics.
AbstractMetricsHandler(MetricFetcher) - Constructor for class org.apache.flink.runtime.webmonitor.metrics.AbstractMetricsHandler
 
AbstractMigrationRestoreStrategy<K,N,S> - Class in org.apache.flink.migration.runtime.state.memory
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
AbstractMigrationRestoreStrategy(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<S>) - Constructor for class org.apache.flink.migration.runtime.state.memory.AbstractMigrationRestoreStrategy
Deprecated.
 
AbstractMultiFSDataInputStream - Class in org.apache.flink.core.fs
Abstract base class for wrappers over multiple FSDataInputStream, which gives a contiguous view on all inner streams and makes them look like a single stream, in which we can read, seek, etc.
AbstractMultiFSDataInputStream() - Constructor for class org.apache.flink.core.fs.AbstractMultiFSDataInputStream
 
AbstractMutableHashTable<T> - Class in org.apache.flink.runtime.operators.hash
 
AbstractMutableHashTable(TypeSerializer<T>, TypeComparator<T>) - Constructor for class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
 
AbstractNonHaServices - Class in org.apache.flink.runtime.highavailability.nonha
Abstract base class for non high-availability services.
AbstractNonHaServices() - Constructor for class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
 
AbstractOperatorBackendStateMetaInfoReader(ClassLoader) - Constructor for class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.AbstractOperatorBackendStateMetaInfoReader
 
AbstractOperatorBackendStateMetaInfoWriter(RegisteredOperatorBackendStateMetaInfo.Snapshot<S>) - Constructor for class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.AbstractOperatorBackendStateMetaInfoWriter
 
AbstractOperatorDescriptor - Interface in org.apache.flink.optimizer.operators
The root of all descriptions of an operator to the optimizer.
AbstractOuterJoinDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
The abstract outer join driver implements the logic of an outer join operator at runtime.
AbstractOuterJoinDriver() - Constructor for class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
AbstractPagedInputView - Class in org.apache.flink.runtime.memory
The base class for all input views that are backed by multiple memory pages.
AbstractPagedInputView(MemorySegment, int, int) - Constructor for class org.apache.flink.runtime.memory.AbstractPagedInputView
Creates a new view that starts with the given segment.
AbstractPagedInputView(int) - Constructor for class org.apache.flink.runtime.memory.AbstractPagedInputView
Creates a new view that is initially not bound to a memory segment.
AbstractPagedOutputView - Class in org.apache.flink.runtime.memory
The base class for all output views that are backed by multiple memory pages.
AbstractPagedOutputView(MemorySegment, int, int) - Constructor for class org.apache.flink.runtime.memory.AbstractPagedOutputView
Creates a new output view that writes initially to the given initial segment.
AbstractPagedOutputView(int, int) - Constructor for class org.apache.flink.runtime.memory.AbstractPagedOutputView
 
AbstractPartialSolutionNode - Class in org.apache.flink.optimizer.dag
The optimizer's internal representation of the partial solution that is input to a bulk iteration.
AbstractPartialSolutionNode(Operator<?>) - Constructor for class org.apache.flink.optimizer.dag.AbstractPartialSolutionNode
 
AbstractPerWindowStateStore() - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.AbstractPerWindowStateStore
 
AbstractReader - Class in org.apache.flink.runtime.io.network.api.reader
A basic reader implementation, which wraps an input gate and handles events.
AbstractReader(InputGate) - Constructor for class org.apache.flink.runtime.io.network.api.reader.AbstractReader
 
AbstractReporter - Class in org.apache.flink.metrics.reporter
Base interface for custom metric reporters.
AbstractReporter() - Constructor for class org.apache.flink.metrics.reporter.AbstractReporter
 
AbstractRichFunction - Class in org.apache.flink.api.common.functions
An abstract stub implementation for rich user-defined functions.
AbstractRichFunction() - Constructor for class org.apache.flink.api.common.functions.AbstractRichFunction
 
AbstractRocksDBState<K,N,S extends State,SD extends StateDescriptor<S,V>,V> - Class in org.apache.flink.contrib.streaming.state
Base class for State implementations that store state in a RocksDB database.
AbstractRocksDBState(ColumnFamilyHandle, TypeSerializer<N>, SD, RocksDBKeyedStateBackend<K>) - Constructor for class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
Creates a new RocksDB backed state.
AbstractRuntimeUDFContext - Class in org.apache.flink.api.common.functions.util
A standalone implementation of the RuntimeContext, created by runtime UDF operators.
AbstractRuntimeUDFContext(TaskInfo, ClassLoader, ExecutionConfig, Map<String, Accumulator<?, ?>>, Map<String, Future<Path>>, MetricGroup) - Constructor for class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
AbstractSchema<X> - Class in org.apache.flink.optimizer.postpass
 
AbstractSchema() - Constructor for class org.apache.flink.optimizer.postpass.AbstractSchema
 
AbstractSortMergeJoinDescriptor - Class in org.apache.flink.optimizer.operators
 
AbstractSortMergeJoinDescriptor(FieldList, FieldList) - Constructor for class org.apache.flink.optimizer.operators.AbstractSortMergeJoinDescriptor
 
AbstractSortMergeJoinDescriptor(FieldList, FieldList, boolean, boolean, boolean) - Constructor for class org.apache.flink.optimizer.operators.AbstractSortMergeJoinDescriptor
 
AbstractStateBackend - Class in org.apache.flink.migration.runtime.state
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
AbstractStateBackend() - Constructor for class org.apache.flink.migration.runtime.state.AbstractStateBackend
Deprecated.
 
AbstractStateBackend - Class in org.apache.flink.runtime.state
An abstract base implementation of the StateBackend interface.
AbstractStateBackend() - Constructor for class org.apache.flink.runtime.state.AbstractStateBackend
 
AbstractStateBackend.DataInputViewHandle - Class in org.apache.flink.migration.runtime.state
Deprecated.
Simple state handle that resolved a DataInputView from a StreamStateHandle.
AbstractStreamOperator<OUT> - Class in org.apache.flink.streaming.api.operators
Base class for all stream operators.
AbstractStreamOperator() - Constructor for class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
AbstractStreamOperator.CountingOutput - Class in org.apache.flink.streaming.api.operators
Wrapping Output that updates metrics on the number of emitted elements.
AbstractStreamOperator.LatencyGauge - Class in org.apache.flink.streaming.api.operators
The gauge uses a HashMap internally to avoid classloading issues when accessing the values using JMX.
AbstractSubtaskAttemptRequestHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Base class for request handlers whose response depends on a specific subtask execution attempt (defined via the "attempt" parameter) of a specific subtask (defined via the "subtasknum" parameter) in a specific job vertex (defined via the "vertexid" parameter) in a specific job, defined via (defined voa the "jobid" parameter).
AbstractSubtaskAttemptRequestHandler(ExecutionGraphHolder) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.AbstractSubtaskAttemptRequestHandler
 
AbstractSubtaskRequestHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Base class for request handlers whose response depends on a specific subtask (defined via the "subtasknum" parameter) in a specific job vertex (defined via the "vertexid" parameter) in a specific job, defined via (defined voa the "jobid" parameter).
AbstractSubtaskRequestHandler(ExecutionGraphHolder) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.AbstractSubtaskRequestHandler
 
AbstractTableInputFormat<T> - Class in org.apache.flink.addons.hbase
Abstract InputFormat to read data from HBase tables.
AbstractTableInputFormat() - Constructor for class org.apache.flink.addons.hbase.AbstractTableInputFormat
 
AbstractTestBase - Class in org.apache.flink.test.util
A base class for tests that run test programs in a Flink mini cluster.
AbstractTestBase(Configuration) - Constructor for class org.apache.flink.test.util.AbstractTestBase
 
AbstractUdfOperator<OUT,FT extends Function> - Class in org.apache.flink.api.common.operators
Abstract superclass for all contracts that represent actual operators.
AbstractUdfOperator(UserCodeWrapper<FT>, OperatorInformation<OUT>, String) - Constructor for class org.apache.flink.api.common.operators.AbstractUdfOperator
Creates a new abstract operator with the given name wrapping the given user function.
AbstractUdfStreamOperator<OUT,F extends Function> - Class in org.apache.flink.streaming.api.operators
This is used as the base class for operators that have a user-defined function.
AbstractUdfStreamOperator(F) - Constructor for class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
AbstractWindowProperty - Class in org.apache.flink.table.expressions
 
AbstractWindowProperty(Expression) - Constructor for class org.apache.flink.table.expressions.AbstractWindowProperty
 
AbstractYarnClusterDescriptor - Class in org.apache.flink.yarn
The descriptor with deployment information for spawning or resuming a YarnClusterClient.
AbstractYarnClusterDescriptor() - Constructor for class org.apache.flink.yarn.AbstractYarnClusterDescriptor
 
AbstractYarnFlinkApplicationMasterRunner - Class in org.apache.flink.yarn
This class is the executable entry point for the YARN application master.
AbstractYarnFlinkApplicationMasterRunner() - Constructor for class org.apache.flink.yarn.AbstractYarnFlinkApplicationMasterRunner
 
AbstractYarnNonHaServices - Class in org.apache.flink.yarn.highavailability
Abstract base class for the high availability services for Flink YARN applications that support no master fail over.
AbstractYarnNonHaServices(Configuration, Configuration) - Constructor for class org.apache.flink.yarn.highavailability.AbstractYarnNonHaServices
Creates new YARN high-availability services, configuring the file system and recovery data directory based on the working directory in the given Hadoop configuration.
Acc() - Method in class org.apache.flink.table.plan.nodes.datastream.AccMode$
An operator in Acc mode emits change messages as CRow which encode a pair of (Boolean, Row).
Acc() - Static method in class org.apache.flink.table.plan.nodes.datastream.AccMode
An operator in Acc mode emits change messages as CRow which encode a pair of (Boolean, Row).
accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.PartialSolutionPlaceHolder
 
accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase.SolutionSetPlaceHolder
 
accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase.WorksetPlaceHolder
 
accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
 
accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
Accepts the visitor and applies it this instance.
accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
Accepts the visitor and applies it this instance.
accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
Accepts the visitor and applies it this instance.
accept(Visitor<Operator<?>>) - Method in class org.apache.flink.api.common.Plan
Traverses the job depth first from all data sinks on towards the sources.
accept(Visitor<OptimizerNode>) - Method in class org.apache.flink.optimizer.dag.AbstractPartialSolutionNode
 
accept(Visitor<OptimizerNode>) - Method in class org.apache.flink.optimizer.dag.DataSinkNode
 
accept(Visitor<OptimizerNode>) - Method in class org.apache.flink.optimizer.dag.DataSourceNode
 
accept(Visitor<OptimizerNode>) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
This method implements the visit of a depth-first graph traversing visitor.
accept(Visitor<OptimizerNode>) - Method in class org.apache.flink.optimizer.dag.SingleInputNode
 
accept(Visitor<OptimizerNode>) - Method in class org.apache.flink.optimizer.dag.TwoInputNode
 
accept(Visitor<PlanNode>) - Method in class org.apache.flink.optimizer.plan.BulkPartialSolutionPlanNode
 
accept(Visitor<PlanNode>) - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
 
accept(Visitor<PlanNode>) - Method in class org.apache.flink.optimizer.plan.NAryUnionPlanNode
 
accept(Visitor<PlanNode>) - Method in class org.apache.flink.optimizer.plan.OptimizedPlan
Applies the given visitor top down to all nodes, starting at the sinks.
accept(Visitor<PlanNode>) - Method in class org.apache.flink.optimizer.plan.SingleInputPlanNode
 
accept(Visitor<PlanNode>) - Method in class org.apache.flink.optimizer.plan.SolutionSetPlanNode
 
accept(Visitor<PlanNode>) - Method in class org.apache.flink.optimizer.plan.SourcePlanNode
 
accept(Visitor<PlanNode>) - Method in class org.apache.flink.optimizer.plan.WorksetPlanNode
 
accept(T) - Method in interface org.apache.flink.runtime.concurrent.AcceptFunction
Method which handles the function call.
accept(Parsers) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
accept(ES, Function1<ES, List<Object>>) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
accept(String, PartialFunction<Object, U>) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
accept(RelShuttle) - Method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
accept(RelShuttle) - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
accept(RexShuttle) - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
accept(RelShuttle) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
accept(RexShuttle) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
accept(RelShuttle) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
accept(RexShuttle) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
accept(RelShuttle) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
accept(RexShuttle) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
accept(RelShuttle) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
accept(RexShuttle) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
accept(RelShuttle) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
accept(RexShuttle) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
accept(RelShuttle) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
accept(RexShuttle) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
accept(RexShuttle) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
accept(RelShuttle) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
accept(RelShuttle) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
accept(RexShuttle) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
accept(RelShuttle) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
accept(RexShuttle) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
accept(RelShuttle) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
accept(RexShuttle) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
accept(RexShuttle) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
accept(RelShuttle) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
accept(RelShuttle) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
accept(RexShuttle) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
accept(RelShuttle) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
accept(RexShuttle) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
accept(RelShuttle) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
accept(Visitor<T>) - Method in interface org.apache.flink.util.Visitable
Contains the logic to invoke the visitor and continue the traversal.
acceptCall(SqlVisitor<R>, SqlCall) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
acceptCall(SqlVisitor<R>, SqlCall, boolean, SqlBasicVisitor.ArgHandler<R>) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
acceptCall(SqlVisitor<R>, SqlCall) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
acceptCall(SqlVisitor<R>, SqlCall, boolean, SqlBasicVisitor.ArgHandler<R>) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
acceptCall(SqlVisitor<R>, SqlCall) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
acceptCall(SqlVisitor<R>, SqlCall, boolean, SqlBasicVisitor.ArgHandler<R>) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
acceptCall(SqlVisitor<R>, SqlCall) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
acceptCall(SqlVisitor<R>, SqlCall, boolean, SqlBasicVisitor.ArgHandler<R>) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
acceptFile(FileStatus) - Method in class org.apache.flink.api.common.io.FileInputFormat
A simple hook to filter files and directories from the input.
acceptForStepFunction(Visitor<OptimizerNode>) - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
 
acceptForStepFunction(Visitor<OptimizerNode>) - Method in interface org.apache.flink.optimizer.dag.IterationNode
 
acceptForStepFunction(Visitor<OptimizerNode>) - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
 
acceptForStepFunction(Visitor<PlanNode>) - Method in class org.apache.flink.optimizer.plan.BulkIterationPlanNode
 
acceptForStepFunction(Visitor<PlanNode>) - Method in interface org.apache.flink.optimizer.plan.IterationPlanNode
 
acceptForStepFunction(Visitor<PlanNode>) - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
 
AcceptFunction<T> - Interface in org.apache.flink.runtime.concurrent
Function which is called with a single argument and does not return a value.
acceptIf(Function1<Object, Object>, Function1<Object, String>) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
acceptMatch(String, PartialFunction<Object, U>) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
AcceptOffers - Class in org.apache.flink.mesos.scheduler.messages
Local message sent by the launch coordinator to the scheduler to accept offers.
AcceptOffers(String, Collection<Protos.OfferID>, Collection<Protos.Offer.Operation>) - Constructor for class org.apache.flink.mesos.scheduler.messages.AcceptOffers
 
AcceptOffers(String, Collection<Protos.OfferID>, Collection<Protos.Offer.Operation>, Protos.Filters) - Constructor for class org.apache.flink.mesos.scheduler.messages.AcceptOffers
 
acceptSeq(ES, Function1<ES, Iterable<Object>>) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
AccessExecution - Interface in org.apache.flink.runtime.executiongraph
Common interface for the runtime Execution and {@link ArchivedExecution}.
AccessExecutionGraph - Interface in org.apache.flink.runtime.executiongraph
Common interface for the runtime ExecutionGraph and ArchivedExecutionGraph.
AccessExecutionJobVertex - Interface in org.apache.flink.runtime.executiongraph
Common interface for the runtime ExecutionJobVertex and ArchivedExecutionJobVertex.
AccessExecutionVertex - Interface in org.apache.flink.runtime.executiongraph
Common interface for the runtime ExecutionVertex and ArchivedExecutionVertex.
accessField(Field, Object) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
This method is handling the IllegalAccess exceptions of Field.get()
AccMode - Class in org.apache.flink.table.plan.nodes.datastream
The AccMode determines how insert, update, and delete changes of tables are encoded by the messeages that an operator emits.
AccMode() - Constructor for class org.apache.flink.table.plan.nodes.datastream.AccMode
 
AccMode$ - Class in org.apache.flink.table.plan.nodes.datastream
The AccMode determines how insert, update, and delete changes of tables are encoded by the messeages that an operator emits.
AccMode$() - Constructor for class org.apache.flink.table.plan.nodes.datastream.AccMode$
 
ACCMODE_INSTANCE() - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamRetractionRules$
Rule instance that assigns the AccMode to DataStreamRel nodes.
ACCMODE_INSTANCE() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamRetractionRules
Rule instance that assigns the AccMode to DataStreamRel nodes.
AccModeTrait - Class in org.apache.flink.table.plan.nodes.datastream
Tracks the AccMode of a RelNode.
AccModeTrait() - Constructor for class org.apache.flink.table.plan.nodes.datastream.AccModeTrait
 
AccModeTrait(Enumeration.Value) - Constructor for class org.apache.flink.table.plan.nodes.datastream.AccModeTrait
 
AccModeTrait$ - Class in org.apache.flink.table.plan.nodes.datastream
 
AccModeTrait$() - Constructor for class org.apache.flink.table.plan.nodes.datastream.AccModeTrait$
 
AccModeTraitDef - Class in org.apache.flink.table.plan.nodes.datastream
Definition of the AccModeTrait.
AccModeTraitDef() - Constructor for class org.apache.flink.table.plan.nodes.datastream.AccModeTraitDef
 
AccModeTraitDef$ - Class in org.apache.flink.table.plan.nodes.datastream
 
AccModeTraitDef$() - Constructor for class org.apache.flink.table.plan.nodes.datastream.AccModeTraitDef$
 
AccRetract() - Method in class org.apache.flink.table.plan.nodes.datastream.AccMode$
* An operator in AccRetract mode emits change messages as CRow which encode a pair of (Boolean, Row).
AccRetract() - Static method in class org.apache.flink.table.plan.nodes.datastream.AccMode
* An operator in AccRetract mode emits change messages as CRow which encode a pair of (Boolean, Row).
accumulate(BigIntegralAvgAccumulator, Object) - Method in class org.apache.flink.table.functions.aggfunctions.BigIntegralAvgAggFunction
 
accumulate(CountAccumulator, Object) - Method in class org.apache.flink.table.functions.aggfunctions.CountAggFunction
 
accumulate(DecimalAvgAccumulator, Object) - Method in class org.apache.flink.table.functions.aggfunctions.DecimalAvgAggFunction
 
accumulate(DecimalSumAccumulator, Object) - Method in class org.apache.flink.table.functions.aggfunctions.DecimalSumAggFunction
 
accumulate(DecimalSumWithRetractAccumulator, Object) - Method in class org.apache.flink.table.functions.aggfunctions.DecimalSumWithRetractAggFunction
 
accumulate(FloatingAvgAccumulator, Object) - Method in class org.apache.flink.table.functions.aggfunctions.FloatingAvgAggFunction
 
accumulate(IntegralAvgAccumulator, Object) - Method in class org.apache.flink.table.functions.aggfunctions.IntegralAvgAggFunction
 
accumulate(MaxAccumulator<T>, Object) - Method in class org.apache.flink.table.functions.aggfunctions.MaxAggFunction
 
accumulate(MaxWithRetractAccumulator<T>, Object) - Method in class org.apache.flink.table.functions.aggfunctions.MaxWithRetractAggFunction
 
accumulate(MinAccumulator<T>, Object) - Method in class org.apache.flink.table.functions.aggfunctions.MinAggFunction
 
accumulate(MinWithRetractAccumulator<T>, Object) - Method in class org.apache.flink.table.functions.aggfunctions.MinWithRetractAggFunction
 
accumulate(SumAccumulator<T>, Object) - Method in class org.apache.flink.table.functions.aggfunctions.SumAggFunction
 
accumulate(SumWithRetractAccumulator<T>, Object) - Method in class org.apache.flink.table.functions.aggfunctions.SumWithRetractAggFunction
 
accumulate(Row, Row) - Method in class org.apache.flink.table.runtime.aggregate.GeneratedAggregations
Accumulates the input values to the accumulators.
AccumulatingKeyedTimePanes<Type,Key,Result> - Class in org.apache.flink.streaming.runtime.operators.windowing
Key/value map organized in panes for accumulating windows (with a window function).
AccumulatingKeyedTimePanes(KeySelector<Type, Key>, InternalWindowFunction<Iterable<Type>, Result, Key, Window>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingKeyedTimePanes
 
AccumulatingProcessingTimeWindowOperator<KEY,IN,OUT> - Class in org.apache.flink.streaming.runtime.operators.windowing
Deprecated.
Deprecated in favour of the generic WindowOperator. This was an optimized implementation used for aligned windows.
AccumulatingProcessingTimeWindowOperator(InternalWindowFunction<Iterable<IN>, OUT, KEY, TimeWindow>, KeySelector<IN, KEY>, TypeSerializer<KEY>, TypeSerializer<IN>, long, long) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingProcessingTimeWindowOperator
Deprecated.
 
Accumulator<V,R extends Serializable> - Interface in org.apache.flink.api.common.accumulators
Accumulators collect distributed statistics or aggregates in a from user functions and operators.
AccumulatorHelper - Class in org.apache.flink.api.common.accumulators
 
AccumulatorHelper() - Constructor for class org.apache.flink.api.common.accumulators.AccumulatorHelper
 
accumulatorMap - Variable in class org.apache.flink.runtime.operators.BatchTask
The accumulator map used in the RuntimeContext.
AccumulatorMessage - Interface in org.apache.flink.runtime.messages.accumulators
Base trait of all accumulator messages
AccumulatorRegistry - Class in org.apache.flink.runtime.accumulators
Main accumulator registry which encapsulates user-defined accumulators.
AccumulatorRegistry(JobID, ExecutionAttemptID) - Constructor for class org.apache.flink.runtime.accumulators.AccumulatorRegistry
 
AccumulatorResultsErroneous - Class in org.apache.flink.runtime.messages.accumulators
Denotes that the accumulator results for jobID could be obtained from the JobManager because of an exception.
AccumulatorResultsErroneous(JobID, Exception) - Constructor for class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsErroneous
 
AccumulatorResultsErroneous$ - Class in org.apache.flink.runtime.messages.accumulators
 
AccumulatorResultsErroneous$() - Constructor for class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsErroneous$
 
AccumulatorResultsFound - Class in org.apache.flink.runtime.messages.accumulators
Contains the retrieved accumulator results from the job manager.
AccumulatorResultsFound(JobID, Map<String, SerializedValue<Object>>) - Constructor for class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsFound
 
AccumulatorResultsFound$ - Class in org.apache.flink.runtime.messages.accumulators
 
AccumulatorResultsFound$() - Constructor for class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsFound$
 
AccumulatorResultsNotFound - Class in org.apache.flink.runtime.messages.accumulators
Denotes that no accumulator results for jobID could be found at the job manager.
AccumulatorResultsNotFound(JobID) - Constructor for class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsNotFound
 
AccumulatorResultsNotFound$ - Class in org.apache.flink.runtime.messages.accumulators
 
AccumulatorResultsNotFound$() - Constructor for class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsNotFound$
 
AccumulatorResultsResponse - Interface in org.apache.flink.runtime.messages.accumulators
Base trait of responses to RequestAccumulatorResults
AccumulatorResultStringsFound - Class in org.apache.flink.runtime.messages.accumulators
Contains the retrieved accumulator result strings from the job manager.
AccumulatorResultStringsFound(JobID, StringifiedAccumulatorResult[]) - Constructor for class org.apache.flink.runtime.messages.accumulators.AccumulatorResultStringsFound
 
AccumulatorResultStringsFound$ - Class in org.apache.flink.runtime.messages.accumulators
 
AccumulatorResultStringsFound$() - Constructor for class org.apache.flink.runtime.messages.accumulators.AccumulatorResultStringsFound$
 
accumulators() - Method in class org.apache.flink.runtime.messages.TaskManagerMessages.Heartbeat
 
accumulators() - Method in class org.apache.flink.table.runtime.aggregate.DataSetSlideWindowAggReduceGroupFunction
 
accumulators() - Method in class org.apache.flink.table.runtime.aggregate.DataSetTumbleTimeWindowAggReduceGroupFunction
 
AccumulatorSnapshot - Class in org.apache.flink.runtime.accumulators
This class encapsulates a map of accumulators for a single task.
AccumulatorSnapshot(JobID, ExecutionAttemptID, Map<String, Accumulator<?, ?>>) - Constructor for class org.apache.flink.runtime.accumulators.AccumulatorSnapshot
 
ack(Object) - Method in class org.apache.flink.storm.util.AbstractLineSpout
 
ack(Object) - Method in class org.apache.flink.storm.util.NullTerminatingSpout
 
Acknowledge - Class in org.apache.flink.runtime.messages
A generic acknowledgement message.
AcknowledgeApplicationClientRegistration$() - Constructor for class org.apache.flink.yarn.YarnMessages.AcknowledgeApplicationClientRegistration$
 
acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, SubtaskState) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointCoordinatorGateway
 
acknowledgeCheckpoint(long, CheckpointMetrics) - Method in interface org.apache.flink.runtime.execution.Environment
Confirms that the invokable has successfully completed all steps it needed to to for the checkpoint with the give checkpoint-ID.
acknowledgeCheckpoint(long, CheckpointMetrics, SubtaskState) - Method in interface org.apache.flink.runtime.execution.Environment
Confirms that the invokable has successfully completed all required steps for the checkpoint with the give checkpoint-ID.
acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, SubtaskState) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
AcknowledgeCheckpoint - Class in org.apache.flink.runtime.messages.checkpoint
This message is sent from the TaskManager to the JobManager to signal that the checkpoint of an individual task is completed.
AcknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, SubtaskState) - Constructor for class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
 
AcknowledgeCheckpoint(JobID, ExecutionAttemptID, long) - Constructor for class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
 
acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, SubtaskState) - Method in class org.apache.flink.runtime.taskexecutor.rpc.RpcCheckpointResponder
 
acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, SubtaskState) - Method in class org.apache.flink.runtime.taskmanager.ActorGatewayCheckpointResponder
 
acknowledgeCheckpoint(JobID, ExecutionAttemptID, long, CheckpointMetrics, SubtaskState) - Method in interface org.apache.flink.runtime.taskmanager.CheckpointResponder
Acknowledges the given checkpoint.
acknowledgeCheckpoint(long, CheckpointMetrics) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
acknowledgeCheckpoint(long, CheckpointMetrics, SubtaskState) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
acknowledgeIDs(long, List<UId>) - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
This method must be implemented to acknowledge the given set of IDs back to the message queue.
acknowledgeIDs(long, List<UId>) - Method in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
Acknowledges the session ids.
AcknowledgeRegistration(InstanceID, int) - Constructor for class org.apache.flink.runtime.messages.RegistrationMessages.AcknowledgeRegistration
 
AcknowledgeRegistration$() - Constructor for class org.apache.flink.runtime.messages.RegistrationMessages.AcknowledgeRegistration$
 
acknowledgeSessionIDs(List<SessionId>) - Method in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
Acknowledges the session ids.
acknowledgeSessionIDs(List<Long>) - Method in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
 
acknowledgeTask(ExecutionAttemptID, SubtaskState, CheckpointMetrics) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
Acknowledges the task with the given execution attempt id and the given subtask state.
ACOS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
acos() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Calculates the arc cosine of a given number.
ACOS() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
ACOS() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
Acos - Class in org.apache.flink.table.expressions
 
Acos(Expression) - Constructor for class org.apache.flink.table.expressions.Acos
 
Acos$ - Class in org.apache.flink.table.expressions
 
Acos$() - Constructor for class org.apache.flink.table.expressions.Acos$
 
ACOS_DEC() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
ACOS_DEC() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
ActionRequestFailureHandler - Interface in org.apache.flink.streaming.connectors.elasticsearch
An implementation of ActionRequestFailureHandler is provided by the user to define how failed ActionRequests should be handled, e.g.
activate(String) - Method in class org.apache.flink.storm.api.FlinkLocalCluster
 
activate() - Method in class org.apache.flink.storm.util.AbstractLineSpout
 
activate() - Method in class org.apache.flink.storm.util.NullTerminatingSpout
 
ACTIVE - Static variable in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
ACTIVE_STATUS - Static variable in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
actor() - Method in interface org.apache.flink.runtime.instance.ActorGateway
Returns the underlying actor with which is communicated
actor() - Method in class org.apache.flink.runtime.instance.AkkaActorGateway
Returns ActorRef of the target actor
actor() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.ResponseArchive
 
ActorGateway - Interface in org.apache.flink.runtime.instance
Interface to abstract the communication with an actor.
ActorGatewayCheckpointResponder - Class in org.apache.flink.runtime.taskmanager
Implementation using ActorGateway to forward the messages.
ActorGatewayCheckpointResponder(ActorGateway) - Constructor for class org.apache.flink.runtime.taskmanager.ActorGatewayCheckpointResponder
 
ActorGatewayKvStateRegistryListener - Class in org.apache.flink.runtime.taskmanager
This implementation uses ActorGateway to forward key-value state notifications to the job manager.
ActorGatewayKvStateRegistryListener(ActorGateway, KvStateServerAddress) - Constructor for class org.apache.flink.runtime.taskmanager.ActorGatewayKvStateRegistryListener
 
ActorGatewayPartitionProducerStateChecker - Class in org.apache.flink.runtime.taskmanager
This implementation uses ActorGateway to trigger the partition state check at the job manager.
ActorGatewayPartitionProducerStateChecker(ActorGateway, FiniteDuration) - Constructor for class org.apache.flink.runtime.taskmanager.ActorGatewayPartitionProducerStateChecker
 
ActorGatewayResultPartitionConsumableNotifier - Class in org.apache.flink.runtime.taskmanager
This implementation uses ActorGateway to notify the job manager about consumable partitions.
ActorGatewayResultPartitionConsumableNotifier(ExecutionContext, ActorGateway, FiniteDuration) - Constructor for class org.apache.flink.runtime.taskmanager.ActorGatewayResultPartitionConsumableNotifier
 
ActorGatewayTaskExecutionStateListener - Class in org.apache.flink.runtime.taskmanager
Implementation using ActorGateway to forward the messages.
ActorGatewayTaskExecutionStateListener(ActorGateway) - Constructor for class org.apache.flink.runtime.taskmanager.ActorGatewayTaskExecutionStateListener
 
ActorGatewayTaskManagerActions - Class in org.apache.flink.runtime.taskmanager
Implementation using ActorGateway to forward the messages.
ActorGatewayTaskManagerActions(ActorGateway) - Constructor for class org.apache.flink.runtime.taskmanager.ActorGatewayTaskManagerActions
 
actorSystemLoader - Variable in class org.apache.flink.client.program.ClusterClient
The actor system used to communicate with the JobManager.
ActorTaskManagerGateway - Class in org.apache.flink.runtime.jobmanager.slots
Implementation of the TaskManagerGateway for ActorGateway.
ActorTaskManagerGateway(ActorGateway) - Constructor for class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
actualModVersion() - Method in exception org.apache.flink.runtime.executiongraph.GlobalModVersionMismatch
 
AdamicAdar<K extends CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.drivers
Driver for AdamicAdar.
AdamicAdar() - Constructor for class org.apache.flink.graph.drivers.AdamicAdar
 
AdamicAdar<K extends CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.similarity
http://social.cs.uiuc.edu/class/cs591kgk/friendsadamic.pdf
AdamicAdar() - Constructor for class org.apache.flink.graph.library.similarity.AdamicAdar
 
AdamicAdar.Result<T> - Class in org.apache.flink.graph.library.similarity
Wraps Tuple3 to encapsulate results from the Adamic-Adar algorithm.
AdaptiveSpanningRecordDeserializer<T extends IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.serialization
 
AdaptiveSpanningRecordDeserializer() - Constructor for class org.apache.flink.runtime.io.network.api.serialization.AdaptiveSpanningRecordDeserializer
 
add(V) - Method in interface org.apache.flink.api.common.accumulators.Accumulator
 
add(Double) - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
 
add(double) - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
 
add(long) - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
 
add(int) - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
 
add(Double) - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
Consider using DoubleCounter.add(double) instead for primitive double values
add(double) - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
 
add(Double) - Method in class org.apache.flink.api.common.accumulators.DoubleMaximum
Consider using DoubleMaximum.add(double) instead for primitive double values
add(double) - Method in class org.apache.flink.api.common.accumulators.DoubleMaximum
 
add(Double) - Method in class org.apache.flink.api.common.accumulators.DoubleMinimum
Consider using DoubleMinimum.add(double) instead for primitive double values
add(double) - Method in class org.apache.flink.api.common.accumulators.DoubleMinimum
 
add(Integer) - Method in class org.apache.flink.api.common.accumulators.Histogram
 
add(Integer) - Method in class org.apache.flink.api.common.accumulators.IntCounter
Consider using IntCounter.add(int) instead for primitive int values
add(int) - Method in class org.apache.flink.api.common.accumulators.IntCounter
 
add(Integer) - Method in class org.apache.flink.api.common.accumulators.IntMaximum
Consider using IntMaximum.add(int) instead for primitive integer values
add(int) - Method in class org.apache.flink.api.common.accumulators.IntMaximum
 
add(Integer) - Method in class org.apache.flink.api.common.accumulators.IntMinimum
Consider using IntMinimum.add(int) instead for primitive integer values
add(int) - Method in class org.apache.flink.api.common.accumulators.IntMinimum
 
add(T) - Method in class org.apache.flink.api.common.accumulators.ListAccumulator
 
add(Long) - Method in class org.apache.flink.api.common.accumulators.LongCounter
Consider using LongCounter.add(long) instead for primitive long values
add(long) - Method in class org.apache.flink.api.common.accumulators.LongCounter
 
add(Long) - Method in class org.apache.flink.api.common.accumulators.LongMaximum
Consider using LongMaximum.add(long) instead for primitive long values
add(long) - Method in class org.apache.flink.api.common.accumulators.LongMaximum
 
add(Long) - Method in class org.apache.flink.api.common.accumulators.LongMinimum
Consider using LongMinimum.add(long) instead for primitive long values
add(long) - Method in class org.apache.flink.api.common.accumulators.LongMinimum
 
add(T) - Method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
add(T, TypeSerializer<T>) - Method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
add(IN, ACC) - Method in interface org.apache.flink.api.common.functions.AggregateFunction
Adds the given value to the given accumulator.
add(IN, ACC) - Method in class org.apache.flink.api.common.functions.RichAggregateFunction
 
add(IN) - Method in interface org.apache.flink.api.common.state.AppendingState
Updates the operator state accessible by AppendingState.get() by adding the given value to the list of values.
add(double, double) - Method in class org.apache.flink.api.java.summarize.aggregation.CompensatedSum
Increments the Kahan sum by adding a value and a correction term
add(double) - Method in class org.apache.flink.api.java.summarize.aggregation.CompensatedSum
Increments the Kahan sum by adding a value without a correction term
add(CompensatedSum) - Method in class org.apache.flink.api.java.summarize.aggregation.CompensatedSum
Increments the Kahan sum by adding two sums, and updating the correction term for reducing numeric errors
add() - Method in class org.apache.flink.api.java.tuple.builder.Tuple0Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in class org.apache.flink.api.java.tuple.builder.Tuple10Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Method in class org.apache.flink.api.java.tuple.builder.Tuple11Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Method in class org.apache.flink.api.java.tuple.builder.Tuple12Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Method in class org.apache.flink.api.java.tuple.builder.Tuple13Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - Method in class org.apache.flink.api.java.tuple.builder.Tuple14Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - Method in class org.apache.flink.api.java.tuple.builder.Tuple15Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15) - Method in class org.apache.flink.api.java.tuple.builder.Tuple16Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16) - Method in class org.apache.flink.api.java.tuple.builder.Tuple17Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17) - Method in class org.apache.flink.api.java.tuple.builder.Tuple18Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18) - Method in class org.apache.flink.api.java.tuple.builder.Tuple19Builder
 
add(T0) - Method in class org.apache.flink.api.java.tuple.builder.Tuple1Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19) - Method in class org.apache.flink.api.java.tuple.builder.Tuple20Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20) - Method in class org.apache.flink.api.java.tuple.builder.Tuple21Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21) - Method in class org.apache.flink.api.java.tuple.builder.Tuple22Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22) - Method in class org.apache.flink.api.java.tuple.builder.Tuple23Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22, T23) - Method in class org.apache.flink.api.java.tuple.builder.Tuple24Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22, T23, T24) - Method in class org.apache.flink.api.java.tuple.builder.Tuple25Builder
 
add(T0, T1) - Method in class org.apache.flink.api.java.tuple.builder.Tuple2Builder
 
add(T0, T1, T2) - Method in class org.apache.flink.api.java.tuple.builder.Tuple3Builder
 
add(T0, T1, T2, T3) - Method in class org.apache.flink.api.java.tuple.builder.Tuple4Builder
 
add(T0, T1, T2, T3, T4) - Method in class org.apache.flink.api.java.tuple.builder.Tuple5Builder
 
add(T0, T1, T2, T3, T4, T5) - Method in class org.apache.flink.api.java.tuple.builder.Tuple6Builder
 
add(T0, T1, T2, T3, T4, T5, T6) - Method in class org.apache.flink.api.java.tuple.builder.Tuple7Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7) - Method in class org.apache.flink.api.java.tuple.builder.Tuple8Builder
 
add(T0, T1, T2, T3, T4, T5, T6, T7, T8) - Method in class org.apache.flink.api.java.tuple.builder.Tuple9Builder
 
add(Utils.ChecksumHashCode) - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
 
add(String) - Method in class org.apache.flink.api.java.utils.RequiredParameters
Add a parameter based on its name.
add(Option) - Method in class org.apache.flink.api.java.utils.RequiredParameters
Add a parameter encapsulated in an Option object.
add(T) - Method in class org.apache.flink.contrib.streaming.state.RocksDBAggregatingState
 
add(T) - Method in class org.apache.flink.contrib.streaming.state.RocksDBFoldingState
Deprecated.
 
add(V) - Method in class org.apache.flink.contrib.streaming.state.RocksDBListState
 
add(V) - Method in class org.apache.flink.contrib.streaming.state.RocksDBReducingState
 
add(KMeans.Point) - Method in class org.apache.flink.examples.java.clustering.KMeans.Point
 
add(Integer) - Method in class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator.VectorAccumulator
Increases the result vector component at the specified position by 1.
add(KMeans.Coordinate) - Method in interface org.apache.flink.examples.scala.clustering.KMeans.Coordinate
 
add(ChecksumHashCode.Checksum) - Method in class org.apache.flink.graph.asm.dataset.ChecksumHashCode.Checksum
 
add(IntValue) - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
 
add(LongValue) - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
 
add(NullValue) - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
 
add(StringValue) - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
 
add(T) - Method in interface org.apache.flink.graph.types.valuearray.ValueArray
Appends the value to this array if and only if the array capacity would not be exceeded.
add(Parameter<T>, T) - Method in class org.apache.flink.ml.common.ParameterMap
Adds a new parameter value to the ParameterMap.
add(DistributedRowMatrix) - Method in class org.apache.flink.ml.math.distributed.DistributedRowMatrix
Adds this matrix to another matrix.
add(int, D) - Method in class org.apache.flink.python.api.util.SetCache
Adds the given DataSet to this cache for the given ID.
add(int, U) - Method in class org.apache.flink.python.api.util.SetCache
Adds the given UnsortedGrouping to this cache for the given ID.
add(int, S) - Method in class org.apache.flink.python.api.util.SetCache
Adds the given SortedGrouping to this cache for the given ID.
add(Buffer, int) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
Adds a buffer to the subpartition with the given index.
add(Buffer) - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
add(IN) - Method in class org.apache.flink.runtime.state.heap.HeapAggregatingState
 
add(T) - Method in class org.apache.flink.runtime.state.heap.HeapFoldingState
Deprecated.
 
add(V) - Method in class org.apache.flink.runtime.state.heap.HeapListState
 
add(V) - Method in class org.apache.flink.runtime.state.heap.HeapReducingState
 
add(Task) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
Add the given task to the task slot.
add(T) - Method in class org.apache.flink.runtime.util.EvictingBoundedList
 
add(int) - Method in class org.apache.flink.runtime.util.IntArrayList
 
add(long) - Method in class org.apache.flink.runtime.util.LongArrayList
 
add(V) - Method in class org.apache.flink.runtime.util.LRUCache
 
add(MetricDump) - Method in class org.apache.flink.runtime.webmonitor.metrics.MetricStore
 
add(Object, Object) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction
 
add(Extractor<TO, OUT>) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ConcatenatedExtract
 
add(ActionRequest...) - Method in interface org.apache.flink.streaming.connectors.elasticsearch.RequestIndexer
Add multiple ActionRequest to the indexer to prepare for sending requests to Elasticsearch.
add(ActionRequest...) - Method in interface org.apache.flink.streaming.connectors.elasticsearch2.RequestIndexer
Deprecated.
 
add(E) - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
Adds the element to the queue, or fails with an exception, if the queue is closed.
add(BufferOrEvent) - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller
Adds a buffer or event to the sequence of spilled buffers and events.
add(CRow, Row) - Method in class org.apache.flink.table.runtime.aggregate.AggregateAggFunction
 
add(int, V) - Method in class org.apache.flink.types.ListValue
 
add(V) - Method in class org.apache.flink.types.ListValue
 
add(Iterator<T>) - Method in class org.apache.flink.util.UnionIterator
 
addAccumulator(String, Accumulator<V, A>) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Add this accumulator.
addAccumulator(String, Accumulator<V, A>) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
addAccumulator(String, Accumulator<V, A>) - Method in class org.apache.flink.graph.AnalyticHelper
Adds an accumulator by prepending the given name with a random string.
addAll(AggregatorRegistry) - Method in class org.apache.flink.api.common.aggregators.AggregatorRegistry
 
addAll(Configuration) - Method in class org.apache.flink.configuration.Configuration
 
addAll(Configuration, String) - Method in class org.apache.flink.configuration.Configuration
Adds all entries from the given configuration into this configuration.
addAll(Configuration) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
addAll(Configuration, String) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
addAll(Configuration) - Method in class org.apache.flink.configuration.UnmodifiableConfiguration
 
addAll(Configuration, String) - Method in class org.apache.flink.configuration.UnmodifiableConfiguration
 
addAll(ValueArray<IntValue>) - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
 
addAll(ValueArray<LongValue>) - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
 
addAll(ValueArray<NullValue>) - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
 
addAll(ValueArray<StringValue>) - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
 
addAll(ValueArray<T>) - Method in interface org.apache.flink.graph.types.valuearray.ValueArray
Appends all of the values in the specified array to the end of this array.
addAll(Collection<? extends V>) - Method in class org.apache.flink.types.ListValue
 
addAll(int, Collection<? extends V>) - Method in class org.apache.flink.types.ListValue
 
addAllToProperties(Properties) - Method in class org.apache.flink.configuration.Configuration
Adds all entries in this Configuration to the given Properties.
addAllToProperties(Properties) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
addAllToProperties(Properties) - Method in class org.apache.flink.configuration.UnmodifiableConfiguration
 
addAndLock(String, T) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Creates a state handle, stores it in ZooKeeper and locks it.
addAppConfigurationEntry(String, AppConfigurationEntry...) - Method in class org.apache.flink.runtime.security.DynamicConfiguration
Add entries for the given application name.
addArtificialDamCost(EstimateProvider, long, Costs) - Method in class org.apache.flink.optimizer.costs.CostEstimator
 
addArtificialDamCost(EstimateProvider, long, Costs) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
 
addBlob(BlobKey) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Adds the BLOB referenced by the key to the JobGraph's dependencies.
addBlockNestedLoopsCosts(EstimateProvider, EstimateProvider, long, Costs, int) - Method in class org.apache.flink.optimizer.costs.CostEstimator
 
addBlockNestedLoopsCosts(EstimateProvider, EstimateProvider, long, Costs, int) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
 
addBroadcastConnection(String, DagConnection) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
Adds the broadcast connection identified by the given name to this node.
addBroadcastCost(EstimateProvider, int, Costs) - Method in class org.apache.flink.optimizer.costs.CostEstimator
 
addBroadcastCost(EstimateProvider, int, Costs) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
 
addBroadcastInputToGroup(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
addBroadcastSet(String, DataSet<?>) - Method in class org.apache.flink.graph.pregel.VertexCentricConfiguration
Adds a data set as a broadcast set to the compute function.
addBroadcastSetForApplyFunction(String, DataSet<?>) - Method in class org.apache.flink.graph.gsa.GSAConfiguration
Adds a data set as a broadcast set to the apply function.
addBroadcastSetForGatherFunction(String, DataSet<?>) - Method in class org.apache.flink.graph.gsa.GSAConfiguration
Adds a data set as a broadcast set to the gather function.
addBroadcastSetForGatherFunction(String, DataSet<?>) - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
Adds a data set as a broadcast set to the gather function.
addBroadcastSetForScatterFunction(String, DataSet<?>) - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
Adds a data set as a broadcast set to the scatter function.
addBroadcastSetForSumFunction(String, DataSet<?>) - Method in class org.apache.flink.graph.gsa.GSAConfiguration
Adds a data set as a broadcast set to the sum function.
addCachedHybridHashCosts(EstimateProvider, EstimateProvider, Costs, int) - Method in class org.apache.flink.optimizer.costs.CostEstimator
 
addCachedHybridHashCosts(EstimateProvider, EstimateProvider, Costs, int) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
Calculates the costs for the cached variant of the hybrid hash join.
addChainedTask(Class<? extends ChainedDriver>, TaskConfig, String) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
addCheckpoint(CompletedCheckpoint) - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
Adds a CompletedCheckpoint instance to the list of completed checkpoints.
addCheckpoint(CompletedCheckpoint) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
 
addCheckpoint(CompletedCheckpoint) - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
Synchronously writes the new checkpoints to ZooKeeper and asynchronously removes older ones.
addChoices(String...) - Method in class org.apache.flink.graph.drivers.parameter.ChoiceParameter
Add additional choices.
addClass(Class<?>) - Method in class org.apache.flink.runtime.util.JarFileCreator
Adds a Class object to the set of classes which shall eventually be included in the jar file.
addClosedBranch(OptimizerNode) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
addClosedBranches(Set<OptimizerNode>) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
addColumn(String, String, Class<?>) - Method in class org.apache.flink.addons.hbase.HBaseTableSource
Adds a column defined by family, qualifier, and type to the table schema.
addComparatorField(int, TypeComparator<?>) - Method in interface org.apache.flink.api.common.typeutils.CompositeType.TypeComparatorBuilder
 
addConfiguration(Configuration) - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
addConsumer(JobEdge) - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
 
addContainerMapping(String, TaggedValue, ModifiedASMFrame) - Method in class org.apache.flink.api.java.sca.TaggedValue
 
addConvertedNonCorrSubqs(Map<SqlNode, RexNode>) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Adds to the current map of non-correlated converted sub-queries the elements from another map that contains non-correlated sub-queries that have been converted by another SqlToRelConverter.
addCoOperator(Integer, String, TwoInputStreamOperator<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
addCosts(Costs) - Method in class org.apache.flink.optimizer.costs.Costs
Adds the given costs to these costs.
addCpuCost(double) - Method in class org.apache.flink.optimizer.costs.Costs
Adds the given CPU cost to the current CPU cost for this Costs object.
addDataSink(GenericDataSinkBase<?>) - Method in class org.apache.flink.api.common.Plan
Adds a data sink to the set of sinks in this program.
addDecoRuleSet(RuleSet) - Method in class org.apache.flink.table.calcite.CalciteConfigBuilder
Appends the given decoration rule set to the built-in rule set.
addDefaultKryoSerializer(Class<?>, T) - Method in class org.apache.flink.api.common.ExecutionConfig
Adds a new Kryo default serializer to the Runtime.
addDefaultKryoSerializer(Class<?>, Class<? extends Serializer<?>>) - Method in class org.apache.flink.api.common.ExecutionConfig
Adds a new Kryo default serializer to the Runtime.
addDefaultKryoSerializer(Class<?>, T) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Adds a new Kryo default serializer to the Runtime.
addDefaultKryoSerializer(Class<?>, Class<? extends Serializer<?>>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Adds a new Kryo default serializer to the Runtime.
addDefaultKryoSerializer(Class<?>, Class<? extends Serializer<?>>) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Registers a default serializer for the given class and its sub-classes at Kryo.
addDefaultKryoSerializer(Class<?>, T) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Registers a default serializer for the given class and its sub-classes at Kryo.
addDefaultKryoSerializer(Class<?>, T) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Adds a new Kryo default serializer to the Runtime.
addDefaultKryoSerializer(Class<?>, Class<? extends Serializer<?>>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Adds a new Kryo default serializer to the Runtime.
addDefaultKryoSerializer(Class<?>, T) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Adds a new Kryo default serializer to the Runtime.
addDefaultKryoSerializer(Class<?>, Class<? extends Serializer<?>>) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Adds a new Kryo default serializer to the Runtime.
addDimension(long, boolean) - Method in class org.apache.flink.graph.generator.GridGraph
Required configuration for each dimension of the graph.
addDiskCost(double) - Method in class org.apache.flink.optimizer.costs.Costs
Adds the costs for disk to the current disk costs for this Costs object.
addEdge(Vertex<K, VV>, Vertex<K, VV>, EV) - Method in class org.apache.flink.graph.Graph
Adds the given edge to the graph.
addEdge(Vertex<K, VV>, Vertex<K, VV>, EV) - Method in class org.apache.flink.graph.scala.Graph
Adds the given edge to the graph.
addEdge(Integer, Integer, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
addEdges(List<Edge<K, EV>>) - Method in class org.apache.flink.graph.Graph
Adds the given list edges to the graph.
addEdges(List<Edge<K, EV>>) - Method in class org.apache.flink.graph.scala.Graph
Adds the given list edges to the graph.
addElementToLatestPane(Type) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
 
addElementToLatestPane(Type) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingKeyedTimePanes
 
addElementToLatestPane(Type) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AggregatingKeyedTimePanes
 
addFeedbackEdge(StreamTransformation<F>) - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
Adds a feedback edge.
addFeedbackEdge(StreamTransformation<T>) - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
Adds a feedback edge.
addField(Integer) - Method in class org.apache.flink.api.common.operators.util.FieldList
 
addField(Integer) - Method in class org.apache.flink.api.common.operators.util.FieldSet
 
addField(Value) - Method in class org.apache.flink.types.Record
 
addFields(int...) - Method in class org.apache.flink.api.common.operators.util.FieldList
 
addFields(FieldSet) - Method in class org.apache.flink.api.common.operators.util.FieldList
 
addFields(int...) - Method in class org.apache.flink.api.common.operators.util.FieldSet
 
addFields(FieldSet) - Method in class org.apache.flink.api.common.operators.util.FieldSet
 
addFile(File, String) - Method in class org.apache.flink.mesos.util.MesosArtifactServer
Adds a file to the artifact server.
addFileInputCost(long, Costs) - Method in class org.apache.flink.optimizer.costs.CostEstimator
 
addFileInputCost(long, Costs) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
 
addFirstInput(Operator<IN1>...) - Method in class org.apache.flink.api.common.operators.DualInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
addFirstInputs(List<Operator<IN1>>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
addForwardedField(int, int, int) - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
Adds, to the existing information, a field that is forwarded directly from the source record(s) in the first input to the destination record(s).
addForwardedField(int, int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
Adds, to the existing information, a field that is forwarded directly from the source record(s) to the destination record(s).
addForwardedField(int, int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties.AllFieldsForwardedProperties
 
addGarbageCollectorName(String) - Method in class org.apache.flink.runtime.webmonitor.metrics.MetricStore.TaskManagerMetricStore
 
addGeneralOptions(Options) - Method in interface org.apache.flink.client.cli.CustomCommandLine
Adds custom options to the existing general options.
addGeneralOptions(Options) - Method in class org.apache.flink.client.cli.DefaultCLI
 
addGeneralOptions(Options) - Method in class org.apache.flink.yarn.cli.FlinkYarnCLI
 
addGeneralOptions(Options) - Method in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
 
addGlobalProperties(RequestedGlobalProperties) - Method in class org.apache.flink.optimizer.dataproperties.InterestingProperties
 
addGroup(int) - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
 
addGroup(String) - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
 
addGroup(int) - Method in interface org.apache.flink.metrics.MetricGroup
Creates a new MetricGroup and adds it to this groups sub-groups.
addGroup(String) - Method in interface org.apache.flink.metrics.MetricGroup
Creates a new MetricGroup and adds it to this groups sub-groups.
addGroup(int) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
addGroup(String) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
addGroup(int) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
addGroup(String) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
addGroupExpr(SqlNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
 
addHash(int) - Method in class org.apache.flink.runtime.operators.util.BloomFilter
 
addHashPartitioningCost(EstimateProvider, Costs) - Method in class org.apache.flink.optimizer.costs.CostEstimator
 
addHashPartitioningCost(EstimateProvider, Costs) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
 
addHeuristicCpuCost(double) - Method in class org.apache.flink.optimizer.costs.Costs
Adds the given heuristic CPU cost to the current heuristic CPU cost for this Costs object.
addHeuristicDiskCost(double) - Method in class org.apache.flink.optimizer.costs.Costs
Adds the heuristic costs for disk to the current heuristic disk costs for this Costs object.
addHeuristicNetworkCost(double) - Method in class org.apache.flink.optimizer.costs.Costs
Adds the heuristic costs for network to the current heuristic network costs for this Costs object.
addHiddenChoices(String...) - Method in class org.apache.flink.graph.drivers.parameter.ChoiceParameter
Add additional hidden choices.
addHybridHashCosts(EstimateProvider, EstimateProvider, Costs, int) - Method in class org.apache.flink.optimizer.costs.CostEstimator
 
addHybridHashCosts(EstimateProvider, EstimateProvider, Costs, int) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
 
addId(UId) - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
Adds an ID to be stored with the current checkpoint.
addIfOpen(E) - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
Tries to add an element to the queue, if the queue is still open.
addIgnore(IterativeCondition<T>) - Method in class org.apache.flink.cep.nfa.State
 
addIgnore(State<T>, IterativeCondition<T>) - Method in class org.apache.flink.cep.nfa.State
 
addInEdge(StreamEdge) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
addInput(Operator<IN>...) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
addInput(Operator<IN>...) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
addInput(List<Operator<IN>>) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
addInputs(List<? extends Operator<IN>>) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
addInputToGroup(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
addInstanceListener(InstanceListener) - Method in class org.apache.flink.runtime.instance.InstanceManager
 
addInterestingProperties(InterestingProperties) - Method in class org.apache.flink.optimizer.dataproperties.InterestingProperties
 
addIOMetrics(AccessExecution, MetricFetcher, String, String) - Method in class org.apache.flink.runtime.webmonitor.utils.MutableIOMetrics
Adds the IO metrics for the given attempt to this object.
addIterationAggregator(String, Aggregator<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
addIterationAggregators(Collection<AggregatorWithName<?>>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
addJar(Path) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Adds the path of a JAR file required to run the job on a task manager.
addJob(JobGraph) - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
 
addJob(JobID) - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
Add a job to be monitored to retrieve the job leader id.
addJob(JobID, String) - Method in class org.apache.flink.runtime.taskexecutor.JobLeaderService
Add the given job to be monitored.
addLibFolderToShipFiles(Collection<File>) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
 
addList(List<T>) - Method in class org.apache.flink.util.UnionIterator
 
addListener(EventListener<Buffer>) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
Adds a buffer availability listener to the buffer provider.
addLocalCandidates(Channel, List<Set<? extends NamedChannel>>, RequestedGlobalProperties, List<PlanNode>, CostEstimator) - Method in class org.apache.flink.optimizer.dag.SingleInputNode
 
addLocalCandidates(Channel, Channel, List<Set<? extends NamedChannel>>, RequestedGlobalProperties, RequestedGlobalProperties, List<PlanNode>, OperatorDescriptorDual.LocalPropertiesPair[], CostEstimator) - Method in class org.apache.flink.optimizer.dag.TwoInputNode
 
addLocalMergeCost(EstimateProvider, EstimateProvider, Costs, int) - Method in class org.apache.flink.optimizer.costs.CostEstimator
 
addLocalMergeCost(EstimateProvider, EstimateProvider, Costs, int) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
 
addLocalProperties(RequestedLocalProperties) - Method in class org.apache.flink.optimizer.dataproperties.InterestingProperties
 
addLocalSortCost(EstimateProvider, Costs) - Method in class org.apache.flink.optimizer.costs.CostEstimator
 
addLocalSortCost(EstimateProvider, Costs) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
 
addLogicalOptRuleSet(RuleSet) - Method in class org.apache.flink.table.calcite.CalciteConfigBuilder
Appends the given optimization rule set to the built-in rule set.
AddLongValue() - Constructor for class org.apache.flink.graph.utils.GraphUtils.AddLongValue
 
addMasterHook(MasterTriggerRestoreHook<?>) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Adds the given master hook to the checkpoint coordinator.
addMasterState(MasterState) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
Adds a master state (state generated on the checkpoint coordinator) to the pending checkpoint.
addMetric(DMetric) - Method in class org.apache.flink.metrics.datadog.DSeries
 
addMetric(String, Metric) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
Adds the given metric to the group and registers it at the registry, if the group is not yet closed, and if no metric with the same name has been registered before.
addNameSpace(Set<String>) - Method in class org.apache.flink.runtime.util.DependencyVisitor
 
addNetworkCost(double) - Method in class org.apache.flink.optimizer.costs.Costs
Adds the costs for network to the current network costs for this Costs object.
addNode(Integer, String, Class<? extends AbstractInvokable>, StreamOperator<?>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
addNormRuleSet(RuleSet) - Method in class org.apache.flink.table.calcite.CalciteConfigBuilder
Appends the given normalization rule set to the built-in rule set.
addOffsetStateGauge(MetricGroup) - Method in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
Add current and committed offsets to metric group
addOperator(String) - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
addOperator(StreamTransformation<?>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Adds an operator to the list of operators that should be executed when calling StreamExecutionEnvironment.execute().
addOperator(Integer, String, StreamOperator<OUT>, TypeInformation<IN>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
addOutEdge(StreamEdge) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
addOutgoingChannel(Channel) - Method in class org.apache.flink.optimizer.plan.PlanNode
Adds a channel to a successor node to this node.
addOutgoingConnection(DagConnection) - Method in class org.apache.flink.optimizer.dag.BinaryUnionNode
 
addOutgoingConnection(DagConnection) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
Adds a new outgoing connection to this node.
addOutputSelector(Integer, OutputSelector<T>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
addOutputSelector(OutputSelector<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
addOutputShipStrategy(ShipStrategyType) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
addPackage(String) - Method in class org.apache.flink.runtime.util.JarFileCreator
Manually specify the package of the dependencies.
addPackages(String[]) - Method in class org.apache.flink.runtime.util.JarFileCreator
Manually specify the packages of the dependencies.
addParameter(Parameter<?>) - Method in class org.apache.flink.graph.drivers.parameter.ParameterizedBase
Adds a parameter to the list.
addPath(Path, Path) - Method in class org.apache.flink.mesos.util.MesosArtifactServer
Adds a path to the artifact server.
addPhysicalOptRuleSet(RuleSet) - Method in class org.apache.flink.table.calcite.CalciteConfigBuilder
Appends the given optimization rule set to the built-in rule set.
addProceed(State<T>, IterativeCondition<T>) - Method in class org.apache.flink.cep.nfa.State
 
addRandomPartitioningCost(EstimateProvider, Costs) - Method in class org.apache.flink.optimizer.costs.CostEstimator
 
addRandomPartitioningCost(EstimateProvider, Costs) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
 
addRange(long, long) - Method in class org.apache.flink.graph.generator.CirculantGraph
Required configuration for each range of offsets in the graph.
addRangePartitionCost(EstimateProvider, Costs) - Method in class org.apache.flink.optimizer.costs.CostEstimator
 
addRangePartitionCost(EstimateProvider, Costs) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
 
addReadFields(int, FieldSet) - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
Adds, to the existing information, field(s) that are read in the source record(s) from the first input.
addReadFields(FieldSet) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
Adds, to the existing information, field(s) that are read in the source record(s).
addRecord(T) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
Starts serializing and copying the given record to the target buffer (if available).
addRecord(T) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
Serializes the complete record to an intermediate data serialization buffer and starts copying it to the target buffer (if available).
addRecord(T) - Method in class org.apache.flink.runtime.operators.sort.LargeRecordHandler
 
addRequest(R) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
 
ADDRESS - Static variable in class org.apache.flink.configuration.JobManagerOptions
The config parameter defining the network address to connect to for communication with the job manager.
address - Variable in class org.apache.flink.core.memory.MemorySegment
The address to the data, relative to the heap memory byte array.
address() - Method in class org.apache.flink.runtime.akka.RemoteAddressExtensionImplementation
 
address() - Method in class org.apache.flink.runtime.messages.JobClientMessages.JobManagerLeaderAddress
 
address() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
Returns the network address the instance's task manager binds its sockets to.
ADDRESS_OPTION - Static variable in class org.apache.flink.client.cli.CliFrontendParser
 
addressLimit - Variable in class org.apache.flink.core.memory.MemorySegment
The address one byte after the last addressable byte.
addressString() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
Gets the IP address where the TaskManager operates.
addReusableArray(Class<?>, int) - Method in class org.apache.flink.table.codegen.CodeGenerator
Adds a reusable array to the member area of the generated Function.
addReusableConstructor(Seq<Class<?>>) - Method in class org.apache.flink.table.codegen.CodeGenerator
Adds a reusable constructor statement with the given parameter types.
addReusableDate() - Method in class org.apache.flink.table.codegen.CodeGenerator
Adds a reusable date to the beginning of the SAM of the generated Function.
addReusableDecimal(BigDecimal) - Method in class org.apache.flink.table.codegen.CodeGenerator
Adds a reusable BigDecimal to the member area of the generated Function.
addReusableFunction(UserDefinedFunction) - Method in class org.apache.flink.table.codegen.CodeGenerator
Adds a reusable UserDefinedFunction to the member area of the generated Function.
addReusableLocalTime() - Method in class org.apache.flink.table.codegen.CodeGenerator
Adds a reusable local time to the beginning of the SAM of the generated Function.
addReusableLocalTimestamp() - Method in class org.apache.flink.table.codegen.CodeGenerator
Adds a reusable local timestamp to the beginning of the SAM of the generated Function.
addReusableOutRecord(TypeInformation<?>) - Method in class org.apache.flink.table.codegen.CodeGenerator
Adds a reusable output record to the member area of the generated Function.
addReusablePrivateFieldAccess(Class<?>, String) - Method in class org.apache.flink.table.codegen.CodeGenerator
Adds a reusable Field to the member area of the generated Function.
addReusableTime() - Method in class org.apache.flink.table.codegen.CodeGenerator
Adds a reusable time to the beginning of the SAM of the generated Function.
addReusableTimestamp() - Method in class org.apache.flink.table.codegen.CodeGenerator
Adds a reusable timestamp to the beginning of the SAM of the generated Function.
addRunOptions(Options) - Method in interface org.apache.flink.client.cli.CustomCommandLine
Adds custom options to the existing run options.
addRunOptions(Options) - Method in class org.apache.flink.client.cli.DefaultCLI
 
addRunOptions(Options) - Method in class org.apache.flink.yarn.cli.FlinkYarnCLI
 
addRunOptions(Options) - Method in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
 
AddScoreToVertexValuesMapper() - Constructor for class org.apache.flink.graph.library.CommunityDetection.AddScoreToVertexValuesMapper
 
addSecondInput(Operator<IN2>...) - Method in class org.apache.flink.api.common.operators.DualInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
addSecondInputs(List<Operator<IN2>>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
addSemanticPropertiesHints() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
addSharedSlotAndAllocateSubSlot(SharedSlot, Locality, JobVertexID) - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
 
addSharedSlotAndAllocateSubSlot(SharedSlot, Locality, CoLocationConstraint) - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
 
addShipFiles(List<File>) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
 
addSink(SinkFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Adds the given sink to this DataStream.
addSink(SinkFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
 
addSink(Integer, String, StreamOperator<OUT>, TypeInformation<IN>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
addSink(SinkFunction<T>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Adds the given sink to this DataStream.
addSink(Function1<T, BoxedUnit>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Adds the given sink to this DataStream.
addSink(DataStream<IN>) - Static method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink
Writes a DataStream into a Cassandra database.
addSource(SourceFunction<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Adds a Data Source to the streaming topology.
addSource(SourceFunction<OUT>, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Ads a data source with a custom type information thus opening a DataStream.
addSource(SourceFunction<OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Ads a data source with a custom type information thus opening a DataStream.
addSource(SourceFunction<OUT>, String, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Ads a data source with a custom type information thus opening a DataStream.
addSource(Integer, String, StreamOperator<OUT>, TypeInformation<IN>, TypeInformation<OUT>, String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
addSource(SourceFunction<T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Create a DataStream using a user defined source function for arbitrary source functionality.
addSource(Function1<SourceFunction.SourceContext<T>, BoxedUnit>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Create a DataStream using a user defined source function for arbitrary source functionality.
addSourceFieldOffset(SingleInputSemanticProperties, int, int) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
Creates SemanticProperties by adding an offset to each input field index of the given SemanticProperties.
addSourceFieldOffsets(DualInputSemanticProperties, int, int, int, int) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
Creates SemanticProperties by adding offsets to each input field index of the given SemanticProperties.
addSqlOperatorTable(SqlOperatorTable) - Method in class org.apache.flink.table.calcite.CalciteConfigBuilder
Appends the given table to the built-in SQL operator table.
addStage() - Method in class org.apache.flink.cep.nfa.DeweyNumber
Creates a new dewey number from this such that a 0 is appended as new last digit.
addState(State<T>) - Method in class org.apache.flink.cep.nfa.NFA
 
addStates(Collection<State<T>>) - Method in class org.apache.flink.cep.nfa.NFA
 
addStateTransition(StateTransitionAction, State<T>, IterativeCondition<T>) - Method in class org.apache.flink.cep.nfa.State
 
addStreamedNestedLoopsCosts(EstimateProvider, EstimateProvider, long, Costs, int) - Method in class org.apache.flink.optimizer.costs.CostEstimator
 
addStreamedNestedLoopsCosts(EstimateProvider, EstimateProvider, long, Costs, int) - Method in class org.apache.flink.optimizer.costs.DefaultCostEstimator
 
addSuppressed(Throwable) - Static method in exception org.apache.flink.table.api.AmbiguousTableSourceConverterException
 
addSuppressed(Throwable) - Static method in exception org.apache.flink.table.api.CatalogAlreadyExistException
 
addSuppressed(Throwable) - Static method in exception org.apache.flink.table.api.CatalogNotExistException
 
addSuppressed(Throwable) - Static method in exception org.apache.flink.table.api.ExpressionParserException
 
addSuppressed(Throwable) - Static method in exception org.apache.flink.table.api.ExternalCatalogAlreadyExistException
 
addSuppressed(Throwable) - Static method in exception org.apache.flink.table.api.ExternalCatalogNotExistException
 
addSuppressed(Throwable) - Static method in exception org.apache.flink.table.api.NoMatchedTableSourceConverterException
 
addSuppressed(Throwable) - Static method in exception org.apache.flink.table.api.SqlParserException
 
addSuppressed(Throwable) - Static method in exception org.apache.flink.table.api.TableAlreadyExistException
 
addSuppressed(Throwable) - Static method in exception org.apache.flink.table.api.TableException
 
addSuppressed(Throwable) - Static method in exception org.apache.flink.table.api.TableNotExistException
 
addSuppressed(Throwable) - Static method in exception org.apache.flink.table.api.UnresolvedException
 
addSuppressed(Throwable) - Static method in exception org.apache.flink.table.api.ValidationException
 
addTake(State<T>, IterativeCondition<T>) - Method in class org.apache.flink.cep.nfa.State
 
addTake(IterativeCondition<T>) - Method in class org.apache.flink.cep.nfa.State
 
addTask(JobVertexID, ExecutionAttemptID, String, int, int) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerJobMetricGroup
 
addTask(Task) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Add the given task to the slot identified by the task's allocation id.
addTaskForJob(JobID, String, JobVertexID, ExecutionAttemptID, String, int, int) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
 
addToDefaults(String, String) - Method in class org.apache.flink.api.java.utils.ParameterTool
 
addToEnvironment(Map<String, String>, String, String) - Static method in class org.apache.flink.yarn.Utils
Copied method from org.apache.hadoop.yarn.util.Apps It was broken by YARN-1824 (2.4.0) and fixed for 2.4.1 by https://issues.apache.org/jira/browse/YARN-1931
addToMessageDigest(MessageDigest) - Method in class org.apache.flink.runtime.blob.BlobKey
Adds the BLOB key to the given MessageDigest.
addType(int, X) - Method in class org.apache.flink.optimizer.postpass.AbstractSchema
 
addUniqueField(FieldSet) - Method in class org.apache.flink.api.common.operators.CompilerHints
Adds a FieldSet to be unique
addUniqueField(int) - Method in class org.apache.flink.api.common.operators.CompilerHints
Adds a field as having only unique values.
addUniqueFieldCombination(FieldSet) - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
 
addUniqueFields(Set<FieldSet>) - Method in class org.apache.flink.api.common.operators.CompilerHints
Adds multiple FieldSets to be unique
addUniqueFields(FieldSet) - Method in class org.apache.flink.optimizer.dataproperties.LocalProperties
Adds a combination of fields that are unique in these data properties.
addVertex(Vertex<K, VV>) - Method in class org.apache.flink.graph.Graph
Adds the input vertex to the graph.
addVertex(Vertex<K, VV>) - Method in class org.apache.flink.graph.scala.Graph
Adds the input vertex to the graph.
addVertex(JobVertex) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Adds a new task vertex to the job graph if it is not already included.
addVertex(JobVertex) - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
 
addVertexToGroup(JobVertexID) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
 
addVertices(List<Vertex<K, VV>>) - Method in class org.apache.flink.graph.Graph
Adds the list of vertices, passed as input, to the graph.
addVertices(List<Vertex<K, VV>>) - Method in class org.apache.flink.graph.scala.Graph
Adds the list of vertices, passed as input, to the graph.
addVirtualPartitionNode(Integer, Integer, StreamPartitioner<?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
Adds a new virtual node that is used to connect a downstream vertex to an input with a certain partitioning.
addVirtualSelectNode(Integer, Integer, List<String>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
Adds a new virtual node that is used to connect a downstream vertex to only the outputs with the selected names.
addVirtualSideOutputNode(Integer, Integer, OutputTag) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
Adds a new virtual node that is used to connect a downstream vertex to only the outputs with the selected side-output OutputTag.
addWindow(W, MergingWindowSet.MergeFunction<W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
Adds a new Window to the set of in-flight windows.
AdjacencyList(long, long[]) - Constructor for class org.apache.flink.examples.scala.graph.PageRankBasic.AdjacencyList
 
AdjacencyList$() - Constructor for class org.apache.flink.examples.scala.graph.PageRankBasic.AdjacencyList$
 
adjustGlobalPropertiesForFullParallelismChange() - Method in class org.apache.flink.optimizer.plan.Channel
 
adjustInputRef(SqlToRelConverter.Blackboard, RexInputRef) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Adjusts the type of a reference to an input field to account for nulls introduced by outer joins; and adjusts the offset to match the physical implementation.
adjustTop() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
Should be called when the Object at top changes values.
adjustType(SqlValidator, SqlCall, RelDataType) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
adjustType(SqlValidator, SqlCall, RelDataType) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
adjustType(SqlValidator, SqlCall, RelDataType) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
adjustType(SqlValidator, SqlCall, RelDataType) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
advance() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
Advances the view to the next memory segment.
advance() - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
Moves the output view to the next page.
advanceTime(NFA<IN>, long) - Method in class org.apache.flink.cep.operator.AbstractKeyedCEPPatternOperator
Advances the time for the given NFA to the given timestamp.
advanceTime(NFA<IN>, long) - Method in class org.apache.flink.cep.operator.KeyedCEPPatternOperator
 
advanceTime(NFA<IN>, long) - Method in class org.apache.flink.cep.operator.TimeoutKeyedCEPPatternOperator
 
advanceWatermark(long) - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
 
afterTableFunction(SqlToRelConverter.Blackboard, SqlCall, LogicalTableFunctionScan) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
 
agg() - Method in class org.apache.flink.table.expressions.OverCall
 
agg() - Method in class org.apache.flink.table.expressions.UnresolvedOverCall
 
AggConverter(SqlToRelConverter.Blackboard, SqlSelect) - Constructor for class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
Creates an AggConverter.
AggFunctionCall - Class in org.apache.flink.table.expressions
 
AggFunctionCall(AggregateFunction<?, ?>, Seq<Expression>) - Constructor for class org.apache.flink.table.expressions.AggFunctionCall
 
AggFunctionCall$ - Class in org.apache.flink.table.expressions
 
AggFunctionCall$() - Constructor for class org.apache.flink.table.expressions.AggFunctionCall$
 
aggregate(T) - Method in interface org.apache.flink.api.common.aggregators.Aggregator
Aggregates the given element.
aggregate(DoubleValue) - Method in class org.apache.flink.api.common.aggregators.DoubleSumAggregator
 
aggregate(double) - Method in class org.apache.flink.api.common.aggregators.DoubleSumAggregator
Adds the given value to the current aggregate.
aggregate(LongValue) - Method in class org.apache.flink.api.common.aggregators.LongSumAggregator
 
aggregate(long) - Method in class org.apache.flink.api.common.aggregators.LongSumAggregator
Adds the given value to the current aggregate.
aggregate(long) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregator
 
aggregate(LongValue) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregator
 
aggregate(T) - Method in class org.apache.flink.api.java.aggregation.AggregationFunction
 
aggregate(U) - Method in class org.apache.flink.api.java.aggregation.MaxAggregationFunction.ImmutableMaxAgg
 
aggregate(U) - Method in class org.apache.flink.api.java.aggregation.MaxAggregationFunction.MutableMaxAgg
 
aggregate(U) - Method in class org.apache.flink.api.java.aggregation.MinAggregationFunction.ImmutableMinAgg
 
aggregate(U) - Method in class org.apache.flink.api.java.aggregation.MinAggregationFunction.MutableMinAgg
 
aggregate(Byte) - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.ByteSumAgg
 
aggregate(ByteValue) - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.ByteValueSumAgg
 
aggregate(Double) - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.DoubleSumAgg
 
aggregate(DoubleValue) - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.DoubleValueSumAgg
 
aggregate(Float) - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.FloatSumAgg
 
aggregate(FloatValue) - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.FloatValueSumAgg
 
aggregate(Integer) - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.IntSumAgg
 
aggregate(IntValue) - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.IntValueSumAgg
 
aggregate(Long) - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.LongSumAgg
 
aggregate(LongValue) - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.LongValueSumAgg
 
aggregate(Short) - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.ShortSumAgg
 
aggregate(ShortValue) - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.ShortValueSumAgg
 
aggregate(Aggregations, int) - Method in class org.apache.flink.api.java.DataSet
Applies an Aggregate transformation on a non-grouped Tuple DataSet.
Note: Only Tuple DataSets can be aggregated. The transformation applies a built-in Aggregation on a specified field of a Tuple DataSet.
aggregate(Aggregations, int) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Applies an Aggregate transformation on a grouped Tuple DataSet.
Note: Only Tuple DataSets can be aggregated. The transformation applies a built-in Aggregation on a specified field of a Tuple group.
aggregate(T) - Method in interface org.apache.flink.api.java.summarize.aggregation.Aggregator
Add a value to the current aggregation
aggregate(Boolean) - Method in class org.apache.flink.api.java.summarize.aggregation.BooleanSummaryAggregator
 
aggregate(Double) - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MaxDoubleAggregator
 
aggregate(Double) - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MinDoubleAggregator
 
aggregate(Double) - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.SumDoubleAggregator
 
aggregate(Float) - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MaxFloatAggregator
 
aggregate(Float) - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MinFloatAggregator
 
aggregate(Float) - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.SumFloatAggregator
 
aggregate(Integer) - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MaxIntegerAggregator
 
aggregate(Integer) - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MinIntegerAggregator
 
aggregate(Integer) - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.SumIntegerAggregator
 
aggregate(Long) - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MaxLongAggregator
 
aggregate(Long) - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MinLongAggregator
 
aggregate(Long) - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.SumLongAggregator
 
aggregate(T) - Method in class org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
Add a value to the current aggregation
aggregate(Object) - Method in class org.apache.flink.api.java.summarize.aggregation.ObjectSummaryAggregator
 
aggregate(Short) - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MaxShortAggregator
 
aggregate(Short) - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MinShortAggregator
 
aggregate(Short) - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.SumShortAggregator
 
aggregate(String) - Method in class org.apache.flink.api.java.summarize.aggregation.StringSummaryAggregator
 
aggregate(Tuple) - Method in class org.apache.flink.api.java.summarize.aggregation.TupleSummaryAggregator
 
aggregate(VT) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator
 
aggregate(Aggregations, int) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
aggregate(Aggregations, String) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
aggregate(Aggregations, int) - Method in class org.apache.flink.api.scala.DataSet
Creates a new DataSet by aggregating the specified tuple field using the given aggregation function.
aggregate(Aggregations, String) - Method in class org.apache.flink.api.scala.DataSet
Creates a new DataSet by aggregating the specified field using the given aggregation function.
aggregate(Aggregations, String) - Method in class org.apache.flink.api.scala.GroupedDataSet
Creates a new DataSet by aggregating the specified tuple field using the given aggregation function.
aggregate(Aggregations, int) - Method in class org.apache.flink.api.scala.GroupedDataSet
Creates a new DataSet by aggregating the specified field using the given aggregation function.
aggregate(AggregateFunction<T, ACC, R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given AggregateFunction to each window.
aggregate(AggregateFunction<T, ACC, R>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given AggregateFunction to each window.
aggregate(AggregateFunction<T, ACC, V>, AllWindowFunction<V, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
aggregate(AggregateFunction<T, ACC, V>, AllWindowFunction<V, R, W>, TypeInformation<ACC>, TypeInformation<V>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
aggregate(AggregateFunction<T, ACC, V>, ProcessAllWindowFunction<V, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
aggregate(AggregateFunction<T, ACC, V>, ProcessAllWindowFunction<V, R, W>, TypeInformation<ACC>, TypeInformation<V>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
aggregate(AggregationFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
 
aggregate(AggregateFunction<T, ACC, R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given aggregation function to each window.
aggregate(AggregateFunction<T, ACC, R>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given aggregation function to each window.
aggregate(AggregateFunction<T, ACC, V>, WindowFunction<V, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
aggregate(AggregateFunction<T, ACC, V>, WindowFunction<V, R, K, W>, TypeInformation<ACC>, TypeInformation<V>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
aggregate(AggregateFunction<T, ACC, V>, ProcessWindowFunction<V, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
aggregate(AggregateFunction<T, ACC, V>, ProcessWindowFunction<V, R, K, W>, TypeInformation<ACC>, TypeInformation<V>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
aggregate(AggregateFunction<T, ACC, R>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Applies the given aggregation function to each window.
aggregate(AggregateFunction<T, ACC, V>, AllWindowFunction<V, R, W>, TypeInformation<ACC>, TypeInformation<V>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Applies the given window function to each window.
aggregate(AggregateFunction<T, ACC, V>, ProcessAllWindowFunction<V, R, W>, TypeInformation<ACC>, TypeInformation<V>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Applies the given window function to each window.
aggregate(AggregateFunction<T, ACC, V>, Function3<W, Iterable<V>, Collector<R>, BoxedUnit>, TypeInformation<ACC>, TypeInformation<V>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Applies the given window function to each window.
aggregate(AggregationFunction.AggregationType, int) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
 
aggregate(AggregateFunction<T, ACC, R>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Applies the given aggregation function to each window and key.
aggregate(AggregateFunction<T, ACC, V>, WindowFunction<V, R, K, W>, TypeInformation<ACC>, TypeInformation<V>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Applies the given window function to each window.
aggregate(AggregateFunction<T, ACC, V>, Function4<K, W, Iterable<V>, Collector<R>, BoxedUnit>, TypeInformation<ACC>, TypeInformation<V>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Applies the given window function to each window.
aggregate(AggregateFunction<T, ACC, V>, ProcessWindowFunction<V, R, K, W>, TypeInformation<ACC>, TypeInformation<V>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Applies the given window function to each window.
aggregate(AggregationFunction.AggregationType, int) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
 
aggregate(LogicalWindow, RelBuilder.GroupKey, Seq<FlinkRelBuilder.NamedWindowProperty>, Iterable<RelBuilder.AggCall>) - Method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
Aggregate - Class in org.apache.flink.table.plan.logical
 
Aggregate(Seq<Expression>, Seq<NamedExpression>, LogicalNode) - Constructor for class org.apache.flink.table.plan.logical.Aggregate
 
Aggregate$ - Class in org.apache.flink.table.plan.logical
 
Aggregate$() - Constructor for class org.apache.flink.table.plan.logical.Aggregate$
 
AggregateAggFunction - Class in org.apache.flink.table.runtime.aggregate
Aggregate Function used for the aggregate operator in WindowedStream
AggregateAggFunction(GeneratedAggregationsFunction) - Constructor for class org.apache.flink.table.runtime.aggregate.AggregateAggFunction
 
AggregateApplyAllWindowFunction<W extends Window,T,ACC,V,R> - Class in org.apache.flink.streaming.api.functions.windowing
AggregateApplyAllWindowFunction(AggregateFunction<T, ACC, V>, AllWindowFunction<V, R, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.AggregateApplyAllWindowFunction
 
AggregateApplyWindowFunction<K,W extends Window,T,ACC,V,R> - Class in org.apache.flink.streaming.api.functions.windowing
AggregateApplyWindowFunction(AggregateFunction<T, ACC, V>, WindowFunction<V, R, K, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.AggregateApplyWindowFunction
 
aggregateBuffer() - Method in class org.apache.flink.table.runtime.aggregate.DataSetTumbleTimeWindowAggReduceGroupFunction
 
aggregateCall(SqlAggFunction, boolean, RexNode, String, RexNode[]) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
aggregateCall(SqlAggFunction, boolean, RexNode, String, Iterable<? extends RexNode>) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
AggregateDataSet<T> - Class in org.apache.flink.api.scala
The result of DataSet.aggregate.
AggregateDataSet(ScalaAggregateOperator<T>, ClassTag<T>) - Constructor for class org.apache.flink.api.scala.AggregateDataSet
 
aggregateExpressions() - Method in class org.apache.flink.table.plan.logical.Aggregate
 
aggregateExpressions() - Method in class org.apache.flink.table.plan.logical.WindowAggregate
 
AggregateFunction<IN,ACC,OUT> - Interface in org.apache.flink.api.common.functions
The AggregateFunction is a flexible aggregation function, characterized by the following features: The aggregates may use different types for input values, intermediate aggregates, and result type, to support a wide range of aggregation types. Support for distributive aggregations: Different intermediate aggregates can be merged together, to allow for pre-aggregation/final-aggregation optimizations.
aggregateFunction() - Method in class org.apache.flink.table.expressions.AggFunctionCall
 
aggregateFunction() - Method in class org.apache.flink.table.expressions.UDAGGExpression
 
AggregateFunction<T,ACC> - Class in org.apache.flink.table.functions
Base class for User-Defined Aggregates.
AggregateFunction() - Constructor for class org.apache.flink.table.functions.AggregateFunction
 
AggregateOperator<IN> - Class in org.apache.flink.api.java.operators
This operator represents the application of a "aggregate" operation on a data set, and the result data set produced by the function.
AggregateOperator(DataSet<IN>, Aggregations, int, String) - Constructor for class org.apache.flink.api.java.operators.AggregateOperator
Non grouped aggregation
AggregateOperator(Grouping<IN>, Aggregations, int, String) - Constructor for class org.apache.flink.api.java.operators.AggregateOperator
Grouped aggregation
AggregateOperator.AggregatingUdf<T extends Tuple> - Class in org.apache.flink.api.java.operators
 
aggregateUserAccumulators() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Merges all accumulator results from the tasks previously executed in the Executions.
AggregateUtil - Class in org.apache.flink.table.runtime.aggregate
 
AggregateUtil() - Constructor for class org.apache.flink.table.runtime.aggregate.AggregateUtil
 
AggregateUtil$ - Class in org.apache.flink.table.runtime.aggregate
 
AggregateUtil$() - Constructor for class org.apache.flink.table.runtime.aggregate.AggregateUtil$
 
AggregatingKeyedTimePanes<Type,Key> - Class in org.apache.flink.streaming.runtime.operators.windowing
Key/value map organized in panes for aggregating windows (with a reduce function).
AggregatingKeyedTimePanes(KeySelector<Type, Key>, ReduceFunction<Type>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.AggregatingKeyedTimePanes
 
AggregatingProcessingTimeWindowOperator<KEY,IN> - Class in org.apache.flink.streaming.runtime.operators.windowing
Deprecated.
Deprecated in favour of the generic WindowOperator. This was an optimized implementation used for aligned windows.
AggregatingProcessingTimeWindowOperator(ReduceFunction<IN>, KeySelector<IN, KEY>, TypeSerializer<KEY>, TypeSerializer<IN>, long, long) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.AggregatingProcessingTimeWindowOperator
Deprecated.
 
aggregatingSelectScope - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
 
AggregatingState<IN,OUT> - Interface in org.apache.flink.api.common.state
State interface for aggregating state, based on an AggregateFunction.
AggregatingStateDescriptor<IN,ACC,OUT> - Class in org.apache.flink.api.common.state
A StateDescriptor for AggregatingState.
AggregatingStateDescriptor(String, AggregateFunction<IN, ACC, OUT>, Class<ACC>) - Constructor for class org.apache.flink.api.common.state.AggregatingStateDescriptor
Creates a new state descriptor with the given name, function, and type.
AggregatingStateDescriptor(String, AggregateFunction<IN, ACC, OUT>, TypeInformation<ACC>) - Constructor for class org.apache.flink.api.common.state.AggregatingStateDescriptor
Creates a new ReducingStateDescriptor with the given name and default value.
AggregatingStateDescriptor(String, AggregateFunction<IN, ACC, OUT>, TypeSerializer<ACC>) - Constructor for class org.apache.flink.api.common.state.AggregatingStateDescriptor
Creates a new ValueStateDescriptor with the given name and default value.
AggregatingUdf(AggregationFunction<Object>[], int[]) - Constructor for class org.apache.flink.api.java.operators.AggregateOperator.AggregatingUdf
 
AggregatingUdf(TypeInformation<T>, AggregationFunction<Object>[], int[]) - Constructor for class org.apache.flink.api.scala.operators.ScalaAggregateOperator.AggregatingUdf
 
Aggregation - Class in org.apache.flink.table.expressions
 
Aggregation() - Constructor for class org.apache.flink.table.expressions.Aggregation
 
AggregationFunction<T> - Class in org.apache.flink.api.java.aggregation
 
AggregationFunction() - Constructor for class org.apache.flink.api.java.aggregation.AggregationFunction
 
AggregationFunction<T> - Class in org.apache.flink.streaming.api.functions.aggregation
Holder class for aggregation types that can be used on a windowed stream or keyed stream.
AggregationFunction() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.AggregationFunction
 
AggregationFunction.AggregationType - Enum in org.apache.flink.streaming.api.functions.aggregation
Aggregation types that can be used on a windowed stream or keyed stream.
AggregationFunctionFactory - Interface in org.apache.flink.api.java.aggregation
 
Aggregations - Enum in org.apache.flink.api.java.aggregation
 
aggregationToString(RelDataType, int[], RelDataType, Seq<Pair<AggregateCall, String>>, Seq<FlinkRelBuilder.NamedWindowProperty>) - Method in interface org.apache.flink.table.plan.nodes.CommonAggregate
 
aggregationToString(RelDataType, int[], RelDataType, Seq<Pair<AggregateCall, String>>, Seq<FlinkRelBuilder.NamedWindowProperty>) - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
aggregationToString(RelDataType, RelDataType, Seq<Pair<AggregateCall, String>>) - Method in interface org.apache.flink.table.plan.nodes.OverAggregate
 
Aggregator<T extends Value> - Interface in org.apache.flink.api.common.aggregators
Aggregators are a means of aggregating values across parallel instances of a function.
Aggregator<T,R> - Interface in org.apache.flink.api.java.summarize.aggregation
Generic interface for aggregation
AGGREGATOR_NAME - Static variable in class org.apache.flink.runtime.iterative.convergence.WorksetEmptyConvergenceCriterion
 
AggregatorRegistry - Class in org.apache.flink.api.common.aggregators
A registry for iteration Aggregators.
AggregatorRegistry() - Constructor for class org.apache.flink.api.common.aggregators.AggregatorRegistry
 
AggregatorWithName<T extends Value> - Class in org.apache.flink.api.common.aggregators
Simple utility class holding an Aggregator with the name it is registered under.
AggregatorWithName(String, Aggregator<T>) - Constructor for class org.apache.flink.api.common.aggregators.AggregatorWithName
Creates a new instance for the given aggregator and name.
AggSqlFunction - Class in org.apache.flink.table.functions.utils
Calcite wrapper for user-defined aggregate functions.
AggSqlFunction(String, AggregateFunction<?, ?>, TypeInformation<?>, FlinkTypeFactory, boolean) - Constructor for class org.apache.flink.table.functions.utils.AggSqlFunction
 
AggSqlFunction$ - Class in org.apache.flink.table.functions.utils
 
AggSqlFunction$() - Constructor for class org.apache.flink.table.functions.utils.AggSqlFunction$
 
AKKA_ASK_TIMEOUT - Static variable in class org.apache.flink.configuration.AkkaOptions
Timeout for akka ask calls
AKKA_ASK_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
Timeout for all blocking calls on the cluster side
AKKA_CLIENT_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
Timeout for all blocking calls on the client side
AKKA_DISPATCHER_THROUGHPUT - Static variable in class org.apache.flink.configuration.ConfigConstants
Maximum number of messages until another actor is executed by the same thread
AKKA_FRAMESIZE - Static variable in class org.apache.flink.configuration.ConfigConstants
Maximum framesize of akka messages
AKKA_JVM_EXIT_ON_FATAL_ERROR - Static variable in class org.apache.flink.configuration.ConfigConstants
Exit JVM on fatal Akka errors
AKKA_LOG_LIFECYCLE_EVENTS - Static variable in class org.apache.flink.configuration.ConfigConstants
Log lifecycle events
AKKA_LOOKUP_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
Timeout for all blocking calls that look up remote actors
AKKA_SSL_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
Override SSL support for the Akka transport
AKKA_STARTUP_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
Timeout for the startup of the actor system
AKKA_TCP_TIMEOUT - Static variable in class org.apache.flink.configuration.AkkaOptions
The Akka tcp connection timeout.
AKKA_TCP_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
Akka TCP timeout
AKKA_TRANSPORT_HEARTBEAT_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
Heartbeat interval of the transport failure detector
AKKA_TRANSPORT_HEARTBEAT_PAUSE - Static variable in class org.apache.flink.configuration.ConfigConstants
Allowed heartbeat pause for the transport failure detector
AKKA_TRANSPORT_THRESHOLD - Static variable in class org.apache.flink.configuration.ConfigConstants
Detection threshold of transport failure detector
AKKA_WATCH_HEARTBEAT_INTERVAL - Static variable in class org.apache.flink.configuration.AkkaOptions
The Akka death watch heartbeat interval.
AKKA_WATCH_HEARTBEAT_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
Heartbeat interval of watch failure detector
AKKA_WATCH_HEARTBEAT_PAUSE - Static variable in class org.apache.flink.configuration.AkkaOptions
The maximum acceptable Akka death watch heartbeat pause.
AKKA_WATCH_HEARTBEAT_PAUSE - Static variable in class org.apache.flink.configuration.ConfigConstants
Allowed heartbeat pause for the watch failure detector
AKKA_WATCH_THRESHOLD - Static variable in class org.apache.flink.configuration.ConfigConstants
Detection threshold for the phi accrual watch failure detector
AkkaActorGateway - Class in org.apache.flink.runtime.instance
Concrete ActorGateway implementation which uses Akka to communicate with remote actors.
AkkaActorGateway(ActorRef, UUID) - Constructor for class org.apache.flink.runtime.instance.AkkaActorGateway
 
AkkaOptions - Class in org.apache.flink.configuration
Akka configuration options.
AkkaOptions() - Constructor for class org.apache.flink.configuration.AkkaOptions
 
AkkaRpcException - Exception in org.apache.flink.runtime.rpc.akka.exceptions
Base class for Akka RPC related exceptions.
AkkaRpcException(String) - Constructor for exception org.apache.flink.runtime.rpc.akka.exceptions.AkkaRpcException
 
AkkaRpcException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rpc.akka.exceptions.AkkaRpcException
 
AkkaRpcException(Throwable) - Constructor for exception org.apache.flink.runtime.rpc.akka.exceptions.AkkaRpcException
 
AkkaRpcService - Class in org.apache.flink.runtime.rpc.akka
Akka based RpcService implementation.
AkkaRpcService(ActorSystem, Time) - Constructor for class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
AkkaRpcServiceUtils - Class in org.apache.flink.runtime.rpc.akka
These RPC utilities contain helper methods around RPC use, such as starting an RPC service, or constructing RPC addresses.
AkkaRpcServiceUtils.AkkaProtocol - Enum in org.apache.flink.runtime.rpc.akka
 
AkkaUtils - Class in org.apache.flink.runtime.akka
This class contains utility functions for akka.
AkkaUtils() - Constructor for class org.apache.flink.runtime.akka.AkkaUtils
 
AkkaUtils$ - Class in org.apache.flink.runtime.akka
This class contains utility functions for akka.
AkkaUtils$() - Constructor for class org.apache.flink.runtime.akka.AkkaUtils$
 
alias() - Method in class org.apache.flink.table.api.OverWindow
 
alias() - Method in class org.apache.flink.table.api.Window
 
alias(RexNode, String) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
Alias - Class in org.apache.flink.table.expressions
 
Alias(Expression, String, Seq<String>) - Constructor for class org.apache.flink.table.expressions.Alias
 
alias() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
alias() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
alias() - Method in class org.apache.flink.table.expressions.UnresolvedOverCall
 
alias() - Method in class org.apache.flink.table.plan.logical.SessionGroupWindow
 
alias() - Method in class org.apache.flink.table.plan.logical.SlidingGroupWindow
 
alias() - Method in class org.apache.flink.table.plan.logical.TumblingGroupWindow
 
Alias$ - Class in org.apache.flink.table.expressions
 
Alias$() - Constructor for class org.apache.flink.table.expressions.Alias$
 
aliasAttribute() - Method in class org.apache.flink.table.plan.logical.LogicalWindow
 
aliasAttribute() - Static method in class org.apache.flink.table.plan.logical.SessionGroupWindow
 
aliasAttribute() - Static method in class org.apache.flink.table.plan.logical.SlidingGroupWindow
 
aliasAttribute() - Static method in class org.apache.flink.table.plan.logical.TumblingGroupWindow
 
aliasList() - Method in class org.apache.flink.table.plan.logical.AliasNode
 
aliasMapping() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
aliasMapping() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
aliasName() - Method in class org.apache.flink.table.expressions.GetCompositeField
Gives a meaningful alias if possible (e.g.
AliasNode - Class in org.apache.flink.table.plan.logical
 
AliasNode(Seq<Expression>, LogicalNode) - Constructor for class org.apache.flink.table.plan.logical.AliasNode
 
AliasNode$ - Class in org.apache.flink.table.plan.logical
 
AliasNode$() - Constructor for class org.apache.flink.table.plan.logical.AliasNode$
 
AlignmentLimitExceededException - Exception in org.apache.flink.runtime.checkpoint.decline
Exception indicating that a checkpoint was declined because too many bytes were buffered in the alignment phase.
AlignmentLimitExceededException(long) - Constructor for exception org.apache.flink.runtime.checkpoint.decline.AlignmentLimitExceededException
 
all() - Method in class org.apache.flink.table.plan.logical.Intersect
 
all() - Method in class org.apache.flink.table.plan.logical.Minus
 
all() - Method in class org.apache.flink.table.plan.logical.Union
 
AllFieldsForwardedProperties() - Constructor for class org.apache.flink.api.common.operators.SingleInputSemanticProperties.AllFieldsForwardedProperties
 
AllGroupCombineDriver<IN,OUT> - Class in org.apache.flink.runtime.operators
Non-chained driver for the partial group reduce operator that acts like a combiner with a custom output type OUT.
AllGroupCombineDriver() - Constructor for class org.apache.flink.runtime.operators.AllGroupCombineDriver
 
AllGroupCombineProperties - Class in org.apache.flink.optimizer.operators
 
AllGroupCombineProperties() - Constructor for class org.apache.flink.optimizer.operators.AllGroupCombineProperties
 
AllGroupReduceDriver<IT,OT> - Class in org.apache.flink.runtime.operators
GroupReduceDriver task which is executed by a Task Manager.
AllGroupReduceDriver() - Constructor for class org.apache.flink.runtime.operators.AllGroupReduceDriver
 
AllGroupReduceProperties - Class in org.apache.flink.optimizer.operators
 
AllGroupReduceProperties() - Constructor for class org.apache.flink.optimizer.operators.AllGroupReduceProperties
 
AllGroupWithPartialPreGroupProperties - Class in org.apache.flink.optimizer.operators
 
AllGroupWithPartialPreGroupProperties() - Constructor for class org.apache.flink.optimizer.operators.AllGroupWithPartialPreGroupProperties
 
allocate(JobID, AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
Allocate the task slot for the given job and allocation id.
AllocatedSlot - Class in org.apache.flink.runtime.jobmanager.slots
The AllocatedSlot represents a slot that the JobManager allocated from a TaskManager.
AllocatedSlot(AllocationID, JobID, TaskManagerLocation, int, ResourceProfile, TaskManagerGateway) - Constructor for class org.apache.flink.runtime.jobmanager.slots.AllocatedSlot
 
allocatePages(Object, int) - Method in class org.apache.flink.runtime.memory.MemoryManager
Allocates a set of memory segments from this memory manager.
allocatePages(Object, List<MemorySegment>, int) - Method in class org.apache.flink.runtime.memory.MemoryManager
Allocates a set of memory segments from this memory manager.
allocateResource(ResourceProfile) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerServices
Allocates a resource according to the resource profile.
allocateResource(ResourceProfile) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ResourceManagerActions
 
allocateResourcesForAll(SlotProvider, boolean) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
Acquires a slot for all the execution vertices of this ExecutionJobVertex.
allocateSegments(int) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
attempts to allocate specified number of segments and should only be used by compaction partition fails silently if not enough segments are available since next compaction could still succeed
allocateSharedSlot(JobID, SlotSharingGroupAssignment) - Method in class org.apache.flink.runtime.instance.Instance
Allocates a shared slot on this TaskManager instance.
allocateSimpleSlot(JobID) - Method in class org.apache.flink.runtime.instance.Instance
Allocates a simple slot on this TaskManager instance.
allocateSlot(ScheduledUnit, ResourceProfile, Iterable<TaskManagerLocation>) - Method in class org.apache.flink.runtime.instance.SlotPool
 
allocateSlot(ScheduledUnit, ResourceProfile, Iterable<TaskManagerLocation>, Time) - Method in interface org.apache.flink.runtime.instance.SlotPoolGateway
 
allocateSlot(ScheduledUnit, boolean) - Method in interface org.apache.flink.runtime.instance.SlotProvider
Allocating slot with specific requirement.
allocateSlot(ScheduledUnit, boolean) - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
allocateSlot(int, JobID, AllocationID, Time) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Allocate the slot with the given index for the given job and allocation id.
allocateSlotForExecution(SlotProvider, boolean) - Method in class org.apache.flink.runtime.executiongraph.Execution
 
allocateUnpooledSegment(int, Object) - Method in class org.apache.flink.core.memory.HeapMemorySegment.HeapMemorySegmentFactory
 
allocateUnpooledSegment(int, Object) - Method in class org.apache.flink.core.memory.HybridMemorySegment.HybridMemorySegmentFactory
 
allocateUnpooledSegment(int) - Static method in class org.apache.flink.core.memory.MemorySegmentFactory
Allocates some unpooled memory and creates a new memory segment that represents that memory.
allocateUnpooledSegment(int, Object) - Static method in class org.apache.flink.core.memory.MemorySegmentFactory
Allocates some unpooled memory and creates a new memory segment that represents that memory.
allocateUnpooledSegment(int, Object) - Method in interface org.apache.flink.core.memory.MemorySegmentFactory.Factory
Allocates some unpooled memory and creates a new memory segment that represents that memory.
AllocationID - Class in org.apache.flink.runtime.clusterframework.types
Unique identifier for a slot allocated by a JobManager from a TaskManager.
AllocationID() - Constructor for class org.apache.flink.runtime.clusterframework.types.AllocationID
Constructs a new random AllocationID.
AllocationID(long, long) - Constructor for class org.apache.flink.runtime.clusterframework.types.AllocationID
Constructs a new AllocationID with the given parts.
allOutputs - Variable in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
allowCombinations() - Method in class org.apache.flink.cep.pattern.Pattern
Applicable only to Quantifier.ONE_OR_MORE(ConsumingStrategy) and Quantifier.TIMES(ConsumingStrategy) patterns, this option allows more flexibility to the matching events.
allowCombinations() - Method in class org.apache.flink.cep.scala.pattern.Pattern
Applicable only to Quantifier.ONE_OR_MORE() and Quantifier.TIMES() patterns, this option allows more flexibility to the matching events.
allowedLateness(Time) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Sets the time by which elements are allowed to be late.
allowedLateness(Time) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Sets the time by which elements are allowed to be late.
allowedLateness(Time) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Sets the allowed lateness to a user-specified value.
allowedLateness(Time) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Sets the allowed lateness to a user-specified value.
allowedLateness - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
The allowed lateness for elements.
allowLazyDeployment() - Method in enum org.apache.flink.runtime.jobgraph.ScheduleMode
Returns whether we are allowed to deploy consumers lazily.
allowNonRestoredState() - Method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
Returns whether non restored state is allowed if the savepoint contains state that cannot be mapped back to the job.
allowsFraming() - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
allowsFraming() - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
allowsFraming() - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
allowsFraming() - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
AllReduceDriver<T> - Class in org.apache.flink.runtime.operators
Reduce task which is executed by a Task Manager.
AllReduceDriver() - Constructor for class org.apache.flink.runtime.operators.AllReduceDriver
 
AllReduceProperties - Class in org.apache.flink.optimizer.operators
 
AllReduceProperties() - Constructor for class org.apache.flink.optimizer.operators.AllReduceProperties
 
allStartedWorkers() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Gets an iterable for all currently started TaskManagers.
AllWindowedStream<T,W extends Window> - Class in org.apache.flink.streaming.api.datastream
A AllWindowedStream represents a data stream where the stream of elements is split into windows based on a WindowAssigner.
AllWindowedStream(DataStream<T>, WindowAssigner<? super T, W>) - Constructor for class org.apache.flink.streaming.api.datastream.AllWindowedStream
 
AllWindowedStream<T,W extends Window> - Class in org.apache.flink.streaming.api.scala
A AllWindowedStream represents a data stream where the stream of elements is split into windows based on a WindowAssigner.
AllWindowedStream(AllWindowedStream<T, W>) - Constructor for class org.apache.flink.streaming.api.scala.AllWindowedStream
 
AllWindowFunction<IN,OUT,W extends Window> - Interface in org.apache.flink.streaming.api.functions.windowing
Base interface for functions that are evaluated over non-keyed windows.
AllWindowFunction<IN,OUT,W extends Window> - Interface in org.apache.flink.streaming.api.scala.function
Base interface for functions that are evaluated over non-grouped windows, i.e., windows over all stream partitions.
AllWorkersDoneEvent - Class in org.apache.flink.runtime.iterative.event
 
AllWorkersDoneEvent() - Constructor for class org.apache.flink.runtime.iterative.event.AllWorkersDoneEvent
 
AllWorkersDoneEvent(Map<String, Aggregator<?>>) - Constructor for class org.apache.flink.runtime.iterative.event.AllWorkersDoneEvent
 
AlreadyRegistered(InstanceID, int) - Constructor for class org.apache.flink.runtime.messages.RegistrationMessages.AlreadyRegistered
 
AlreadyRegistered$() - Constructor for class org.apache.flink.runtime.messages.RegistrationMessages.AlreadyRegistered$
 
ALS - Class in org.apache.flink.ml.recommendation
Alternating least squares algorithm to calculate a matrix factorization.
ALS() - Constructor for class org.apache.flink.ml.recommendation.ALS
 
ALS$ - Class in org.apache.flink.ml.recommendation
 
ALS$() - Constructor for class org.apache.flink.ml.recommendation.ALS$
 
ALS.BlockedFactorization - Class in org.apache.flink.ml.recommendation
 
ALS.BlockedFactorization$ - Class in org.apache.flink.ml.recommendation
 
ALS.BlockIDGenerator - Class in org.apache.flink.ml.recommendation
 
ALS.BlockIDPartitioner - Class in org.apache.flink.ml.recommendation
 
ALS.BlockRating - Class in org.apache.flink.ml.recommendation
 
ALS.BlockRating$ - Class in org.apache.flink.ml.recommendation
 
ALS.Blocks$ - Class in org.apache.flink.ml.recommendation
 
ALS.Factorization - Class in org.apache.flink.ml.recommendation
 
ALS.Factorization$ - Class in org.apache.flink.ml.recommendation
 
ALS.Factors - Class in org.apache.flink.ml.recommendation
Latent factor model vector
ALS.Factors$ - Class in org.apache.flink.ml.recommendation
 
ALS.InBlockInformation - Class in org.apache.flink.ml.recommendation
 
ALS.InBlockInformation$ - Class in org.apache.flink.ml.recommendation
 
ALS.Iterations$ - Class in org.apache.flink.ml.recommendation
 
ALS.Lambda$ - Class in org.apache.flink.ml.recommendation
 
ALS.NumFactors$ - Class in org.apache.flink.ml.recommendation
 
ALS.OutBlockInformation - Class in org.apache.flink.ml.recommendation
 
ALS.OutBlockInformation$ - Class in org.apache.flink.ml.recommendation
 
ALS.OutLinks - Class in org.apache.flink.ml.recommendation
 
ALS.Rating - Class in org.apache.flink.ml.recommendation
Representation of a user-item rating
ALS.Rating$ - Class in org.apache.flink.ml.recommendation
 
ALS.Seed$ - Class in org.apache.flink.ml.recommendation
 
ALS.TemporaryPath$ - Class in org.apache.flink.ml.recommendation
 
alt(String) - Method in class org.apache.flink.api.java.utils.Option
Define an alternative / short name of the parameter.
alterSubCatalog(String, ExternalCatalog, boolean) - Method in interface org.apache.flink.table.catalog.CrudExternalCatalog
Modifies an existing sub catalog of this catalog.
alterSubCatalog(String, ExternalCatalog, boolean) - Method in class org.apache.flink.table.catalog.InMemoryExternalCatalog
 
alterTable(String, ExternalCatalogTable, boolean) - Method in interface org.apache.flink.table.catalog.CrudExternalCatalog
Modifies an existing table of this catalog.
alterTable(String, ExternalCatalogTable, boolean) - Method in class org.apache.flink.table.catalog.InMemoryExternalCatalog
 
ALWAYS_NULL() - Method in class org.apache.flink.table.codegen.GeneratedExpression$
 
ALWAYS_NULL() - Static method in class org.apache.flink.table.codegen.GeneratedExpression
 
AmbiguousTableSourceConverterException - Exception in org.apache.flink.table.api
Exception for finding more than one TableSourceConverter for a given table type.
AmbiguousTableSourceConverterException(String, Throwable) - Constructor for exception org.apache.flink.table.api.AmbiguousTableSourceConverterException
 
AmbiguousTableSourceConverterException(String) - Constructor for exception org.apache.flink.table.api.AmbiguousTableSourceConverterException
 
AmbiguousTableSourceConverterException$ - Class in org.apache.flink.table.api
 
AmbiguousTableSourceConverterException$() - Constructor for class org.apache.flink.table.api.AmbiguousTableSourceConverterException$
 
amount() - Method in class org.apache.flink.table.examples.scala.StreamSQLExample.Order
 
amount() - Method in class org.apache.flink.table.examples.scala.StreamTableExample.Order
 
AnalyticHelper<T> - Class in org.apache.flink.graph
A GraphAnalytic computes over a DataSet and returns the results via Flink accumulators.
AnalyticHelper() - Constructor for class org.apache.flink.graph.AnalyticHelper
 
analyze() - Method in class org.apache.flink.api.java.sca.NestedMethodAnalyzer
 
analyze() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
analyze(scala.reflect.macros.Context.universe) - Method in class org.apache.flink.api.scala.codegen.TypeAnalyzer.UDTAnalyzerInstance
 
analyzeCondition() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
analyzeDualInputUdf(TwoInputUdfOperator<?, ?, ?, ?>, Class<?>, String, Function, Keys<?>, Keys<?>) - Static method in class org.apache.flink.api.java.operators.UdfOperatorUtils
 
analyzePojo(Class<OUT>, ArrayList<Type>, ParameterizedType, TypeInformation<IN1>, TypeInformation<IN2>) - Method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
analyzeSingleInputUdf(SingleInputUdfOperator<?, ?, ?>, Class<?>, String, Function, Keys<?>) - Static method in class org.apache.flink.api.java.operators.UdfOperatorUtils
 
AND - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Logical AND operator.
and(Aggregations, int) - Method in class org.apache.flink.api.java.operators.AggregateOperator
 
and(Aggregations, int) - Method in class org.apache.flink.api.scala.AggregateDataSet
Adds the given aggregation on the given field to the previous aggregation operation.
and(Aggregations, String) - Method in class org.apache.flink.api.scala.AggregateDataSet
Adds the given aggregation on the given field to the previous aggregation operation.
and(Aggregations, int) - Method in class org.apache.flink.api.scala.operators.ScalaAggregateOperator
 
and(RexNode[]) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
and(Iterable<? extends RexNode>) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
And - Class in org.apache.flink.table.expressions
 
And(Expression, Expression) - Constructor for class org.apache.flink.table.expressions.And
 
And$ - Class in org.apache.flink.table.expressions
 
And$() - Constructor for class org.apache.flink.table.expressions.And$
 
AndCondition<T> - Class in org.apache.flink.cep.pattern.conditions
A condition which combines two conditions with a logical AND and returns true if both are true.
AndCondition(IterativeCondition<T>, IterativeCondition<T>) - Constructor for class org.apache.flink.cep.pattern.conditions.AndCondition
 
AndFilterFunction<T> - Class in org.apache.flink.cep.pattern
Deprecated.
This is only used when migrating from an older Flink version. Use the AndCondition instead.

A filter function which combines two filter functions with a logical and. Thus, the filter function only returns true, iff both filters return true.

AndFilterFunction(FilterFunction<T>, FilterFunction<T>) - Constructor for class org.apache.flink.cep.pattern.AndFilterFunction
Deprecated.
 
andMax(int) - Method in class org.apache.flink.api.java.operators.AggregateOperator
 
andMax(int) - Method in class org.apache.flink.api.scala.AggregateDataSet
Syntactic sugar for and with MAX
andMax(String) - Method in class org.apache.flink.api.scala.AggregateDataSet
Syntactic sugar for and with MAX
andMin(int) - Method in class org.apache.flink.api.java.operators.AggregateOperator
 
andMin(int) - Method in class org.apache.flink.api.scala.AggregateDataSet
Syntactic sugar for and with MIN
andMin(String) - Method in class org.apache.flink.api.scala.AggregateDataSet
Syntactic sugar for and with MIN
andSum(int) - Method in class org.apache.flink.api.java.operators.AggregateOperator
 
andSum(int) - Method in class org.apache.flink.api.scala.AggregateDataSet
Syntactic sugar for and with SUM
andSum(String) - Method in class org.apache.flink.api.scala.AggregateDataSet
Syntactic sugar for and with SUM
AnnotationVisitorImpl(int) - Constructor for class org.apache.flink.runtime.util.DependencyVisitor.AnnotationVisitorImpl
 
AntiJoinVisits() - Constructor for class org.apache.flink.examples.java.relational.WebLogAnalysis.AntiJoinVisits
 
API_KEY - Static variable in class org.apache.flink.metrics.datadog.DatadogHttpReporter
 
APP_MASTER_RPC_ADDRESS - Static variable in class org.apache.flink.yarn.configuration.YarnConfigOptions
The hostname or address where the application master RPC system is listening.
APP_MASTER_RPC_PORT - Static variable in class org.apache.flink.yarn.configuration.YarnConfigOptions
The port where the application master RPC system is listening.
append(char) - Method in class org.apache.flink.types.StringValue
 
append(CharSequence) - Method in class org.apache.flink.types.StringValue
 
append(CharSequence, int, int) - Method in class org.apache.flink.types.StringValue
 
append(StringValue) - Method in class org.apache.flink.types.StringValue
 
append(StringValue, int, int) - Method in class org.apache.flink.types.StringValue
 
AppendingState<IN,OUT> - Interface in org.apache.flink.api.common.state
Base interface for partitioned state that supports adding elements and inspecting the current state.
appendKeyExtractor(Operator<T>, Keys.SelectorFunctionKeys<T, K>) - Static method in class org.apache.flink.api.java.operators.KeyFunctions
 
appendKeyExtractor(Operator<T>, Keys.SelectorFunctionKeys<T, K1>, Keys.SelectorFunctionKeys<T, K2>) - Static method in class org.apache.flink.api.java.operators.KeyFunctions
 
appendKeyRemover(Operator<Tuple2<K, T>>, Keys.SelectorFunctionKeys<T, K>) - Static method in class org.apache.flink.api.java.operators.KeyFunctions
 
appendOrdering(Integer, Class<? extends Comparable<?>>, Order) - Method in class org.apache.flink.api.common.operators.Ordering
Extends this ordering by appending an additional order requirement.
appendRecord(T) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
Inserts the given object into the current buffer.
AppendStreamTableSink<T> - Interface in org.apache.flink.table.sinks
Defines an external TableSink to emit streaming Table with only insert changes.
ApplicationClient - Class in org.apache.flink.yarn
Actor which is responsible to repeatedly poll the Yarn cluster status from the ResourceManager.
ApplicationClient(Configuration, LeaderRetrievalService) - Constructor for class org.apache.flink.yarn.ApplicationClient
 
ApplicationClient$ - Class in org.apache.flink.yarn
 
ApplicationClient$() - Constructor for class org.apache.flink.yarn.ApplicationClient$
 
ApplicationMasterStatus(int, int) - Constructor for class org.apache.flink.yarn.YarnMessages.ApplicationMasterStatus
 
ApplicationMasterStatus$() - Constructor for class org.apache.flink.yarn.YarnMessages.ApplicationMasterStatus$
 
ApplicationStatus - Enum in org.apache.flink.runtime.clusterframework
The status of an application.
apply(Function2<Iterator<L>, Iterator<R>, O>, TypeInformation<O>, ClassTag<O>) - Method in class org.apache.flink.api.scala.CoGroupDataSet
Creates a new DataSet where the result for each pair of co-grouped element lists is the result of the given function.
apply(Function3<Iterator<L>, Iterator<R>, Collector<O>, BoxedUnit>, TypeInformation<O>, ClassTag<O>) - Method in class org.apache.flink.api.scala.CoGroupDataSet
Creates a new DataSet where the result for each pair of co-grouped element lists is the result of the given function.
apply(CoGroupFunction<L, R, O>, TypeInformation<O>, ClassTag<O>) - Method in class org.apache.flink.api.scala.CoGroupDataSet
Creates a new DataSet by passing each pair of co-grouped element lists to the given function.
apply(Function2<L, R, O>, TypeInformation<O>, ClassTag<O>) - Method in class org.apache.flink.api.scala.CrossDataSet
Creates a new DataSet where the result for each pair of elements is the result of the given function.
apply(CrossFunction<L, R, O>, TypeInformation<O>, ClassTag<O>) - Method in class org.apache.flink.api.scala.CrossDataSet
Creates a new DataSet by passing each pair of values to the given function.
apply(Function2<L, R, O>, TypeInformation<O>, ClassTag<O>) - Method in class org.apache.flink.api.scala.JoinDataSet
Creates a new DataSet where the result for each pair of joined elements is the result of the given function.
apply(Function3<L, R, Collector<O>, BoxedUnit>, TypeInformation<O>, ClassTag<O>) - Method in class org.apache.flink.api.scala.JoinDataSet
Creates a new DataSet by passing each pair of joined values to the given function.
apply(FlatJoinFunction<L, R, O>, TypeInformation<O>, ClassTag<O>) - Method in class org.apache.flink.api.scala.JoinDataSet
Creates a new DataSet by passing each pair of joined values to the given function.
apply(JoinFunction<L, R, O>, TypeInformation<O>, ClassTag<O>) - Method in class org.apache.flink.api.scala.JoinDataSet
Creates a new DataSet by passing each pair of joined values to the given function.
apply(Function2<L, R, O>, TypeInformation<O>, ClassTag<O>) - Method in interface org.apache.flink.api.scala.JoinFunctionAssigner
 
apply(Function3<L, R, Collector<O>, BoxedUnit>, TypeInformation<O>, ClassTag<O>) - Method in interface org.apache.flink.api.scala.JoinFunctionAssigner
 
apply(FlatJoinFunction<L, R, O>, TypeInformation<O>, ClassTag<O>) - Method in interface org.apache.flink.api.scala.JoinFunctionAssigner
 
apply(JoinFunction<L, R, O>, TypeInformation<O>, ClassTag<O>) - Method in interface org.apache.flink.api.scala.JoinFunctionAssigner
 
apply(Function0<T>) - Method in class org.apache.flink.api.scala.metrics.ScalaGauge$
 
apply(Function0<T>) - Static method in class org.apache.flink.api.scala.metrics.ScalaGauge
 
apply(Pattern<T, F>) - Method in class org.apache.flink.cep.scala.pattern.Pattern$
Constructs a new Pattern by wrapping a given Java API Pattern
apply(Pattern<T, F>) - Static method in class org.apache.flink.cep.scala.pattern.Pattern
Constructs a new Pattern by wrapping a given Java API Pattern
apply(PatternStream<T>) - Method in class org.apache.flink.cep.scala.PatternStream$
 
apply(PatternStream<T>) - Static method in class org.apache.flink.cep.scala.PatternStream
 
apply(M, VV) - Method in class org.apache.flink.graph.gsa.ApplyFunction
This method is invoked once per superstep, after the SumFunction in a GatherSumApplyIteration.
apply() - Method in class org.apache.flink.ml.classification.SVM$
 
apply() - Static method in class org.apache.flink.ml.classification.SVM
 
apply() - Method in class org.apache.flink.ml.common.ParameterMap$
 
apply(Parameter<T>) - Method in class org.apache.flink.ml.common.ParameterMap
Retrieves a parameter value associated to a given key.
apply(int, int, int[]) - Method in class org.apache.flink.ml.math.DenseMatrix$
 
apply(int, int, Seq<Object>) - Method in class org.apache.flink.ml.math.DenseMatrix$
 
apply(int, int) - Method in class org.apache.flink.ml.math.DenseMatrix
Element wise access function
apply(Seq<Object>) - Method in class org.apache.flink.ml.math.DenseVector$
 
apply(int[]) - Method in class org.apache.flink.ml.math.DenseVector$
 
apply(int) - Method in class org.apache.flink.ml.math.DenseVector
Element wise access function
apply(int, int) - Method in interface org.apache.flink.ml.math.Matrix
Element wise access function
apply(int, int) - Method in class org.apache.flink.ml.math.SparseMatrix
Element wise access function
apply(int) - Method in class org.apache.flink.ml.math.SparseVector
Element wise access function
apply(int) - Method in interface org.apache.flink.ml.math.Vector
Element wise access function
apply() - Method in class org.apache.flink.ml.metrics.distances.ChebyshevDistanceMetric$
 
apply() - Static method in class org.apache.flink.ml.metrics.distances.ChebyshevDistanceMetric
 
apply() - Method in class org.apache.flink.ml.metrics.distances.CosineDistanceMetric$
 
apply() - Static method in class org.apache.flink.ml.metrics.distances.CosineDistanceMetric
 
apply() - Method in class org.apache.flink.ml.metrics.distances.EuclideanDistanceMetric$
 
apply() - Static method in class org.apache.flink.ml.metrics.distances.EuclideanDistanceMetric
 
apply() - Method in class org.apache.flink.ml.metrics.distances.ManhattanDistanceMetric$
 
apply() - Static method in class org.apache.flink.ml.metrics.distances.ManhattanDistanceMetric
 
apply(double) - Method in class org.apache.flink.ml.metrics.distances.MinkowskiDistanceMetric$
 
apply(double) - Static method in class org.apache.flink.ml.metrics.distances.MinkowskiDistanceMetric
 
apply() - Method in class org.apache.flink.ml.metrics.distances.SquaredEuclideanDistanceMetric$
 
apply() - Static method in class org.apache.flink.ml.metrics.distances.SquaredEuclideanDistanceMetric
 
apply() - Method in class org.apache.flink.ml.metrics.distances.TanimotoDistanceMetric$
 
apply() - Static method in class org.apache.flink.ml.metrics.distances.TanimotoDistanceMetric
 
apply() - Method in class org.apache.flink.ml.nn.KNN$
 
apply() - Static method in class org.apache.flink.ml.nn.KNN
 
apply() - Method in class org.apache.flink.ml.optimization.GradientDescent$
 
apply() - Static method in class org.apache.flink.ml.optimization.GradientDescent
 
apply() - Method in class org.apache.flink.ml.outlier.StochasticOutlierSelection$
 
apply() - Static method in class org.apache.flink.ml.outlier.StochasticOutlierSelection
 
apply() - Method in class org.apache.flink.ml.preprocessing.MinMaxScaler$
 
apply() - Static method in class org.apache.flink.ml.preprocessing.MinMaxScaler
 
apply() - Method in class org.apache.flink.ml.preprocessing.PolynomialFeatures$
 
apply() - Static method in class org.apache.flink.ml.preprocessing.PolynomialFeatures
 
apply() - Method in class org.apache.flink.ml.preprocessing.StandardScaler$
 
apply() - Static method in class org.apache.flink.ml.preprocessing.StandardScaler
 
apply() - Method in class org.apache.flink.ml.recommendation.ALS$
 
apply() - Static method in class org.apache.flink.ml.recommendation.ALS
 
apply(long) - Method in class org.apache.flink.ml.recommendation.ALS.BlockIDGenerator
 
apply(int) - Method in class org.apache.flink.ml.recommendation.ALS.BlockRating
 
apply(int) - Method in class org.apache.flink.ml.recommendation.ALS.OutLinks
 
apply() - Method in class org.apache.flink.ml.regression.MultipleLinearRegression$
 
apply() - Static method in class org.apache.flink.ml.regression.MultipleLinearRegression
 
apply(ActorSystem) - Static method in class org.apache.flink.runtime.akka.RemoteAddressExtension
 
apply(V) - Method in interface org.apache.flink.runtime.concurrent.ApplyFunction
Method which handles the function call.
apply(T, U) - Method in interface org.apache.flink.runtime.concurrent.BiFunction
Method which handles the function call.
apply(ActorRef, ListeningBehaviour, long, long) - Method in class org.apache.flink.runtime.jobmanager.JobInfo$
 
apply(ActorRef, ListeningBehaviour, long, long) - Static method in class org.apache.flink.runtime.jobmanager.JobInfo
 
apply(S, T) - Method in interface org.apache.flink.runtime.state.StateTransformationFunction
Binary function that applies a given value to the given old state to compute the new state.
apply(I) - Method in interface org.apache.flink.runtime.util.EvictingBoundedList.Function
Transforms the value.
apply(RetrievableStateHandle<T>) - Method in interface org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore.RemoveCallback
Callback method.
apply(AllWindowFunction<T, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
apply(AllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
apply(ReduceFunction<T>, AllWindowFunction<T, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
apply(ReduceFunction<T>, AllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
apply(R, FoldFunction<T, R>, AllWindowFunction<R, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
apply(R, FoldFunction<T, R>, AllWindowFunction<R, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
apply(CoGroupFunction<T1, T2, T>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
Completes the co-group operation with the user function that is executed for windowed groups.
apply(CoGroupFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
Completes the co-group operation with the user function that is executed for windowed groups.
apply(JoinFunction<T1, T2, T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
Completes the join operation with the user function that is executed for each combination of elements with the same key in a window.
apply(FlatJoinFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
Completes the join operation with the user function that is executed for each combination of elements with the same key in a window.
apply(FlatJoinFunction<T1, T2, T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
Completes the join operation with the user function that is executed for each combination of elements with the same key in a window.
apply(JoinFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
Completes the join operation with the user function that is executed for each combination of elements with the same key in a window.
apply(WindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
apply(WindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
apply(ReduceFunction<T>, WindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
apply(ReduceFunction<T>, WindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
apply(R, FoldFunction<T, R>, WindowFunction<R, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
apply(R, FoldFunction<T, R>, WindowFunction<R, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
apply(W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.AggregateApplyAllWindowFunction
 
apply(K, W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.AggregateApplyWindowFunction
 
apply(W, Iterable<IN>, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.windowing.AllWindowFunction
Evaluates the window and outputs none or several elements.
apply(W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyAllWindowFunction
Deprecated.
 
apply(K, W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyWindowFunction
Deprecated.
 
apply(W, Iterable<T>, Collector<T>) - Method in class org.apache.flink.streaming.api.functions.windowing.PassThroughAllWindowFunction
 
apply(K, W, Iterable<T>, Collector<T>) - Method in class org.apache.flink.streaming.api.functions.windowing.PassThroughWindowFunction
 
apply(W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyAllWindowFunction
 
apply(K, W, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyWindowFunction
 
apply(KEY, W, Iterable<IN>, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.windowing.WindowFunction
Evaluates the window and outputs none or several elements.
apply(AllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Applies the given window function to each window.
apply(Function3<W, Iterable<T>, Collector<R>, BoxedUnit>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Applies the given window function to each window.
apply(ReduceFunction<T>, AllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Deprecated.
Use reduce(ReduceFunction, AllWindowFunction) instead.
apply(Function2<T, T, T>, Function3<W, Iterable<T>, Collector<R>, BoxedUnit>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Deprecated.
Use reduce(ReduceFunction, AllWindowFunction) instead.
apply(R, FoldFunction<T, R>, AllWindowFunction<R, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Deprecated.
Use fold(R, FoldFunction, AllWindowFunction) instead.
apply(R, Function2<R, T, R>, Function3<W, Iterable<R>, Collector<R>, BoxedUnit>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Deprecated.
Use fold(R, FoldFunction, AllWindowFunction instead.
apply(Function2<Iterator<T1>, Iterator<T2>, O>, TypeInformation<O>) - Method in class org.apache.flink.streaming.api.scala.CoGroupedStreams.Where.EqualTo.WithWindow
Completes the co-group operation with the user function that is executed for windowed groups.
apply(Function3<Iterator<T1>, Iterator<T2>, Collector<O>, BoxedUnit>, TypeInformation<O>) - Method in class org.apache.flink.streaming.api.scala.CoGroupedStreams.Where.EqualTo.WithWindow
Completes the co-group operation with the user function that is executed for windowed groups.
apply(CoGroupFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.scala.CoGroupedStreams.Where.EqualTo.WithWindow
Completes the co-group operation with the user function that is executed for windowed groups.
apply(W, Iterable<IN>, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.scala.function.AllWindowFunction
Evaluates the window and outputs none or several elements.
apply(W, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.api.scala.function.util.ScalaAllWindowFunction
 
apply(W, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.api.scala.function.util.ScalaAllWindowFunctionWrapper
 
apply(KEY, W, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.api.scala.function.util.ScalaWindowFunction
 
apply(KEY, W, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.api.scala.function.util.ScalaWindowFunctionWrapper
 
apply(KEY, W, Iterable<IN>, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.scala.function.WindowFunction
Evaluates the window and outputs none or several elements.
apply(Function2<T1, T2, O>, TypeInformation<O>) - Method in class org.apache.flink.streaming.api.scala.JoinedStreams.Where.EqualTo.WithWindow
Completes the join operation with the user function that is executed for windowed groups.
apply(Function3<T1, T2, Collector<O>, BoxedUnit>, TypeInformation<O>) - Method in class org.apache.flink.streaming.api.scala.JoinedStreams.Where.EqualTo.WithWindow
Completes the join operation with the user function that is executed for windowed groups.
apply(JoinFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.scala.JoinedStreams.Where.EqualTo.WithWindow
Completes the join operation with the user function that is executed for windowed groups.
apply(FlatJoinFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.scala.JoinedStreams.Where.EqualTo.WithWindow
Completes the join operation with the user function that is executed for windowed groups.
apply(String, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.scala.OutputTag$
 
apply(String, TypeInformation<T>) - Static method in class org.apache.flink.streaming.api.scala.OutputTag
 
apply(WindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Applies the given window function to each window.
apply(Function4<K, W, Iterable<T>, Collector<R>, BoxedUnit>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Applies the given window function to each window.
apply(ReduceFunction<T>, WindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Deprecated.
Use reduce(ReduceFunction, WindowFunction) instead.
apply(Function2<T, T, T>, Function4<K, W, Iterable<T>, Collector<R>, BoxedUnit>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Deprecated.
Use reduce(ReduceFunction, WindowFunction) instead.
apply(R, FoldFunction<T, R>, WindowFunction<R, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Deprecated.
Use fold(R, FoldFunction, WindowFunction) instead.
apply(R, Function2<R, T, R>, Function4<K, W, Iterable<R>, Collector<R>, BoxedUnit>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Deprecated.
Use fold(R, FoldFunction, WindowFunction) instead.
apply(TimeWindow, Iterable<Integer>, Collector<Double[]>) - Method in class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.PartialModelBuilder
 
apply(Long, Window, Iterable<Tuple2<Long, Long>>, Collector<Tuple2<Long, Long>>) - Method in class org.apache.flink.streaming.examples.windowing.GroupedProcessingTimeWindowExample.SummingWindowFunction
 
apply(Expression, Seq<Expression>) - Method in class org.apache.flink.table.api.scala.array$
Creates an array of literals.
apply(Expression, Seq<Expression>) - Static method in class org.apache.flink.table.api.scala.array
Creates an array of literals.
apply() - Method in class org.apache.flink.table.api.scala.currentDate$
Returns the current SQL date in UTC time zone.
apply() - Static method in class org.apache.flink.table.api.scala.currentDate
Returns the current SQL date in UTC time zone.
apply() - Method in class org.apache.flink.table.api.scala.currentTime$
Returns the current SQL time in UTC time zone.
apply() - Static method in class org.apache.flink.table.api.scala.currentTime
Returns the current SQL time in UTC time zone.
apply() - Method in class org.apache.flink.table.api.scala.currentTimestamp$
Returns the current SQL timestamp in UTC time zone.
apply() - Static method in class org.apache.flink.table.api.scala.currentTimestamp
Returns the current SQL timestamp in UTC time zone.
apply() - Method in class org.apache.flink.table.api.scala.localTime$
Returns the current SQL time in local time zone.
apply() - Static method in class org.apache.flink.table.api.scala.localTime
Returns the current SQL time in local time zone.
apply() - Method in class org.apache.flink.table.api.scala.localTimestamp$
Returns the current SQL timestamp in local time zone.
apply() - Static method in class org.apache.flink.table.api.scala.localTimestamp
Returns the current SQL timestamp in local time zone.
apply() - Method in class org.apache.flink.table.api.scala.pi$
Returns a value that is closer than any other value to pi.
apply() - Static method in class org.apache.flink.table.api.scala.pi
Returns a value that is closer than any other value to pi.
apply(Seq<Expression>, TypeInformation<T>) - Method in class org.apache.flink.table.api.scala.TableFunctionConversions
Creates a Table from a TableFunction in Scala Table API.
apply(Expression, Expression, Expression, Expression) - Method in class org.apache.flink.table.api.scala.temporalOverlaps$
Determines whether two anchored time intervals overlap.
apply(Expression, Expression, Expression, Expression) - Static method in class org.apache.flink.table.api.scala.temporalOverlaps
Determines whether two anchored time intervals overlap.
apply(String) - Method in class org.apache.flink.table.api.TableException$
 
apply(String) - Static method in exception org.apache.flink.table.api.TableException
 
apply(String) - Method in class org.apache.flink.table.api.ValidationException$
 
apply(String) - Static method in exception org.apache.flink.table.api.ValidationException
 
apply(Object) - Method in class org.apache.flink.table.expressions.Literal$
 
apply(Object) - Static method in class org.apache.flink.table.expressions.Literal
 
apply(int) - Static method in class org.apache.flink.table.expressions.TimeIntervalUnit
 
apply(int) - Static method in class org.apache.flink.table.expressions.TimePointUnit
 
apply(int) - Static method in class org.apache.flink.table.expressions.TrimMode
 
apply(Seq<Expression>) - Method in class org.apache.flink.table.expressions.UDAGGExpression
Creates a call to an AggregateFunction.
apply(Seq<Expression>) - Method in class org.apache.flink.table.functions.ScalarFunction
Creates a call to a ScalarFunction in Scala Table API.
apply(String, AggregateFunction<?, ?>, TypeInformation<?>, FlinkTypeFactory, boolean) - Method in class org.apache.flink.table.functions.utils.AggSqlFunction$
 
apply(String, AggregateFunction<?, ?>, TypeInformation<?>, FlinkTypeFactory, boolean) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
apply(String, TableFunction<?>, TypeInformation<?>, FlinkTypeFactory, FlinkTableFunctionImpl<?>) - Method in class org.apache.flink.table.functions.utils.TableSqlFunction$
Util function to create a TableSqlFunction.
apply(String, TableFunction<?>, TypeInformation<?>, FlinkTypeFactory, FlinkTableFunctionImpl<?>) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
Util function to create a TableSqlFunction.
apply(int) - Static method in class org.apache.flink.table.plan.nodes.datastream.AccMode
 
apply(TimeWindow, Iterable<Row>, Collector<CRow>) - Method in class org.apache.flink.table.runtime.aggregate.IncrementalAggregateAllTimeWindowFunction
 
apply(W, Iterable<Row>, Collector<CRow>) - Method in class org.apache.flink.table.runtime.aggregate.IncrementalAggregateAllWindowFunction
Calculate aggregated values output by aggregate buffer, and set them into output Row based on the mapping relation between intermediate aggregate data and output data.
apply(Tuple, TimeWindow, Iterable<Row>, Collector<CRow>) - Method in class org.apache.flink.table.runtime.aggregate.IncrementalAggregateTimeWindowFunction
 
apply(Tuple, W, Iterable<Row>, Collector<CRow>) - Method in class org.apache.flink.table.runtime.aggregate.IncrementalAggregateWindowFunction
Calculate aggregated values output by aggregate buffer, and set them into output Row based on the mapping relation between intermediate aggregate data and output data.
apply() - Method in class org.apache.flink.table.runtime.types.CRow$
 
apply(Row, boolean) - Method in class org.apache.flink.table.runtime.types.CRow$
 
apply() - Static method in class org.apache.flink.table.runtime.types.CRow
 
apply(Row, boolean) - Static method in class org.apache.flink.table.runtime.types.CRow
 
apply(TypeInformation<Row>) - Method in class org.apache.flink.table.runtime.types.CRowTypeInfo$
 
apply(TypeInformation<Row>) - Static method in class org.apache.flink.table.runtime.types.CRowTypeInfo
 
apply(Statement, Description) - Method in class org.apache.flink.testutils.junit.RetryRule
 
ApplyFunction<K,VV,M> - Class in org.apache.flink.graph.gsa
The base class for the third and last step of a GatherSumApplyIteration.
ApplyFunction() - Constructor for class org.apache.flink.graph.gsa.ApplyFunction
 
ApplyFunction<V,R> - Interface in org.apache.flink.runtime.concurrent
Function which is called with a single argument.
applyIteratorTrueAssumption() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
applyPredicate(List<Expression>) - Method in interface org.apache.flink.table.sources.FilterableTableSource
Check and pick all predicates this table source can support.
applyRegistrations(Kryo, Collection<KryoRegistration>) - Static method in class org.apache.flink.api.java.typeutils.runtime.KryoUtils
Apply a list of KryoRegistration to a Kryo instance.
applyRepartitioner(OperatorStateRepartitioner, List<OperatorStateHandle>, int, int) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
Repartitions the given operator state using the given OperatorStateRepartitioner with respect to the new parallelism.
applyState(FSM.State<S, D>) - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
applyState(FSM.State<S, D>) - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
applyState(FSM.State<S, D>) - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
applyState(FSM.State<S, D>) - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
applyTo(ParameterTool) - Method in class org.apache.flink.api.java.utils.RequiredParameters
Check for all required parameters defined: - has a value been passed - if not, does the parameter have an associated default value - does the type of the parameter match the one defined in RequiredParameters - does the value provided in the parameterTool adhere to the choices defined in the option If any check fails, a RequiredParametersException is thrown
applyWith(ACC, Function2<ACC, T, ACC>, Function3<K, W, Stream<ACC>, TraversableOnce<R>>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.extensions.impl.acceptPartialFunctions.OnWindowedStream
Applies the given window function to each window.
applyWithState(I, Function2<I, Option<S>, Tuple2<O, Option<S>>>) - Method in interface org.apache.flink.streaming.api.scala.function.StatefulFunction
 
appMasterHostname - Variable in class org.apache.flink.yarn.AbstractYarnFlinkApplicationMasterRunner
The host name passed by env
archive() - Method in interface org.apache.flink.api.common.Archiveable
 
archive() - Method in class org.apache.flink.api.common.ExecutionConfig
 
archive() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
archive() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
archive() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
archive() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
archive() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
ARCHIVE_DIR - Static variable in class org.apache.flink.configuration.JobManagerOptions
The location where the JobManager stores the archives of completed jobs.
ARCHIVE_NAME - Static variable in class org.apache.flink.runtime.jobmaster.JobMaster
 
Archiveable<T extends Serializable> - Interface in org.apache.flink.api.common
 
ArchivedExecution - Class in org.apache.flink.runtime.executiongraph
 
ArchivedExecution(Execution) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecution
 
ArchivedExecution(StringifiedAccumulatorResult[], IOMetrics, ExecutionAttemptID, int, ExecutionState, String, TaskManagerLocation, int, long[]) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecution
 
ArchivedExecutionConfig - Class in org.apache.flink.api.common
Serializable class which is created when archiving the job.
ArchivedExecutionConfig(ExecutionConfig) - Constructor for class org.apache.flink.api.common.ArchivedExecutionConfig
 
ArchivedExecutionConfig(String, String, int, boolean, Map<String, String>) - Constructor for class org.apache.flink.api.common.ArchivedExecutionConfig
 
ArchivedExecutionGraph - Class in org.apache.flink.runtime.executiongraph
 
ArchivedExecutionGraph(JobID, String, Map<JobVertexID, ArchivedExecutionJobVertex>, List<ArchivedExecutionJobVertex>, long[], JobStatus, String, String, StringifiedAccumulatorResult[], Map<String, SerializedValue<Object>>, ArchivedExecutionConfig, boolean, JobCheckpointingSettings, CheckpointStatsSnapshot) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
ArchivedExecutionJobVertex - Class in org.apache.flink.runtime.executiongraph
 
ArchivedExecutionJobVertex(ExecutionJobVertex) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
 
ArchivedExecutionJobVertex(ArchivedExecutionVertex[], JobVertexID, String, int, int, StringifiedAccumulatorResult[]) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
 
ArchivedExecutionVertex - Class in org.apache.flink.runtime.executiongraph
 
ArchivedExecutionVertex(ExecutionVertex) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
 
ArchivedExecutionVertex(int, String, ArchivedExecution, EvictingBoundedList<ArchivedExecution>) - Constructor for class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
 
ArchivedJob(Option<ArchivedExecutionGraph>) - Constructor for class org.apache.flink.runtime.messages.ArchiveMessages.ArchivedJob
 
ArchivedJob$() - Constructor for class org.apache.flink.runtime.messages.ArchiveMessages.ArchivedJob$
 
ArchivedJobs(Iterable<ArchivedExecutionGraph>) - Constructor for class org.apache.flink.runtime.messages.ArchiveMessages.ArchivedJobs
 
ArchivedJobs$() - Constructor for class org.apache.flink.runtime.messages.ArchiveMessages.ArchivedJobs$
 
ArchivedJson - Class in org.apache.flink.runtime.webmonitor.history
A simple container for a handler's JSON response and the REST URLs for which the response would've been returned.
ArchivedJson(String, String) - Constructor for class org.apache.flink.runtime.webmonitor.history.ArchivedJson
 
ArchiveExecutionGraph(JobID, ArchivedExecutionGraph) - Constructor for class org.apache.flink.runtime.messages.ArchiveMessages.ArchiveExecutionGraph
 
ArchiveExecutionGraph$() - Constructor for class org.apache.flink.runtime.messages.ArchiveMessages.ArchiveExecutionGraph$
 
archiveJob(Path, AccessExecutionGraph) - Static method in class org.apache.flink.runtime.history.FsJobArchivist
Writes the given AccessExecutionGraph to the FileSystem pointed to by JobManagerOptions.ARCHIVE_DIR.
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.webmonitor.handlers.checkpoints.CheckpointConfigHandler.CheckpointConfigJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.webmonitor.handlers.checkpoints.CheckpointStatsDetailsHandler.CheckpointStatsDetailsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.webmonitor.handlers.checkpoints.CheckpointStatsDetailsSubtasksHandler.CheckpointStatsDetailsSubtasksJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.webmonitor.handlers.checkpoints.CheckpointStatsHandler.CheckpointStatsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.webmonitor.handlers.CurrentJobsOverviewHandler.CurrentJobsOverviewJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobAccumulatorsHandler.JobAccumulatorsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobConfigHandler.JobConfigJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobDetailsHandler.JobDetailsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobExceptionsHandler.JobExceptionsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobPlanHandler.JobPlanJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobVertexAccumulatorsHandler.JobVertexAccumulatorsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobVertexDetailsHandler.JobVertexDetailsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobVertexTaskManagersHandler.JobVertexTaskManagersJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.webmonitor.handlers.SubtaskExecutionAttemptAccumulatorsHandler.SubtaskExecutionAttemptAccumulatorsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.webmonitor.handlers.SubtaskExecutionAttemptDetailsHandler.SubtaskExecutionAttemptDetailsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.webmonitor.handlers.SubtasksAllAccumulatorsHandler.SubtasksAllAccumulatorsJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in class org.apache.flink.runtime.webmonitor.handlers.SubtasksTimesHandler.SubtasksTimesJsonArchivist
 
archiveJsonWithPath(AccessExecutionGraph) - Method in interface org.apache.flink.runtime.webmonitor.history.JsonArchivist
Returns a Collection of ArchivedJsons containing JSON responses and their respective REST URL for a given job.
ArchiveMessages - Class in org.apache.flink.runtime.messages
This object contains the archive specific messages.
ArchiveMessages() - Constructor for class org.apache.flink.runtime.messages.ArchiveMessages
 
ArchiveMessages$ - Class in org.apache.flink.runtime.messages
This object contains the archive specific messages.
ArchiveMessages$() - Constructor for class org.apache.flink.runtime.messages.ArchiveMessages$
 
ArchiveMessages.ArchivedJob - Class in org.apache.flink.runtime.messages
 
ArchiveMessages.ArchivedJob$ - Class in org.apache.flink.runtime.messages
 
ArchiveMessages.ArchivedJobs - Class in org.apache.flink.runtime.messages
Response to RequestArchivedJobs message.
ArchiveMessages.ArchivedJobs$ - Class in org.apache.flink.runtime.messages
 
ArchiveMessages.ArchiveExecutionGraph - Class in org.apache.flink.runtime.messages
 
ArchiveMessages.ArchiveExecutionGraph$ - Class in org.apache.flink.runtime.messages
 
ArchiveMessages.RequestArchivedJob - Class in org.apache.flink.runtime.messages
Reqeuest a specific ExecutionGraph by JobID.
ArchiveMessages.RequestArchivedJob$ - Class in org.apache.flink.runtime.messages
 
ArchiveMessages.RequestArchivedJobs$ - Class in org.apache.flink.runtime.messages
Request the currently archived jobs in the archiver.
ArchiveMessages.RequestJobCounts$ - Class in org.apache.flink.runtime.messages
Requests the number of finished, canceled, and failed jobs
areBranchCompatible(PlanNode, PlanNode) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
Checks whether to candidate plans for the sub-plan of this node are comparable.
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.AbstractSortMergeJoinDescriptor
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.BinaryUnionOpDescriptor
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CartesianProductDescriptor
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupDescriptor
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupRawDescriptor
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupWithSolutionSetFirstDescriptor
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupWithSolutionSetSecondDescriptor
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashFullOuterJoinBuildFirstDescriptor
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashFullOuterJoinBuildSecondDescriptor
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashJoinBuildFirstProperties
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashJoinBuildSecondProperties
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashLeftOuterJoinBuildFirstDescriptor
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashLeftOuterJoinBuildSecondDescriptor
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashRightOuterJoinBuildFirstDescriptor
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashRightOuterJoinBuildSecondDescriptor
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
 
areCoFulfilled(RequestedLocalProperties, RequestedLocalProperties, LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.UtilSinkJoinOpDescriptor
 
areCompatible(Keys<?>) - Method in class org.apache.flink.api.common.operators.Keys
Check if two sets of keys are compatible to each other (matching types, key counts)
areCompatible(RequestedGlobalProperties, RequestedGlobalProperties, GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.AbstractJoinDescriptor
 
areCompatible(RequestedGlobalProperties, RequestedGlobalProperties, GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.BinaryUnionOpDescriptor
 
areCompatible(RequestedGlobalProperties, RequestedGlobalProperties, GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.CartesianProductDescriptor
 
areCompatible(RequestedGlobalProperties, RequestedGlobalProperties, GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupDescriptor
 
areCompatible(RequestedGlobalProperties, RequestedGlobalProperties, GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupRawDescriptor
 
areCompatible(RequestedGlobalProperties, RequestedGlobalProperties, GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
 
areCompatible(RequestedGlobalProperties, RequestedGlobalProperties, GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.UtilSinkJoinOpDescriptor
 
areExplicitEnvironmentsAllowed() - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Checks whether it is currently permitted to explicitly instantiate a LocalEnvironment or a RemoteEnvironment.
areFieldsUnique(FieldSet) - Method in class org.apache.flink.optimizer.dataproperties.LocalProperties
Checks whether the given set of fields is unique, as specified in these local properties.
ARG_CONVERSION_DURATION - Static variable in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
 
ARG_CONVERSION_RATE - Static variable in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
 
ARG_DMAX - Static variable in class org.apache.flink.metrics.ganglia.GangliaReporter
 
ARG_HOST - Static variable in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
 
ARG_HOST - Static variable in class org.apache.flink.metrics.statsd.StatsDReporter
 
ARG_MODE_ADDRESSING - Static variable in class org.apache.flink.metrics.ganglia.GangliaReporter
 
ARG_PORT - Static variable in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
 
ARG_PORT - Static variable in class org.apache.flink.metrics.jmx.JMXReporter
 
ARG_PORT - Static variable in class org.apache.flink.metrics.statsd.StatsDReporter
 
ARG_PREFIX - Static variable in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
 
ARG_PROTOCOL - Static variable in class org.apache.flink.metrics.graphite.GraphiteReporter
 
ARG_TMAX - Static variable in class org.apache.flink.metrics.ganglia.GangliaReporter
 
ARG_TTL - Static variable in class org.apache.flink.metrics.ganglia.GangliaReporter
 
args() - Method in class org.apache.flink.table.expressions.AggFunctionCall
 
args() - Method in class org.apache.flink.table.expressions.Call
 
ARGUMENT_ASSIGNMENT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
ARGUMENT_ASSIGNMENT operator (=<) assigns an argument to a function call to a particular named parameter.
argumentMustBeScalar(int) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
argumentMustBeScalar(int) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
argumentMustBeScalar(int) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
argumentMustBeScalar(int) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
arity - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
aroundPostRestart(Throwable) - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
aroundPostRestart(Throwable) - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
aroundPostRestart(Throwable) - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
aroundPostRestart(Throwable) - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
aroundPostRestart(Throwable) - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
aroundPostRestart(Throwable) - Static method in class org.apache.flink.mesos.scheduler.Tasks
 
aroundPostRestart(Throwable) - Static method in class org.apache.flink.runtime.jobmanager.JobManager
 
aroundPostRestart(Throwable) - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
 
aroundPostRestart(Throwable) - Static method in class org.apache.flink.yarn.ApplicationClient
 
aroundPostRestart(Throwable) - Static method in class org.apache.flink.yarn.YarnTaskManager
 
aroundPostStop() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
aroundPostStop() - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
aroundPostStop() - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
aroundPostStop() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
aroundPostStop() - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
aroundPostStop() - Static method in class org.apache.flink.mesos.scheduler.Tasks
 
aroundPostStop() - Static method in class org.apache.flink.runtime.jobmanager.JobManager
 
aroundPostStop() - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
 
aroundPostStop() - Static method in class org.apache.flink.yarn.ApplicationClient
 
aroundPostStop() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
aroundPreRestart(Throwable, Option<Object>) - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
aroundPreRestart(Throwable, Option<Object>) - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
aroundPreRestart(Throwable, Option<Object>) - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
aroundPreRestart(Throwable, Option<Object>) - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
aroundPreRestart(Throwable, Option<Object>) - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
aroundPreRestart(Throwable, Option<Object>) - Static method in class org.apache.flink.mesos.scheduler.Tasks
 
aroundPreRestart(Throwable, Option<Object>) - Static method in class org.apache.flink.runtime.jobmanager.JobManager
 
aroundPreRestart(Throwable, Option<Object>) - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
 
aroundPreRestart(Throwable, Option<Object>) - Static method in class org.apache.flink.yarn.ApplicationClient
 
aroundPreRestart(Throwable, Option<Object>) - Static method in class org.apache.flink.yarn.YarnTaskManager
 
aroundPreStart() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
aroundPreStart() - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
aroundPreStart() - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
aroundPreStart() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
aroundPreStart() - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
aroundPreStart() - Static method in class org.apache.flink.mesos.scheduler.Tasks
 
aroundPreStart() - Static method in class org.apache.flink.runtime.jobmanager.JobManager
 
aroundPreStart() - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
 
aroundPreStart() - Static method in class org.apache.flink.yarn.ApplicationClient
 
aroundPreStart() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class org.apache.flink.mesos.scheduler.Tasks
 
aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class org.apache.flink.runtime.jobmanager.JobManager
 
aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
 
aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class org.apache.flink.yarn.ApplicationClient
 
aroundReceive(PartialFunction<Object, BoxedUnit>, Object) - Static method in class org.apache.flink.yarn.YarnTaskManager
 
array - Class in org.apache.flink.table.api.scala
Creates an array of literals.
array() - Constructor for class org.apache.flink.table.api.scala.array
 
array() - Method in class org.apache.flink.table.expressions.ArrayCardinality
 
array() - Method in class org.apache.flink.table.expressions.ArrayElement
 
array() - Method in class org.apache.flink.table.expressions.ArrayElementAt
 
array$ - Class in org.apache.flink.table.api.scala
Creates an array of literals.
array$() - Constructor for class org.apache.flink.table.api.scala.array$
 
array2ArrayConstructor(Object) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionConversions
 
ARRAY_QUERY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The ARRAY Query Constructor.
ARRAY_VALUE_CONSTRUCTOR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The ARRAY Value Constructor.
arrayAwareToString(Object) - Static method in class org.apache.flink.util.StringUtils
This method calls Object.toString() on the given object, unless the object is an array.
ArrayCardinality - Class in org.apache.flink.table.expressions
 
ArrayCardinality(Expression) - Constructor for class org.apache.flink.table.expressions.ArrayCardinality
 
ArrayCardinality$ - Class in org.apache.flink.table.expressions
 
ArrayCardinality$() - Constructor for class org.apache.flink.table.expressions.ArrayCardinality$
 
ArrayConstructor - Class in org.apache.flink.table.expressions
 
ArrayConstructor(Seq<Expression>) - Constructor for class org.apache.flink.table.expressions.ArrayConstructor
 
ArrayConstructor$ - Class in org.apache.flink.table.expressions
 
ArrayConstructor$() - Constructor for class org.apache.flink.table.expressions.ArrayConstructor$
 
ArrayDescriptor(int, scala.reflect.macros.Context.universe, TypeDescriptors<C>.UDTDescriptor) - Constructor for class org.apache.flink.api.scala.codegen.TypeDescriptors.ArrayDescriptor
 
ArrayElement - Class in org.apache.flink.table.expressions
 
ArrayElement(Expression) - Constructor for class org.apache.flink.table.expressions.ArrayElement
 
ArrayElement$ - Class in org.apache.flink.table.expressions
 
ArrayElement$() - Constructor for class org.apache.flink.table.expressions.ArrayElement$
 
ArrayElementAt - Class in org.apache.flink.table.expressions
 
ArrayElementAt(Expression, Expression) - Constructor for class org.apache.flink.table.expressions.ArrayElementAt
 
ArrayElementAt$ - Class in org.apache.flink.table.expressions
 
ArrayElementAt$() - Constructor for class org.apache.flink.table.expressions.ArrayElementAt$
 
ArrayFromTuple - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
Converts a Tuple to an Object-Array.
ArrayFromTuple() - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ArrayFromTuple
Using this constructor the extractor will convert the whole tuple (all fields in the original order) to an array.
ArrayFromTuple(int...) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ArrayFromTuple
Using this constructor the extractor will combine the fields as specified in the indexes parameter in an object array.
ArrayListSerializer<T> - Class in org.apache.flink.runtime.state
 
ArrayListSerializer(TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.state.ArrayListSerializer
 
arrayNext() - Method in class org.apache.flink.api.avro.DataInputDecoder
 
arrayNext() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
ArrayRelDataType - Class in org.apache.flink.table.plan.schema
Flink distinguishes between primitive arrays (int[], double[], ...) and object arrays (Integer[], MyPojo[], ...).
ArrayRelDataType(TypeInformation<?>, RelDataType, boolean) - Constructor for class org.apache.flink.table.plan.schema.ArrayRelDataType
 
arrayToMap(String[]) - Static method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
 
arrayToString(Object) - Static method in class org.apache.flink.util.StringUtils
Returns a string representation of the given array.
Artifact(Path, Path, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
 
AS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
AS operator associates an expression in the SELECT clause with an alias.
as(String) - Method in class org.apache.flink.table.api.OverWindowWithPreceding
Assigns an alias for this window that the following select() clause can refer to.
as(Expression) - Method in class org.apache.flink.table.api.OverWindowWithPreceding
Assigns an alias for this window that the following select() clause can refer to.
as(Symbol, Seq<Symbol>) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Specifies a name for an expression i.e.
as(Expression) - Method in class org.apache.flink.table.api.SessionWithGapOnTime
Assigns an alias for this window that the following groupBy() and select() clause can refer to.
as(String) - Method in class org.apache.flink.table.api.SessionWithGapOnTime
Assigns an alias for this window that the following groupBy() and select() clause can refer to.
as(Expression) - Method in class org.apache.flink.table.api.SlideWithSizeAndSlideOnTime
Assigns an alias for this window that the following groupBy() and select() clause can refer to.
as(String) - Method in class org.apache.flink.table.api.SlideWithSizeAndSlideOnTime
Assigns an alias for this window that the following groupBy() and select() clause can refer to.
as(Seq<Expression>) - Method in class org.apache.flink.table.api.Table
Renames the fields of the expression result.
as(String) - Method in class org.apache.flink.table.api.Table
Renames the fields of the expression result.
as(Expression) - Method in class org.apache.flink.table.api.TumbleWithSizeOnTime
Assigns an alias for this window that the following groupBy() and select() clause can refer to.
as(String) - Method in class org.apache.flink.table.api.TumbleWithSizeOnTime
Assigns an alias for this window that the following groupBy() and select() clause can refer to.
as(String) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
AS() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
AS() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
as(Option<Seq<String>>) - Method in class org.apache.flink.table.expressions.TableFunctionCall
Assigns an alias for this table function's returned fields that the following operator can refer to.
asArray(Class<U>) - Static method in class org.apache.flink.api.common.operators.AbstractUdfOperator
Generic utility function that wraps a single class object into an array of that class type.
asBreeze() - Method in class org.apache.flink.ml.math.Breeze.BreezeArrayConverter
 
asBreeze() - Method in class org.apache.flink.ml.math.Breeze.Matrix2BreezeConverter
 
asBreeze() - Method in class org.apache.flink.ml.math.Breeze.Vector2BreezeConverter
 
asc() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Specifies ascending order of an expression i.e.
Asc - Class in org.apache.flink.table.expressions
 
Asc(Expression) - Constructor for class org.apache.flink.table.expressions.Asc
 
ASC() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
ASC() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
Asc$ - Class in org.apache.flink.table.expressions
 
Asc$() - Constructor for class org.apache.flink.table.expressions.Asc$
 
ascending - Variable in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
ascendingComparison - Variable in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
AscendingTimestampExtractor<T> - Class in org.apache.flink.streaming.api.functions
Deprecated.
AscendingTimestampExtractor() - Constructor for class org.apache.flink.streaming.api.functions.AscendingTimestampExtractor
Deprecated.
 
AscendingTimestampExtractor<T> - Class in org.apache.flink.streaming.api.functions.timestamps
A timestamp assigner and watermark generator for streams where timestamps are monotonously ascending.
AscendingTimestampExtractor() - Constructor for class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
 
AscendingTimestampExtractor.FailingHandler - Class in org.apache.flink.streaming.api.functions.timestamps
Handler that fails the program when timestamp monotony is violated.
AscendingTimestampExtractor.IgnoringHandler - Class in org.apache.flink.streaming.api.functions.timestamps
Handler that does nothing when timestamp monotony is violated.
AscendingTimestampExtractor.LoggingHandler - Class in org.apache.flink.streaming.api.functions.timestamps
Handler that only logs violations of timestamp monotony, on WARN log level.
AscendingTimestampExtractor.MonotonyViolationHandler - Interface in org.apache.flink.streaming.api.functions.timestamps
Interface for handlers that handle violations of the monotonous ascending timestamps property.
asFile(String) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
asFlinkTuples() - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
Specifies that the InputFormat returns Flink tuples instead of HCatRecord.
ASIN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
asin() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Calculates the arc sine of a given number.
ASIN() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
ASIN() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
Asin - Class in org.apache.flink.table.expressions
 
Asin(Expression) - Constructor for class org.apache.flink.table.expressions.Asin
 
Asin$ - Class in org.apache.flink.table.expressions
 
Asin$() - Constructor for class org.apache.flink.table.expressions.Asin$
 
ASIN_DEC() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
ASIN_DEC() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
asJavaCollection() - Method in class org.apache.flink.runtime.messages.ArchiveMessages.ArchivedJobs
 
asJavaCollection() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RegisteredTaskManagers
 
asJavaIterable() - Method in class org.apache.flink.runtime.messages.ArchiveMessages.ArchivedJobs
 
asJavaIterable() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RegisteredTaskManagers
 
asJavaIterable() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RunningJobs
 
ask(Object, FiniteDuration) - Method in interface org.apache.flink.runtime.instance.ActorGateway
Sends a message asynchronously and returns its response.
ask(Object, FiniteDuration) - Method in class org.apache.flink.runtime.instance.AkkaActorGateway
Sends a message asynchronously and returns its response.
askTimeout() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
askTimeout() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
The timeout for all actor ask futures
askTimeout() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
asLatencyMarker() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
Casts this element into a LatencyMarker.
asLong(Expression) - Method in class org.apache.flink.table.runtime.aggregate.AggregateUtil$
 
asLong(Expression) - Static method in class org.apache.flink.table.runtime.aggregate.AggregateUtil
 
asQueryableState(String) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Publishes the keyed stream as queryable ValueState instance.
asQueryableState(String, ValueStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Publishes the keyed stream as a queryable ValueState instance.
asQueryableState(String, FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Deprecated.
will be removed in a future version
asQueryableState(String, ReducingStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Publishes the keyed stream as a queryable ReducingState instance.
asQueryableState(String) - Method in class org.apache.flink.streaming.api.scala.KeyedStream
Publishes the keyed stream as a queryable ValueState instance.
asQueryableState(String, ValueStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.scala.KeyedStream
Publishes the keyed stream as a queryable ValueState instance.
asQueryableState(String, FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.streaming.api.scala.KeyedStream
Deprecated.
will be removed in a future version. Since .
asQueryableState(String, ReducingStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.scala.KeyedStream
Publishes the keyed stream as a queryable ReducingState instance.
asRecord() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
Casts this element into a StreamRecord.
asResultCollection() - Method in interface org.apache.flink.streaming.api.operators.async.queue.AsyncResult
Return this async result as a async result collection.
asResultCollection() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
 
assertNumericExpr(TypeInformation<?>, String) - Method in class org.apache.flink.table.typeutils.TypeCheckUtils$
 
assertNumericExpr(TypeInformation<?>, String) - Static method in class org.apache.flink.table.typeutils.TypeCheckUtils
 
assertOrderableExpr(TypeInformation<?>, String) - Method in class org.apache.flink.table.typeutils.TypeCheckUtils$
 
assertOrderableExpr(TypeInformation<?>, String) - Static method in class org.apache.flink.table.typeutils.TypeCheckUtils
 
Assign(List<Tuple2<TaskRequest, String>>) - Constructor for class org.apache.flink.mesos.scheduler.LaunchCoordinator.Assign
 
assign(KafkaTopicPartition, int) - Static method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionAssigner
Returns the index of the target subtask that a specific Kafka partition should be assigned to.
Assign$() - Constructor for class org.apache.flink.mesos.scheduler.LaunchCoordinator.Assign$
 
assignAscendingTimestamps(Function1<T, Object>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Assigns timestamps to the elements in the data stream and periodically creates watermarks to signal event time progress.
AssignDefaultRetractionRule() - Constructor for class org.apache.flink.table.plan.rules.datastream.DataStreamRetractionRules.AssignDefaultRetractionRule
 
AssignerWithPeriodicWatermarks<T> - Interface in org.apache.flink.streaming.api.functions
The AssignerWithPeriodicWatermarks assigns event time timestamps to elements, and generates low watermarks that signal event time progress within the stream.
AssignerWithPunctuatedWatermarks<T> - Interface in org.apache.flink.streaming.api.functions
The AssignerWithPunctuatedWatermarks assigns event time timestamps to elements, and generates low watermarks that signal event time progress within the stream.
assignKeyToParallelOperator(Object, int, int) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
Assigns the given key to a parallel operator index.
assignPartition(int, byte) - Static method in class org.apache.flink.runtime.operators.hash.MutableHashTable
Assigns a partition to a bucket.
assignPartitions(KafkaConsumer<?, ?>, List<TopicPartition>) - Method in class org.apache.flink.streaming.connectors.kafka.internal.KafkaConsumerCallBridge
 
assignPartitions(KafkaConsumer<?, ?>, List<TopicPartition>) - Method in class org.apache.flink.streaming.connectors.kafka.internal.KafkaConsumerCallBridge010
 
AssignRangeIndex<IN> - Class in org.apache.flink.runtime.operators.udf
This mapPartition function require a DataSet with RangeBoundaries as broadcast input, it generate Tuple2 which includes range index and record itself as output.
AssignRangeIndex(TypeComparatorFactory<IN>) - Constructor for class org.apache.flink.runtime.operators.udf.AssignRangeIndex
 
assignStates() - Method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
 
assignTimestamps(TimestampExtractor<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
assignTimestamps(TimestampExtractor<T>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Deprecated.
. Since .
assignTimestampsAndWatermarks(AssignerWithPeriodicWatermarks<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Assigns timestamps to the elements in the data stream and periodically creates watermarks to signal event time progress.
assignTimestampsAndWatermarks(AssignerWithPunctuatedWatermarks<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Assigns timestamps to the elements in the data stream and creates watermarks to signal event time progress based on the elements themselves.
assignTimestampsAndWatermarks(AssignerWithPeriodicWatermarks<T>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Assigns timestamps to the elements in the data stream and periodically creates watermarks to signal event time progress.
assignTimestampsAndWatermarks(AssignerWithPunctuatedWatermarks<T>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Assigns timestamps to the elements in the data stream and periodically creates watermarks to signal event time progress.
assignTimestampsAndWatermarks(AssignerWithPunctuatedWatermarks<T>) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
Specifies an AssignerWithPunctuatedWatermarks to emit watermarks in a punctuated manner.
assignTimestampsAndWatermarks(AssignerWithPeriodicWatermarks<T>) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
Specifies an AssignerWithPunctuatedWatermarks to emit watermarks in a punctuated manner.
assignToKeyGroup(Object, int) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
Assigns the given key to a key-group index.
assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.BaseAlignedWindowAssigner
 
assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
 
assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
 
assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
 
assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
 
assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
 
assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
 
assignWindows(Object, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
 
assignWindows(T, long, WindowAssigner.WindowAssignerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
Returns a Collection of windows that should be assigned to the element.
asStreamStatus() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
Casts this element into a StreamStatus.
assumeJava8() - Static method in class org.apache.flink.core.testutils.CommonTestUtils
Checks whether this code runs in a Java 8 (Java 1.8) JVM.
asVariable(String) - Static method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
Formats the given string to resemble a scope variable.
asWatermark() - Method in interface org.apache.flink.streaming.api.operators.async.queue.AsyncResult
Return this async result as a async watermark result.
asWatermark() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
 
asWatermark() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
Casts this element into a Watermark.
AsyncCollectionResult<T> - Interface in org.apache.flink.streaming.api.operators.async.queue
AsyncResult sub class for asynchronous result collections.
AsyncCollector<OUT> - Interface in org.apache.flink.streaming.api.functions.async.collector
AsyncCollector collects data / error in user codes while processing async i/o.
AsyncCollector<OUT> - Interface in org.apache.flink.streaming.api.scala.async
The async collector collects data/errors from the user code while processing asynchronous I/O operations.
AsyncDataStream - Class in org.apache.flink.streaming.api.datastream
A helper class to apply AsyncFunction to a data stream.
AsyncDataStream() - Constructor for class org.apache.flink.streaming.api.datastream.AsyncDataStream
 
AsyncDataStream - Class in org.apache.flink.streaming.api.scala
A helper class to apply AsyncFunction to a data stream.
AsyncDataStream() - Constructor for class org.apache.flink.streaming.api.scala.AsyncDataStream
 
AsyncDataStream$ - Class in org.apache.flink.streaming.api.scala
A helper class to apply AsyncFunction to a data stream.
AsyncDataStream$() - Constructor for class org.apache.flink.streaming.api.scala.AsyncDataStream$
 
AsyncDataStream.OutputMode - Enum in org.apache.flink.streaming.api.datastream
Output mode for asynchronous operations.
AsyncDoneCallback - Interface in org.apache.flink.runtime.io.async
Callback for an asynchronous operation that is called on termination
asyncException - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
Errors encountered in the async producer are stored here
AsyncExceptionHandler - Interface in org.apache.flink.streaming.runtime.tasks
An interface marking a task as capable of handling exceptions thrown by different threads, other than the one executing the task itself.
AsyncFunction<IN,OUT> - Interface in org.apache.flink.streaming.api.functions.async
A function to trigger Async I/O operation.
AsyncFunction<IN,OUT> - Interface in org.apache.flink.streaming.api.scala.async
A function to trigger async I/O operations.
AsynchronousBlockReader - Class in org.apache.flink.runtime.io.disk.iomanager
A reader that reads data in blocks from a file channel.
AsynchronousBlockReader(FileIOChannel.ID, RequestQueue<ReadRequest>, LinkedBlockingQueue<MemorySegment>) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockReader
Creates a new block channel reader for the given channel.
AsynchronousBlockWriter - Class in org.apache.flink.runtime.io.disk.iomanager
 
AsynchronousBlockWriter(FileIOChannel.ID, RequestQueue<WriteRequest>, LinkedBlockingQueue<MemorySegment>) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockWriter
Creates a new block channel writer for the given channel.
AsynchronousBlockWriterWithCallback - Class in org.apache.flink.runtime.io.disk.iomanager
An asynchronous implementation of the BlockChannelWriterWithCallback that queues I/O requests and calls a callback once they have been handled.
AsynchronousBlockWriterWithCallback(FileIOChannel.ID, RequestQueue<WriteRequest>, RequestDoneCallback<MemorySegment>) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockWriterWithCallback
Creates a new asynchronous block writer for the given channel.
AsynchronousBufferFileReader - Class in org.apache.flink.runtime.io.disk.iomanager
 
AsynchronousBufferFileReader(FileIOChannel.ID, RequestQueue<ReadRequest>, RequestDoneCallback<Buffer>) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileReader
 
AsynchronousBufferFileSegmentReader - Class in org.apache.flink.runtime.io.disk.iomanager
 
AsynchronousBufferFileSegmentReader(FileIOChannel.ID, RequestQueue<ReadRequest>, RequestDoneCallback<FileSegment>) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileSegmentReader
 
AsynchronousBufferFileWriter - Class in org.apache.flink.runtime.io.disk.iomanager
 
AsynchronousBufferFileWriter(FileIOChannel.ID, RequestQueue<WriteRequest>) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileWriter
 
AsynchronousBulkBlockReader - Class in org.apache.flink.runtime.io.disk.iomanager
 
AsynchronousBulkBlockReader(FileIOChannel.ID, RequestQueue<ReadRequest>, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBulkBlockReader
 
AsynchronousException - Exception in org.apache.flink.streaming.runtime.tasks
An exception for wrapping exceptions that are thrown by an operator in threads other than the main compute thread of that operator.
AsynchronousException(Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.AsynchronousException
 
AsynchronousException(String, Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.AsynchronousException
 
AsynchronousFileIOChannel<T,R extends org.apache.flink.runtime.io.disk.iomanager.IORequest> - Class in org.apache.flink.runtime.io.disk.iomanager
A base class for readers and writers that accept read or write requests for whole blocks.
AsynchronousFileIOChannel(FileIOChannel.ID, RequestQueue<R>, RequestDoneCallback<T>, boolean) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
Creates a new channel access to the path indicated by the given ID.
asyncInvoke(IN, AsyncCollector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.async.AsyncFunction
Trigger async operation for each stream input.
asyncInvoke(IN, AsyncCollector<OUT>) - Method in class org.apache.flink.streaming.api.functions.async.RichAsyncFunction
 
asyncInvoke(IN, AsyncCollector<OUT>) - Method in interface org.apache.flink.streaming.api.scala.async.AsyncFunction
Trigger the async operation for each stream input
AsyncIOExample - Class in org.apache.flink.streaming.examples.async
Example to illustrates how to use AsyncFunction
AsyncIOExample() - Constructor for class org.apache.flink.streaming.examples.async.AsyncIOExample
 
AsyncIOExample - Class in org.apache.flink.streaming.scala.examples.async
 
AsyncIOExample() - Constructor for class org.apache.flink.streaming.scala.examples.async.AsyncIOExample
 
AsyncIOExample$ - Class in org.apache.flink.streaming.scala.examples.async
 
AsyncIOExample$() - Constructor for class org.apache.flink.streaming.scala.examples.async.AsyncIOExample$
 
AsyncResult - Interface in org.apache.flink.streaming.api.operators.async.queue
Asynchronous result returned by the StreamElementQueue.
AsyncStoppable - Interface in org.apache.flink.runtime.io.async
An asynchronous operation that can be stopped.
AsyncStoppableTaskWithCallback<V> - Class in org.apache.flink.runtime.io.async
 
AsyncStoppableTaskWithCallback(StoppableCallbackCallable<V>) - Constructor for class org.apache.flink.runtime.io.async.AsyncStoppableTaskWithCallback
 
AsyncWaitOperator<IN,OUT> - Class in org.apache.flink.streaming.api.operators.async
The AsyncWaitOperator allows to asynchronously process incoming stream records.
AsyncWaitOperator(AsyncFunction<IN, OUT>, long, int, AsyncDataStream.OutputMode) - Constructor for class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
AsyncWatermarkResult - Interface in org.apache.flink.streaming.api.operators.async.queue
AsyncResult subclass for asynchronous result Watermark.
at(Expression) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Accesses the element of an array based on an index (starting at 1).
ATAN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
atan() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Calculates the arc tangent of a given number.
ATAN() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
ATAN() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
Atan - Class in org.apache.flink.table.expressions
 
Atan(Expression) - Constructor for class org.apache.flink.table.expressions.Atan
 
Atan$ - Class in org.apache.flink.table.expressions
 
Atan$() - Constructor for class org.apache.flink.table.expressions.Atan$
 
ATAN2 - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
ATAN_DEC() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
ATAN_DEC() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
atom() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
atom() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
AtomicDisposableReferenceCounter - Class in org.apache.flink.runtime.util
Atomic reference counter, which enters a "disposed" state after it reaches a configurable reference count (default 0).
AtomicDisposableReferenceCounter() - Constructor for class org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
 
AtomicDisposableReferenceCounter(int) - Constructor for class org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
 
AtomicKvStateRequestStats - Class in org.apache.flink.runtime.query.netty
Atomic KvStateRequestStats implementation.
AtomicKvStateRequestStats() - Constructor for class org.apache.flink.runtime.query.netty.AtomicKvStateRequestStats
 
AtomicType<T> - Interface in org.apache.flink.api.common.typeinfo
An atomic type is a type that is treated as one indivisible unit and where the entire type acts as a key.
attachJobGraph(List<JobVertex>) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
AttachToJobAndWait(JobID) - Constructor for class org.apache.flink.runtime.messages.JobClientMessages.AttachToJobAndWait
 
AttachToJobAndWait$() - Constructor for class org.apache.flink.runtime.messages.JobClientMessages.AttachToJobAndWait$
 
attachToRunningJob(JobID, ActorGateway, Configuration, ActorSystem, HighAvailabilityServices, FiniteDuration, boolean) - Static method in class org.apache.flink.runtime.client.JobClient
Attaches to a running Job using the JobID.
attempt() - Method in class org.apache.flink.runtime.messages.RegistrationMessages.TriggerTaskManagerRegistration
 
attemptID() - Method in class org.apache.flink.runtime.messages.TaskMessages.CancelTask
 
attemptID() - Method in class org.apache.flink.runtime.messages.TaskMessages.StopTask
 
attemptNumber() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
Attribute - Class in org.apache.flink.table.expressions
 
Attribute() - Constructor for class org.apache.flink.table.expressions.Attribute
 
ATTRIBUTE_COUNT - Static variable in class org.apache.flink.storm.wordcount.operators.BoltCounter
 
ATTRIBUTE_COUNT - Static variable in class org.apache.flink.storm.wordcount.operators.BoltCounterByName
 
ATTRIBUTE_COUNT - Static variable in class org.apache.flink.storm.wordcount.operators.BoltTokenizer
 
ATTRIBUTE_COUNT - Static variable in class org.apache.flink.storm.wordcount.operators.BoltTokenizerByName
 
ATTRIBUTE_COUNT_INDEX - Static variable in class org.apache.flink.storm.wordcount.operators.BoltTokenizer
 
ATTRIBUTE_COUNT_INDEX - Static variable in class org.apache.flink.storm.wordcount.operators.BoltTokenizerByName
 
ATTRIBUTE_LINE - Static variable in class org.apache.flink.storm.util.AbstractLineSpout
 
ATTRIBUTE_WORD - Static variable in class org.apache.flink.storm.wordcount.operators.BoltCounter
 
ATTRIBUTE_WORD - Static variable in class org.apache.flink.storm.wordcount.operators.BoltCounterByName
 
ATTRIBUTE_WORD - Static variable in class org.apache.flink.storm.wordcount.operators.BoltTokenizer
 
ATTRIBUTE_WORD - Static variable in class org.apache.flink.storm.wordcount.operators.BoltTokenizerByName
 
ATTRIBUTE_WORD_INDEX - Static variable in class org.apache.flink.storm.wordcount.operators.BoltTokenizer
 
ATTRIBUTE_WORD_INDEX - Static variable in class org.apache.flink.storm.wordcount.operators.BoltTokenizerByName
 
Attributes - Class in org.apache.flink.contrib.tweetinputformat.model.places
 
Attributes() - Constructor for class org.apache.flink.contrib.tweetinputformat.model.places.Attributes
 
attrNameCntr() - Method in class org.apache.flink.table.api.TableEnvironment
 
autoAck - Variable in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
 
AuxiliaryConverter - Interface in org.apache.calcite.sql2rel
Converts an expression for a group window function (e.g.
AuxiliaryConverter.Impl - Class in org.apache.calcite.sql2rel
Simple implementation of AuxiliaryConverter.
auxiliaryToGroup(SqlKind) - Static method in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Returns the group function for which a given kind is an auxiliary function, or null if it is not an auxiliary function.
available() - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
 
available() - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
 
available() - Method in class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
 
available() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
 
available() - Method in class org.apache.flink.runtime.state.BoundedInputStream
 
available() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
 
available() - Method in class org.apache.flink.runtime.util.NonClosingStreamDecorator
 
availableMemory - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
The free memory segments currently available to the hash join.
AverageAccumulator - Class in org.apache.flink.api.common.accumulators
An accumulator that computes the average value.
AverageAccumulator() - Constructor for class org.apache.flink.api.common.accumulators.AverageAccumulator
 
AverageClusteringCoefficient<K extends Comparable<K> & CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.clustering.directed
The average clustering coefficient measures the mean connectedness of a graph.
AverageClusteringCoefficient() - Constructor for class org.apache.flink.graph.library.clustering.directed.AverageClusteringCoefficient
 
AverageClusteringCoefficient<K extends Comparable<K> & CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.clustering.undirected
The average clustering coefficient measures the mean connectedness of a graph.
AverageClusteringCoefficient() - Constructor for class org.apache.flink.graph.library.clustering.undirected.AverageClusteringCoefficient
 
AverageClusteringCoefficient.Result - Class in org.apache.flink.graph.library.clustering.directed
Wraps global clustering coefficient metrics.
AverageClusteringCoefficient.Result - Class in org.apache.flink.graph.library.clustering.undirected
Wraps global clustering coefficient metrics.
AVG - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
AVG aggregate function.
avg() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Returns the average (arithmetic mean) of the numeric field across all input values.
avg(boolean, String, RexNode) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
Avg - Class in org.apache.flink.table.expressions
 
Avg(Expression) - Constructor for class org.apache.flink.table.expressions.Avg
 
Avg$ - Class in org.apache.flink.table.expressions
 
Avg$() - Constructor for class org.apache.flink.table.expressions.Avg$
 
AVG_RECORD_BYTES_UNKNOWN - Static variable in interface org.apache.flink.api.common.io.statistics.BaseStatistics
Constant indicating that average record width is unknown.
avgBytesPerRecord - Variable in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
 
avgLen() - Method in class org.apache.flink.table.plan.stats.ColumnStats
 
AvroInputFormat<E> - Class in org.apache.flink.api.java.io
Provides a FileInputFormat for Avro records.
AvroInputFormat(Path, Class<E>) - Constructor for class org.apache.flink.api.java.io.AvroInputFormat
 
AvroKeyValue(GenericRecord) - Constructor for class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter.AvroKeyValue
Wraps a GenericRecord that is a key value pair.
AvroKeyValueSinkWriter<K,V> - Class in org.apache.flink.streaming.connectors.fs
Implementation of AvroKeyValue writer that can be used in Sink.
AvroKeyValueSinkWriter(Map<String, String>) - Constructor for class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter
C'tor for the writer
AvroKeyValueSinkWriter.AvroKeyValue<K,V> - Class in org.apache.flink.streaming.connectors.fs
 
AvroOutputFormat<E> - Class in org.apache.flink.api.java.io
 
AvroOutputFormat(Path, Class<E>) - Constructor for class org.apache.flink.api.java.io.AvroOutputFormat
 
AvroOutputFormat(Class<E>) - Constructor for class org.apache.flink.api.java.io.AvroOutputFormat
 
AvroOutputFormat.Codec - Enum in org.apache.flink.api.java.io
Wrapper which encapsulates the supported codec and a related serialization byte.
AvroRowDeserializationSchema - Class in org.apache.flink.streaming.util.serialization
Deserialization schema from Avro bytes over SpecificRecord to Row.
AvroRowDeserializationSchema(Class<? extends SpecificRecord>) - Constructor for class org.apache.flink.streaming.util.serialization.AvroRowDeserializationSchema
Creates a Avro deserialization schema for the given record.
AvroRowSerializationSchema - Class in org.apache.flink.streaming.util.serialization
Serialization schema that serializes Row over SpecificRecord into a Avro bytes.
AvroRowSerializationSchema(Class<? extends SpecificRecord>) - Constructor for class org.apache.flink.streaming.util.serialization.AvroRowSerializationSchema
Creates a Avro serialization schema for the given schema.
AvroSchemaSerializer() - Constructor for class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.AvroSchemaSerializer
 
AvroSerializer<T> - Class in org.apache.flink.api.java.typeutils.runtime
General purpose serialization.
AvroSerializer(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
 
AvroSerializer(Class<T>, Class<? extends T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
 
AvroSerializer.AvroSerializerConfigSnapshot<T> - Class in org.apache.flink.api.java.typeutils.runtime
 
AvroSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.AvroSerializer.AvroSerializerConfigSnapshot
 
AvroSerializerConfigSnapshot(Class<T>, Class<? extends T>, LinkedHashMap<String, KryoRegistration>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.AvroSerializer.AvroSerializerConfigSnapshot
 
AvroTypeInfo<T extends org.apache.avro.specific.SpecificRecordBase> - Class in org.apache.flink.api.java.typeutils
Special type information to generate a special AvroTypeInfo for Avro POJOs (implementing SpecificRecordBase, the typed Avro POJOs) Proceeding: It uses a regular pojo type analysis and replaces all GenericType<CharSequence> with a GenericType<avro.Utf8>.
AvroTypeInfo(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.AvroTypeInfo
 
await() - Method in class org.apache.flink.core.testutils.MultiShotLatch
Waits until MultiShotLatch.trigger() is called.
await() - Method in class org.apache.flink.core.testutils.OneShotLatch
Waits until OneShotLatch.trigger() is called.
await(long, TimeUnit) - Method in class org.apache.flink.core.testutils.OneShotLatch
Waits until OneShotLatch.trigger() is called.
awaitJobManagerGatewayAndWebPort() - Method in class org.apache.flink.runtime.webmonitor.JobManagerRetriever
Awaits the leading job manager gateway and its web monitor port.
awaitJobResult(JobListeningContext) - Static method in class org.apache.flink.runtime.client.JobClient
Given a JobListeningContext, awaits the result of the job execution that this context is bound to
awaitStartOfSuperstepOrTermination(int) - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepKickoffLatch
 
awaitTermination() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
axpy(double, Vector, Vector) - Method in class org.apache.flink.ml.math.BLAS$
y += a * x
axpy(double, Vector, Vector) - Static method in class org.apache.flink.ml.math.BLAS
y += a * x

B

B - Variable in class org.apache.flink.graph.generator.RMatGraph
 
back() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable.UnmatchedBuildIterator
 
backend - Variable in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
Backend that holds the actual RocksDB instance where we store state
BackPressureStatsTracker - Class in org.apache.flink.runtime.webmonitor
Back pressure statistics tracker.
BackPressureStatsTracker(StackTraceSampleCoordinator, int, int, Time) - Constructor for class org.apache.flink.runtime.webmonitor.BackPressureStatsTracker
Creates a back pressure statistics tracker.
BarrierBuffer - Class in org.apache.flink.streaming.runtime.io
The barrier buffer is CheckpointBarrierHandler that blocks inputs with barriers until all inputs have received the barrier for a given checkpoint.
BarrierBuffer(InputGate, IOManager) - Constructor for class org.apache.flink.streaming.runtime.io.BarrierBuffer
Creates a new checkpoint stream aligner.
BarrierBuffer(InputGate, IOManager, long) - Constructor for class org.apache.flink.streaming.runtime.io.BarrierBuffer
Creates a new checkpoint stream aligner.
BarrierTracker - Class in org.apache.flink.streaming.runtime.io
The BarrierTracker keeps track of what checkpoint barriers have been received from which input channels.
BarrierTracker(InputGate) - Constructor for class org.apache.flink.streaming.runtime.io.BarrierTracker
 
BaseAlignedWindowAssigner - Class in org.apache.flink.streaming.api.windowing.assigners
BaseAlignedWindowAssigner(long) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.BaseAlignedWindowAssigner
 
BasePathBucketer<T> - Class in org.apache.flink.streaming.connectors.fs.bucketing
A Bucketer that does not perform any bucketing of files.
BasePathBucketer() - Constructor for class org.apache.flink.streaming.connectors.fs.bucketing.BasePathBucketer
 
BaseStatistics - Interface in org.apache.flink.api.common.io.statistics
Interface describing the basic statistics that can be obtained from the input.
baseType() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.FactoryTypeDescriptor
 
baseURL() - Method in class org.apache.flink.mesos.util.MesosArtifactServer
 
BasicArrayTypeInfo<T,C> - Class in org.apache.flink.api.common.typeinfo
 
BasicOperatorTable - Class in org.apache.flink.table.validate
 
BasicOperatorTable() - Constructor for class org.apache.flink.table.validate.BasicOperatorTable
 
BasicTypeComparator<T extends Comparable<T>> - Class in org.apache.flink.api.common.typeutils.base
 
BasicTypeComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
BasicTypeInfo<T> - Class in org.apache.flink.api.common.typeinfo
Type information for primitive types (int, long, double, byte, ...), String, Date, Void, BigInteger, and BigDecimal.
BasicTypeInfo(Class<T>, Class<?>[], TypeSerializer<T>, Class<? extends TypeComparator<T>>) - Constructor for class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
BatchQueryConfig - Class in org.apache.flink.table.api
The BatchQueryConfig holds parameters to configure the behavior of batch queries.
BatchQueryConfig() - Constructor for class org.apache.flink.table.api.BatchQueryConfig
 
BatchScan - Interface in org.apache.flink.table.plan.nodes.dataset
 
BatchTableEnvironment - Class in org.apache.flink.table.api
The abstract base class for batch TableEnvironments.
BatchTableEnvironment(ExecutionEnvironment, TableConfig) - Constructor for class org.apache.flink.table.api.BatchTableEnvironment
 
BatchTableEnvironment - Class in org.apache.flink.table.api.java
The TableEnvironment for a Java batch DataSet ExecutionEnvironment.
BatchTableEnvironment(ExecutionEnvironment, TableConfig) - Constructor for class org.apache.flink.table.api.java.BatchTableEnvironment
 
BatchTableEnvironment - Class in org.apache.flink.table.api.scala
The TableEnvironment for a Scala batch DataSet ExecutionEnvironment.
BatchTableEnvironment(ExecutionEnvironment, TableConfig) - Constructor for class org.apache.flink.table.api.scala.BatchTableEnvironment
 
BatchTableSink<T> - Interface in org.apache.flink.table.sinks
Defines an external TableSink to emit a batch Table.
BatchTableSource<T> - Interface in org.apache.flink.table.sources
Defines an external batch table and provides access to its data.
BatchTableSourceScan - Class in org.apache.flink.table.plan.nodes.dataset
Flink RelNode to read data from an external source defined by a BatchTableSource.
BatchTableSourceScan(RelOptCluster, RelTraitSet, RelOptTable, BatchTableSource<?>) - Constructor for class org.apache.flink.table.plan.nodes.dataset.BatchTableSourceScan
 
BatchTableSourceScanRule - Class in org.apache.flink.table.plan.rules.dataSet
 
BatchTableSourceScanRule() - Constructor for class org.apache.flink.table.plan.rules.dataSet.BatchTableSourceScanRule
 
BatchTableSourceScanRule$ - Class in org.apache.flink.table.plan.rules.dataSet
 
BatchTableSourceScanRule$() - Constructor for class org.apache.flink.table.plan.rules.dataSet.BatchTableSourceScanRule$
 
BatchTask<S extends Function,OT> - Class in org.apache.flink.runtime.operators
The base class for all batch tasks.
BatchTask() - Constructor for class org.apache.flink.runtime.operators.BatchTask
 
bcVarManager() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
bcVarManager() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
Handler for shared broadcast variables (shared between multiple Tasks)
bcVarManager() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
begin(String) - Static method in class org.apache.flink.cep.pattern.Pattern
Starts a new pattern sequence.
begin(String) - Method in class org.apache.flink.cep.scala.pattern.Pattern$
Starts a new pattern sequence.
begin(String) - Static method in class org.apache.flink.cep.scala.pattern.Pattern
Starts a new pattern sequence.
begin() - Method in class org.apache.flink.table.expressions.Substring
 
BernoulliSampler<T> - Class in org.apache.flink.api.java.sampling
A sampler implementation built upon a Bernoulli trail.
BernoulliSampler(double) - Constructor for class org.apache.flink.api.java.sampling.BernoulliSampler
Create a Bernoulli sampler with sample fraction and default random number generator.
BernoulliSampler(double, long) - Constructor for class org.apache.flink.api.java.sampling.BernoulliSampler
Create a Bernoulli sampler with sample fraction and random number generator seed.
BernoulliSampler(double, Random) - Constructor for class org.apache.flink.api.java.sampling.BernoulliSampler
Create a Bernoulli sampler with sample fraction and random number generator.
bestEffortDiscardAllStateObjects(Iterable<? extends StateObject>) - Static method in class org.apache.flink.runtime.state.StateUtil
Iterates through the passed state handles and calls discardState() on each handle that is not null.
bestEffortGetNumOfUsedBuffers() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
Returns the number of used buffers of this buffer pool.
BETWEEN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
BiFunction<T,U,R> - Interface in org.apache.flink.runtime.concurrent
Function which is called with two arguments and returns a value.
BIG_DEC_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
BIG_INT_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
BigDecComparator - Class in org.apache.flink.api.common.typeutils.base
Comparator for comparing BigDecimal values.
BigDecComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.BigDecComparator
 
BigDecParser - Class in org.apache.flink.types.parser
Parses a text field into a BigDecimal.
BigDecParser() - Constructor for class org.apache.flink.types.parser.BigDecParser
 
BigDecSerializer - Class in org.apache.flink.api.common.typeutils.base
Serializer for serializing/deserializing BigDecimal values including null values.
BigDecSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
BigIntComparator - Class in org.apache.flink.api.common.typeutils.base
Comparator for comparing BigInteger values.
BigIntComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.BigIntComparator
 
BigIntegralAvgAccumulator - Class in org.apache.flink.table.functions.aggfunctions
The initial accumulator for Big Integral Avg aggregate function
BigIntegralAvgAccumulator() - Constructor for class org.apache.flink.table.functions.aggfunctions.BigIntegralAvgAccumulator
 
BigIntegralAvgAggFunction<T> - Class in org.apache.flink.table.functions.aggfunctions
Base Class for Built-in Big Integral Avg aggregate function
BigIntegralAvgAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.BigIntegralAvgAggFunction
 
BigIntParser - Class in org.apache.flink.types.parser
Parses a text field into a BigInteger.
BigIntParser() - Constructor for class org.apache.flink.types.parser.BigIntParser
 
BigIntSerializer - Class in org.apache.flink.api.common.typeutils.base
Serializer for serializing/deserializing BigInteger values including null values.
BigIntSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
BinaryArithmetic - Class in org.apache.flink.table.expressions
 
BinaryArithmetic() - Constructor for class org.apache.flink.table.expressions.BinaryArithmetic
 
BinaryComparison - Class in org.apache.flink.table.expressions
 
BinaryComparison() - Constructor for class org.apache.flink.table.expressions.BinaryComparison
 
BinaryExpression - Class in org.apache.flink.table.expressions
 
BinaryExpression() - Constructor for class org.apache.flink.table.expressions.BinaryExpression
 
BinaryInputFormat<T> - Class in org.apache.flink.api.common.io
Base class for all input formats that use blocks of fixed size.
BinaryInputFormat() - Constructor for class org.apache.flink.api.common.io.BinaryInputFormat
 
BinaryInputFormat.BlockBasedInput - Class in org.apache.flink.api.common.io
Reads the content of a block of data.
BinaryNode - Class in org.apache.flink.table.plan.logical
 
BinaryNode() - Constructor for class org.apache.flink.table.plan.logical.BinaryNode
 
binaryOperation(AbstractInsnNode, BasicValue, BasicValue) - Method in class org.apache.flink.api.java.sca.NestedMethodAnalyzer
 
BinaryOperatorInformation<IN1,IN2,OUT> - Class in org.apache.flink.api.common.operators
A class for holding information about a single input operator, such as input/output TypeInformation.
BinaryOperatorInformation(TypeInformation<IN1>, TypeInformation<IN2>, TypeInformation<OUT>) - Constructor for class org.apache.flink.api.common.operators.BinaryOperatorInformation
 
BinaryOutputFormat<T> - Class in org.apache.flink.api.common.io
 
BinaryOutputFormat() - Constructor for class org.apache.flink.api.common.io.BinaryOutputFormat
 
BinaryOutputFormat.BlockBasedOutput - Class in org.apache.flink.api.common.io
Writes a block info at the end of the blocks.
Current implementation uses only int and not long.
BinaryPredicate - Class in org.apache.flink.table.expressions
 
BinaryPredicate() - Constructor for class org.apache.flink.table.expressions.BinaryPredicate
 
BinaryResult<T> - Interface in org.apache.flink.graph.asm.result
A GraphAlgorithm result for a pair vertices.
binarySearch(Vector<Object>, double, int, double, double, double, double, int) - Method in class org.apache.flink.ml.outlier.StochasticOutlierSelection$
Performs a binary search to get affinities in such a way that each conditional Gaussian has the same perplexity.
binarySearch(Vector<Object>, double, int, double, double, double, double, int) - Static method in class org.apache.flink.ml.outlier.StochasticOutlierSelection
Performs a binary search to get affinities in such a way that each conditional Gaussian has the same perplexity.
BinaryUnionNode - Class in org.apache.flink.optimizer.dag
The Optimizer representation of a binary Union.
BinaryUnionNode(Union<?>) - Constructor for class org.apache.flink.optimizer.dag.BinaryUnionNode
 
BinaryUnionNode.UnionSemanticProperties - Class in org.apache.flink.optimizer.dag
 
BinaryUnionOpDescriptor - Class in org.apache.flink.optimizer.operators
 
BinaryUnionOpDescriptor() - Constructor for class org.apache.flink.optimizer.operators.BinaryUnionOpDescriptor
 
BinaryUnionPlanNode - Class in org.apache.flink.optimizer.plan
A special subclass for the union to make it identifiable.
BinaryUnionPlanNode(BinaryUnionNode, Channel, Channel) - Constructor for class org.apache.flink.optimizer.plan.BinaryUnionPlanNode
 
BinaryUnionPlanNode(BinaryUnionPlanNode) - Constructor for class org.apache.flink.optimizer.plan.BinaryUnionPlanNode
 
BinaryUnionReplacer - Class in org.apache.flink.optimizer.traversals
A traversal that collects cascading binary unions into a single n-ary union operator.
BinaryUnionReplacer() - Constructor for class org.apache.flink.optimizer.traversals.BinaryUnionReplacer
 
bind(StateBinder) - Method in class org.apache.flink.api.common.state.AggregatingStateDescriptor
 
bind(StateBinder) - Method in class org.apache.flink.api.common.state.FoldingStateDescriptor
Deprecated.
 
bind(StateBinder) - Method in class org.apache.flink.api.common.state.ListStateDescriptor
 
bind(StateBinder) - Method in class org.apache.flink.api.common.state.MapStateDescriptor
 
bind(StateBinder) - Method in class org.apache.flink.api.common.state.ReducingStateDescriptor
 
bind(StateBinder) - Method in class org.apache.flink.api.common.state.StateDescriptor
Creates a new State on the given StateBinder.
bind(StateBinder) - Method in class org.apache.flink.api.common.state.ValueStateDescriptor
 
bind(StateBinder) - Method in class org.apache.flink.migration.api.common.state.ListStateDescriptor
Deprecated.
 
bindVariables(String[], String[]) - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
 
BipartiteEdge<KT,KB,EV> - Class in org.apache.flink.graph.bipartite
A BipartiteEdge represents a link between top and bottom vertices in a BipartiteGraph.
BipartiteEdge() - Constructor for class org.apache.flink.graph.bipartite.BipartiteEdge
 
BipartiteEdge(KT, KB, EV) - Constructor for class org.apache.flink.graph.bipartite.BipartiteEdge
 
BipartiteGraph<KT,KB,VVT,VVB,EV> - Class in org.apache.flink.graph.bipartite
The vertices of a bipartite graph are divided into two disjoint sets, referenced by the names "top" and "bottom".
bitMix(int) - Static method in class org.apache.flink.util.MathUtils
Bit-mixing for pseudo-randomization of integers (e.g., to guard against bad hash functions).
BitSet - Class in org.apache.flink.runtime.operators.util
 
BitSet(int) - Constructor for class org.apache.flink.runtime.operators.util.BitSet
 
bitSet - Variable in class org.apache.flink.runtime.operators.util.BloomFilter
 
BitSet(int) - Constructor for class org.apache.flink.runtime.operators.util.BloomFilter.BitSet
 
bitSize() - Method in class org.apache.flink.runtime.operators.util.BitSet
Number of bits
bitSize() - Method in class org.apache.flink.runtime.operators.util.BloomFilter.BitSet
Number of bits
Blackboard(SqlValidatorScope, Map<String, RexNode>, boolean) - Constructor for class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
Creates a Blackboard.
BLAS - Class in org.apache.flink.ml.math
BLAS routines for vectors and matrices.
BLAS() - Constructor for class org.apache.flink.ml.math.BLAS
 
BLAS$ - Class in org.apache.flink.ml.math
BLAS routines for vectors and matrices.
BLAS$() - Constructor for class org.apache.flink.ml.math.BLAS$
 
BLOB_FETCH_BACKLOG_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
The config parameter defining the backlog of BLOB fetches on the JobManager
BLOB_FETCH_CONCURRENT_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
The config parameter defining the maximum number of concurrent BLOB fetches that the JobManager serves.
BLOB_FETCH_RETRIES_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
The config parameter defining number of retires for failed BLOB fetches.
BLOB_SERVER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
The config parameter defining the server port of the blob service.
BLOB_SERVICE_SSL_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
Flag to override ssl support for the blob service transport
BLOB_STORAGE_DIRECTORY_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
The config parameter defining the storage directory to be used by the blob server.
BlobCache - Class in org.apache.flink.runtime.blob
The BLOB cache implements a local cache for content-addressable BLOBs.
BlobCache(InetSocketAddress, Configuration, BlobView) - Constructor for class org.apache.flink.runtime.blob.BlobCache
Instantiates a new BLOB cache.
BlobClient - Class in org.apache.flink.runtime.blob
The BLOB client can communicate with the BLOB server and either upload (PUT), download (GET), or delete (DELETE) BLOBs.
BlobClient(InetSocketAddress, Configuration) - Constructor for class org.apache.flink.runtime.blob.BlobClient
Instantiates a new BLOB client.
BlobKey - Class in org.apache.flink.runtime.blob
A BLOB key uniquely identifies a BLOB.
BlobKey() - Constructor for class org.apache.flink.runtime.blob.BlobKey
Constructs a new BLOB key.
BlobLibraryCacheManager - Class in org.apache.flink.runtime.execution.librarycache
For each job graph that is submitted to the system the library cache manager maintains a set of libraries (typically JAR files) which the job requires to run.
BlobLibraryCacheManager(BlobService, long) - Constructor for class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
 
blobManagerPort() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.ClassloadingProps
 
blobPort() - Method in class org.apache.flink.runtime.messages.RegistrationMessages.AcknowledgeRegistration
 
blobPort() - Method in class org.apache.flink.runtime.messages.RegistrationMessages.AlreadyRegistered
 
BlobServer - Class in org.apache.flink.runtime.blob
This class implements the BLOB server.
BlobServer(Configuration, BlobStore) - Constructor for class org.apache.flink.runtime.blob.BlobServer
Instantiates a new BLOB server and binds it to a free network port.
BlobServerProtocol - Class in org.apache.flink.runtime.blob
 
BlobService - Interface in org.apache.flink.runtime.blob
A simple store and retrieve binary large objects (BLOBs).
BlobStore - Interface in org.apache.flink.runtime.blob
A blob store.
BlobStoreService - Interface in org.apache.flink.runtime.blob
Service interface for the BlobStore which allows to close and clean up its data.
blobStoreService - Variable in class org.apache.flink.yarn.highavailability.YarnHighAvailabilityServices
Blob store service to be used for the BlobServer and BlobCache
BlobUtils - Class in org.apache.flink.runtime.blob
Utility class to work with blob data.
BlobView - Interface in org.apache.flink.runtime.blob
View on blobs stored in a BlobStore.
Block<T> - Class in org.apache.flink.ml.common
Base class for blocks of elements.
Block(int, Vector<T>) - Constructor for class org.apache.flink.ml.common.Block
 
block(DataSet<T>, int, Option<Partitioner<Object>>, TypeInformation<T>, ClassTag<T>) - Method in class org.apache.flink.ml.common.FlinkMLTools$
Groups the DataSet input into numBlocks blocks.
block(DataSet<T>, int, Option<Partitioner<Object>>, TypeInformation<T>, ClassTag<T>) - Static method in class org.apache.flink.ml.common.FlinkMLTools
Groups the DataSet input into numBlocks blocks.
Block$ - Class in org.apache.flink.ml.common
 
Block$() - Constructor for class org.apache.flink.ml.common.Block$
 
BLOCK_SIZE_PARAMETER_KEY - Static variable in class org.apache.flink.api.common.io.BinaryInputFormat
The config parameter which defines the fixed length of a record.
BLOCK_SIZE_PARAMETER_KEY - Static variable in class org.apache.flink.api.common.io.BinaryOutputFormat
The config parameter which defines the fixed length of a record.
BlockBasedInput(FSDataInputStream, int) - Constructor for class org.apache.flink.api.common.io.BinaryInputFormat.BlockBasedInput
 
BlockBasedInput(FSDataInputStream, int, long) - Constructor for class org.apache.flink.api.common.io.BinaryInputFormat.BlockBasedInput
 
BlockBasedOutput(OutputStream, int) - Constructor for class org.apache.flink.api.common.io.BinaryOutputFormat.BlockBasedOutput
 
BlockChannelReader<T> - Interface in org.apache.flink.runtime.io.disk.iomanager
A reader that reads data in blocks from a file channel.
BlockChannelWriter<T> - Interface in org.apache.flink.runtime.io.disk.iomanager
A writer that writes data in blocks to a file channel.
BlockChannelWriterWithCallback<T> - Interface in org.apache.flink.runtime.io.disk.iomanager
 
BlockedFactorization(DataSet<Tuple2<Object, double[][]>>, DataSet<Tuple2<Object, double[][]>>) - Constructor for class org.apache.flink.ml.recommendation.ALS.BlockedFactorization
 
BlockedFactorization$() - Constructor for class org.apache.flink.ml.recommendation.ALS.BlockedFactorization$
 
blockForeverNonInterruptibly() - Static method in class org.apache.flink.core.testutils.CommonTestUtils
Permanently blocks the current thread.
blockHeadCopy - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
BlockIDGenerator(int) - Constructor for class org.apache.flink.ml.recommendation.ALS.BlockIDGenerator
 
BlockIDPartitioner() - Constructor for class org.apache.flink.ml.recommendation.ALS.BlockIDPartitioner
 
BlockInfo - Class in org.apache.flink.api.common.io
A block of 24 bytes written at the end of a block in a binary file, and containing i) the number of records in the block, ii) the accumulated number of records, and iii) the offset of the first record in the block.
BlockInfo() - Constructor for class org.apache.flink.api.common.io.BlockInfo
 
BlockInfo<T extends org.apache.commons.math3.random.RandomGenerator> - Class in org.apache.flink.graph.generator.random
Defines a source of randomness and a unit of work.
BlockInfo(RandomGenerable<T>, int, int, long, long) - Constructor for class org.apache.flink.graph.generator.random.BlockInfo
 
BlockingBackChannel - Class in org.apache.flink.runtime.iterative.concurrent
A concurrent datastructure that establishes a backchannel buffer between an iteration head and an iteration tail.
BlockingBackChannel(SerializedUpdateBuffer) - Constructor for class org.apache.flink.runtime.iterative.concurrent.BlockingBackChannel
 
BlockingBackChannelBroker - Class in org.apache.flink.runtime.iterative.concurrent
Singleton class for the threadsafe handover of BlockingBackChannels from iteration heads to iteration tails
BlockingQueueBroker - Class in org.apache.flink.streaming.runtime.io
Broker for the BlockingQueue used in StreamIterationHead and StreamIterationTail for implementing feedback streams.
BlockLocation - Interface in org.apache.flink.core.fs
A BlockLocation lists hosts, offset and length of block.
BlockRating(Tuple2<int[], double[]>[]) - Constructor for class org.apache.flink.ml.recommendation.ALS.BlockRating
 
BlockRating$() - Constructor for class org.apache.flink.ml.recommendation.ALS.BlockRating$
 
BlockResettableMutableObjectIterator<T> - Class in org.apache.flink.runtime.operators.resettable
Implementation of an iterator that fetches a block of data into main memory and offers resettable access to the data in that block.
BlockResettableMutableObjectIterator(MemoryManager, MutableObjectIterator<T>, TypeSerializer<T>, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.resettable.BlockResettableMutableObjectIterator
 
Blocks$() - Constructor for class org.apache.flink.ml.classification.SVM.Blocks$
 
Blocks$() - Constructor for class org.apache.flink.ml.nn.KNN.Blocks$
 
Blocks$() - Constructor for class org.apache.flink.ml.recommendation.ALS.Blocks$
 
BloomFilter - Class in org.apache.flink.runtime.operators.util
BloomFilter is a probabilistic data structure for set membership check.
BloomFilter(int, int) - Constructor for class org.apache.flink.runtime.operators.util.BloomFilter
 
BloomFilter.BitSet - Class in org.apache.flink.runtime.operators.util
Bare metal bit set implementation.
body - Variable in class org.apache.flink.examples.java.misc.CollectionExecutionExample.EMail
 
bolt - Variable in class org.apache.flink.storm.wrappers.BoltWrapper
The wrapped Storm bolt.
BoltCounter - Class in org.apache.flink.storm.wordcount.operators
Implements the word counter that counts the occurrence of each unique word.
BoltCounter() - Constructor for class org.apache.flink.storm.wordcount.operators.BoltCounter
 
BoltCounterByName - Class in org.apache.flink.storm.wordcount.operators
Implements the word counter that counts the occurrence of each unique word.
BoltCounterByName() - Constructor for class org.apache.flink.storm.wordcount.operators.BoltCounterByName
 
BoltFileSink - Class in org.apache.flink.storm.util
Implements a sink that write the received data to the given file (as a result of Object.toString() for each attribute).
BoltFileSink(String) - Constructor for class org.apache.flink.storm.util.BoltFileSink
 
BoltFileSink(String, OutputFormatter) - Constructor for class org.apache.flink.storm.util.BoltFileSink
 
BoltPrintSink - Class in org.apache.flink.storm.util
Implements a sink that prints the received data to stdout.
BoltPrintSink(OutputFormatter) - Constructor for class org.apache.flink.storm.util.BoltPrintSink
 
BoltTokenizer - Class in org.apache.flink.storm.wordcount.operators
Implements the string tokenizer that splits sentences into words as a bolt.
BoltTokenizer() - Constructor for class org.apache.flink.storm.wordcount.operators.BoltTokenizer
 
BoltTokenizerByName - Class in org.apache.flink.storm.wordcount.operators
Implements the string tokenizer that splits sentences into words as a bolt.
BoltTokenizerByName() - Constructor for class org.apache.flink.storm.wordcount.operators.BoltTokenizerByName
 
BoltTokenizerWordCount - Class in org.apache.flink.storm.wordcount
Implements the "WordCount" program that computes a simple word occurrence histogram over text files in a streaming fashion.
BoltTokenizerWordCount() - Constructor for class org.apache.flink.storm.wordcount.BoltTokenizerWordCount
 
BoltTokenizerWordCountPojo - Class in org.apache.flink.storm.wordcount
Implements the "WordCount" program that computes a simple word occurrence histogram over text files in a streaming fashion.
BoltTokenizerWordCountPojo() - Constructor for class org.apache.flink.storm.wordcount.BoltTokenizerWordCountPojo
 
BoltTokenizerWordCountWithNames - Class in org.apache.flink.storm.wordcount
Implements the "WordCount" program that computes a simple word occurrence histogram over text files in a streaming fashion.
BoltTokenizerWordCountWithNames() - Constructor for class org.apache.flink.storm.wordcount.BoltTokenizerWordCountWithNames
 
BoltWrapper<IN,OUT> - Class in org.apache.flink.storm.wrappers
A BoltWrapper wraps an IRichBolt in order to execute the Storm bolt within a Flink Streaming program.
BoltWrapper(IRichBolt) - Constructor for class org.apache.flink.storm.wrappers.BoltWrapper
Instantiates a new BoltWrapper that wraps the given Storm bolt such that it can be used within a Flink streaming program.
BoltWrapper(IRichBolt, Fields) - Constructor for class org.apache.flink.storm.wrappers.BoltWrapper
Instantiates a new BoltWrapper that wraps the given Storm bolt such that it can be used within a Flink streaming program.
BoltWrapper(IRichBolt, String[]) - Constructor for class org.apache.flink.storm.wrappers.BoltWrapper
Instantiates a new BoltWrapper that wraps the given Storm bolt such that it can be used within a Flink streaming program.
BoltWrapper(IRichBolt, Collection<String>) - Constructor for class org.apache.flink.storm.wrappers.BoltWrapper
Instantiates a new BoltWrapper that wraps the given Storm bolt such that it can be used within a Flink streaming program.
BoltWrapper(IRichBolt, Fields, String[]) - Constructor for class org.apache.flink.storm.wrappers.BoltWrapper
Instantiates a new BoltWrapper that wraps the given Storm bolt such that it can be used within a Flink streaming program.
BoltWrapper(IRichBolt, Fields, Collection<String>) - Constructor for class org.apache.flink.storm.wrappers.BoltWrapper
Instantiates a new BoltWrapper that wraps the given Storm bolt such that it can be used within a Flink streaming program.
BoltWrapper(IRichBolt, String, String, String, Fields, Collection<String>) - Constructor for class org.apache.flink.storm.wrappers.BoltWrapper
Instantiates a new BoltWrapper that wraps the given Storm bolt such that it can be used within a Flink streaming program.
BOOLEAN - Static variable in class org.apache.flink.api.common.typeinfo.Types
 
BOOLEAN() - Method in class org.apache.flink.table.api.Types$
 
BOOLEAN() - Static method in class org.apache.flink.table.api.Types
 
BOOLEAN() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
BOOLEAN() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
boolean2Literal(boolean) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionConversions
 
BOOLEAN_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
BOOLEAN_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
BOOLEAN_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
BOOLEAN_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
BooleanColumnSummary - Class in org.apache.flink.api.java.summarize
Summary for a column of booleans
BooleanColumnSummary(long, long, long) - Constructor for class org.apache.flink.api.java.summarize.BooleanColumnSummary
 
BooleanComparator - Class in org.apache.flink.api.common.typeutils.base
 
BooleanComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.BooleanComparator
 
BooleanConditions - Class in org.apache.flink.cep.pattern.conditions
Utility class containing an IterativeCondition that always returns true and one that always returns false.
BooleanConditions() - Constructor for class org.apache.flink.cep.pattern.conditions.BooleanConditions
 
BooleanExplodeTableFunc - Class in org.apache.flink.table.plan.util
 
BooleanExplodeTableFunc() - Constructor for class org.apache.flink.table.plan.util.BooleanExplodeTableFunc
 
BooleanMaxAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Boolean Max aggregate function
BooleanMaxAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.BooleanMaxAggFunction
 
BooleanMaxWithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Boolean Max with retraction aggregate function
BooleanMaxWithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.BooleanMaxWithRetractAggFunction
 
BooleanMinAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Boolean Min aggregate function
BooleanMinAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.BooleanMinAggFunction
 
BooleanMinWithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Boolean Min with retraction aggregate function
BooleanMinWithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.BooleanMinWithRetractAggFunction
 
BooleanParameter - Class in org.apache.flink.graph.drivers.parameter
A Parameter storing a Boolean.
BooleanParameter(ParameterizedBase, String) - Constructor for class org.apache.flink.graph.drivers.parameter.BooleanParameter
Set the parameter name and add this parameter to the list of parameters stored by owner.
BooleanParser - Class in org.apache.flink.types.parser
 
BooleanParser() - Constructor for class org.apache.flink.types.parser.BooleanParser
 
BooleanPrimitiveArrayComparator - Class in org.apache.flink.api.common.typeutils.base.array
 
BooleanPrimitiveArrayComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArrayComparator
 
BooleanPrimitiveArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
A serializer for boolean arrays.
BooleanPrimitiveArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
BooleanSerializer - Class in org.apache.flink.api.common.typeutils.base
 
BooleanSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
BooleanSerializer() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.BooleanSerializer
 
BooleanSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
 
BooleanSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.BooleanSummaryAggregator
 
BooleanValue - Class in org.apache.flink.types
Boxed serializable and comparable boolean type, representing the primitive type boolean.
BooleanValue() - Constructor for class org.apache.flink.types.BooleanValue
 
BooleanValue(boolean) - Constructor for class org.apache.flink.types.BooleanValue
 
BooleanValueComparator - Class in org.apache.flink.api.common.typeutils.base
Specialized comparator for BooleanValue based on CopyableValueComparator.
BooleanValueComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
BooleanValueParser - Class in org.apache.flink.types.parser
 
BooleanValueParser() - Constructor for class org.apache.flink.types.parser.BooleanValueParser
 
BooleanValueSerializer - Class in org.apache.flink.api.common.typeutils.base
 
BooleanValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
BooleanValueSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.BooleanValueSummaryAggregator
 
boolLiteral() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
boolLiteral() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
bootstrapCommand() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
Get the bootstrap command.
BootstrapTools - Class in org.apache.flink.runtime.clusterframework
Tools for starting JobManager and TaskManager processes, including the Actor Systems used to run the JobManager and TaskManager actors.
BOTH() - Method in class org.apache.flink.table.expressions.TrimMode$
 
BOTH() - Static method in class org.apache.flink.table.expressions.TrimMode
 
Bottou(double) - Constructor for class org.apache.flink.ml.optimization.LearningRateMethod.Bottou
 
Bottou$() - Constructor for class org.apache.flink.ml.optimization.LearningRateMethod.Bottou$
 
BoundedInputStream - Class in org.apache.flink.runtime.state
Wrapper around a FSDataInputStream to limit the maximum read offset.
BoundedInputStream(FSDataInputStream, long) - Constructor for class org.apache.flink.runtime.state.BoundedInputStream
 
BoundedOutOfOrdernessTimestampExtractor<T> - Class in org.apache.flink.streaming.api.functions.timestamps
This is a AssignerWithPeriodicWatermarks used to emit Watermarks that lag behind the element with the maximum timestamp (in event time) seen so far by a fixed amount of time, t_late.
BoundedOutOfOrdernessTimestampExtractor(Time) - Constructor for class org.apache.flink.streaming.api.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor
 
BoundingBox - Class in org.apache.flink.contrib.tweetinputformat.model.places
A series of longitude and latitude points, defining a box which will contain the Place entity this bounding box is related to.
BoundingBox() - Constructor for class org.apache.flink.contrib.tweetinputformat.model.places.BoundingBox
 
BoundingBox(List<double[]>) - Constructor for class org.apache.flink.contrib.tweetinputformat.model.places.BoundingBox
 
box() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.BoxedPrimitiveDescriptor
 
BoxedPrimitiveDescriptor(int, scala.reflect.macros.Context.universe, scala.reflect.macros.Context.universe, scala.reflect.macros.Context.universe, Function1<Universe.TreeContextApi, Universe.TreeContextApi>, Function1<Universe.TreeContextApi, Universe.TreeContextApi>) - Constructor for class org.apache.flink.api.scala.codegen.TypeDescriptors.BoxedPrimitiveDescriptor
 
boxedPrimitives() - Method in interface org.apache.flink.api.scala.codegen.TypeAnalyzer
 
boxedTypeTermForTypeInfo(TypeInformation<?>) - Method in class org.apache.flink.table.codegen.CodeGenUtils$
 
boxedTypeTermForTypeInfo(TypeInformation<?>) - Static method in class org.apache.flink.table.codegen.CodeGenUtils
 
BranchesVisitor - Class in org.apache.flink.optimizer.traversals
This traversal of the optimizer DAG computes the information needed to track branches and joins in the data flow.
BranchesVisitor() - Constructor for class org.apache.flink.optimizer.traversals.BranchesVisitor
 
branchingNode - Variable in class org.apache.flink.optimizer.dag.OptimizerNode.UnclosedBranchDescriptor
 
branchPlan - Variable in class org.apache.flink.optimizer.plan.PlanNode
 
breaksPipeline() - Method in enum org.apache.flink.optimizer.dag.TempMode
 
Breeze - Class in org.apache.flink.ml.math
This class contains convenience function to wrap a matrix/vector into a breeze matrix/vector and to unwrap it again.
Breeze() - Constructor for class org.apache.flink.ml.math.Breeze
 
Breeze$ - Class in org.apache.flink.ml.math
This class contains convenience function to wrap a matrix/vector into a breeze matrix/vector and to unwrap it again.
Breeze$() - Constructor for class org.apache.flink.ml.math.Breeze$
 
Breeze.Breeze2MatrixConverter - Class in org.apache.flink.ml.math
 
Breeze.Breeze2VectorConverter - Class in org.apache.flink.ml.math
 
Breeze.BreezeArrayConverter<T> - Class in org.apache.flink.ml.math
 
Breeze.Matrix2BreezeConverter - Class in org.apache.flink.ml.math
 
Breeze.Vector2BreezeConverter - Class in org.apache.flink.ml.math
 
Breeze2MatrixConverter(Matrix<Object>) - Constructor for class org.apache.flink.ml.math.Breeze.Breeze2MatrixConverter
 
Breeze2VectorConverter(Vector<Object>) - Constructor for class org.apache.flink.ml.math.Breeze.Breeze2VectorConverter
 
BreezeArrayConverter(Object) - Constructor for class org.apache.flink.ml.math.Breeze.BreezeArrayConverter
 
BreezeLabeledVector(int, Vector<Object>) - Constructor for class org.apache.flink.ml.outlier.StochasticOutlierSelection.BreezeLabeledVector
 
BreezeLabeledVector$() - Constructor for class org.apache.flink.ml.outlier.StochasticOutlierSelection.BreezeLabeledVector$
 
BreezeVectorConverter<T extends Vector> - Interface in org.apache.flink.ml.math
Type class which allows the conversion from Breeze vectors to Flink vectors
broadcast() - Method in class org.apache.flink.streaming.api.datastream.DataStream
Sets the partitioning of the DataStream so that the output elements are broadcasted to every parallel instance of the next operation.
broadcast() - Method in class org.apache.flink.streaming.api.scala.DataStream
Sets the partitioning of the DataStream so that the output tuples are broad casted to every parallel instance of the next component.
broadcastCheckpointBarrier(long, long, CheckpointOptions) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
 
broadcastCheckpointCancelMarker(long) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
 
broadcastEmit(T) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
This is used to broadcast Streaming Watermarks in-band with records.
broadcastEmit(T) - Method in class org.apache.flink.streaming.runtime.io.StreamRecordWriter
 
broadcastEvent(AbstractEvent) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
 
broadcastEvent(AbstractEvent) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
broadcastInputReaders - Variable in class org.apache.flink.runtime.operators.BatchTask
The input readers for the configured broadcast variables for this task.
broadcastInputs - Variable in class org.apache.flink.api.common.operators.AbstractUdfOperator
The extra inputs which parameterize the user function.
broadcastInputSerializers - Variable in class org.apache.flink.runtime.operators.BatchTask
The serializers for the broadcast input data types.
BroadcastPartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
Partitioner that selects all the output channels.
BroadcastPartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
 
broadcastSet() - Method in class org.apache.flink.table.runtime.MapSideJoinRunner
 
BroadcastVariableInitializer<T,O> - Interface in org.apache.flink.api.common.functions
A broadcast variable initializer can be used to transform a broadcast variable into another format during initialization.
BroadcastVariableKey - Class in org.apache.flink.runtime.broadcast
 
BroadcastVariableKey(JobVertexID, String, int) - Constructor for class org.apache.flink.runtime.broadcast.BroadcastVariableKey
 
BroadcastVariableManager - Class in org.apache.flink.runtime.broadcast
 
BroadcastVariableManager() - Constructor for class org.apache.flink.runtime.broadcast.BroadcastVariableManager
 
BroadcastVariableMaterialization<T,C> - Class in org.apache.flink.runtime.broadcast
 
BroadcastVariableMaterialization(BroadcastVariableKey) - Constructor for class org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization
 
Broker<V> - Class in org.apache.flink.runtime.iterative.concurrent
A concurrent data structure that allows the hand-over of an object between a pair of threads
Broker() - Constructor for class org.apache.flink.runtime.iterative.concurrent.Broker
 
brokerKey() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
Bucketer - Interface in org.apache.flink.streaming.connectors.fs
Deprecated.
use Bucketer instead.
Bucketer<T> - Interface in org.apache.flink.streaming.connectors.fs.bucketing
A bucketer is used with a BucketingSink to put emitted elements into rolling files.
BucketingSink<T> - Class in org.apache.flink.streaming.connectors.fs.bucketing
Sink that emits its input elements to FileSystem files within buckets.
BucketingSink(String) - Constructor for class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
Creates a new BucketingSink that writes files to the given base directory.
buckets - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
The array of memory segments that contain the buckets which form the actual hash-table of hash-codes and pointers to the elements.
bucketsPerSegmentBits - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
The number of bits that describe the position of a bucket in a memory segment.
bucketsPerSegmentMask - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
The number of hash table buckets in a single memory segment - 1.
BucketState() - Constructor for class org.apache.flink.streaming.connectors.fs.RollingSink.BucketState
Deprecated.
 
buffer - Variable in class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
 
buffer - Variable in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
buffer - Variable in class org.apache.flink.python.api.streaming.data.PythonSender.Serializer
 
Buffer - Class in org.apache.flink.runtime.io.network.buffer
Wrapper for pooled MemorySegment instances.
Buffer(MemorySegment, BufferRecycler) - Constructor for class org.apache.flink.runtime.io.network.buffer.Buffer
 
Buffer(MemorySegment, BufferRecycler, boolean) - Constructor for class org.apache.flink.runtime.io.network.buffer.Buffer
 
buffer() - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
 
buffer(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
 
buffer(int, int) - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
 
buffer() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel.BufferAndAvailability
 
buffer - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
buffer - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
BufferAndAvailability(Buffer, boolean) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.InputChannel.BufferAndAvailability
 
BufferAvailabilityListener - Interface in org.apache.flink.runtime.io.network.partition
Listener interface implemented by consumers of ResultSubpartitionView that want to be notified of availability of further buffers.
bufferedReader() - Method in class org.apache.flink.api.scala.FlinkShell$
Buffered reader to substitute input in test
bufferedReader() - Static method in class org.apache.flink.api.scala.FlinkShell
Buffered reader to substitute input in test
BufferFileReader - Interface in org.apache.flink.runtime.io.disk.iomanager
 
BufferFileSegmentReader - Interface in org.apache.flink.runtime.io.disk.iomanager
 
BufferFileWriter - Interface in org.apache.flink.runtime.io.disk.iomanager
 
BufferOrEvent - Class in org.apache.flink.runtime.io.network.partition.consumer
Either type for Buffer or AbstractEvent instances tagged with the channel index, from which they were received.
BufferOrEvent(Buffer, int) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
BufferOrEvent(AbstractEvent, int) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
BufferPool - Interface in org.apache.flink.runtime.io.network.buffer
A dynamically sized buffer pool.
BufferPoolFactory - Interface in org.apache.flink.runtime.io.network.buffer
A factory for buffer pools.
BufferPoolOwner - Interface in org.apache.flink.runtime.io.network.buffer
 
BufferProvider - Interface in org.apache.flink.runtime.io.network.buffer
A buffer provider to request buffers from in a synchronous or asynchronous fashion.
BufferRecycler - Interface in org.apache.flink.runtime.io.network.buffer
 
BufferSpiller - Class in org.apache.flink.streaming.runtime.io
The buffer spiller takes the buffers and events from a data stream and adds them to a spill file.
BufferSpiller(IOManager, int) - Constructor for class org.apache.flink.streaming.runtime.io.BufferSpiller
Creates a new buffer spiller, spilling to one of the I/O manager's temp directories.
BufferSpiller.SpilledBufferOrEventSequence - Class in org.apache.flink.streaming.runtime.io
This class represents a sequence of spilled buffers and events, created by the BufferSpiller.
bufferTimeout - Variable in class org.apache.flink.streaming.api.transformations.StreamTransformation
 
build() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple0Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple10Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple11Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple12Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple13Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple14Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple15Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple16Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple17Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple18Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple19Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple1Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple20Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple21Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple22Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple23Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple24Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple25Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple2Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple3Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple4Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple5Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple6Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple7Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple8Builder
 
build() - Method in class org.apache.flink.api.java.tuple.builder.Tuple9Builder
 
build() - Method in interface org.apache.flink.mesos.scheduler.TaskSchedulerBuilder
Build a Fenzo task scheduler.
build(List<Object>) - Method in interface org.apache.flink.ml.math.VectorBuilder
Builds a Vector of type T from a List[Double]
build() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
build() - Method in class org.apache.flink.runtime.clusterframework.overlays.FlinkDistributionOverlay.Builder
 
build() - Method in class org.apache.flink.runtime.clusterframework.overlays.HadoopConfOverlay.Builder
 
build() - Method in class org.apache.flink.runtime.clusterframework.overlays.HadoopUserOverlay.Builder
 
build() - Method in class org.apache.flink.runtime.clusterframework.overlays.KeytabOverlay.Builder
 
build() - Method in class org.apache.flink.runtime.clusterframework.overlays.Krb5ConfOverlay.Builder
 
build() - Method in class org.apache.flink.runtime.clusterframework.overlays.SSLStoreOverlay.Builder
 
build() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraPojoSinkBuilder
 
build() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
Finalizes the configuration of this sink.
build() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraTupleSinkBuilder
 
build() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
The Builder method If URI is NULL we use host, port, vHost, username, password combination to initialize connection.
build() - Method in class org.apache.flink.table.calcite.CalciteConfigBuilder
Builds a new CalciteConfig.
build() - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
build() - Method in class org.apache.flink.table.sources.CsvTableSource.Builder
Apply the current values and constructs a newly-created CsvTableSource.
buildBloomFilterForBucketsInPartition(int, HashPartition<BT, PT>) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
buildBulkProcessor(BulkProcessor.Listener) - Method in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase
Build the BulkProcessor.
buildCluster(Cluster.Builder) - Method in class org.apache.flink.streaming.connectors.cassandra.ClusterBuilder
Configures the connection to Cassandra.
Builder() - Constructor for class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
Builder() - Constructor for class org.apache.flink.runtime.clusterframework.overlays.FlinkDistributionOverlay.Builder
 
Builder() - Constructor for class org.apache.flink.runtime.clusterframework.overlays.HadoopConfOverlay.Builder
 
Builder() - Constructor for class org.apache.flink.runtime.clusterframework.overlays.HadoopUserOverlay.Builder
 
Builder() - Constructor for class org.apache.flink.runtime.clusterframework.overlays.KeytabOverlay.Builder
 
Builder() - Constructor for class org.apache.flink.runtime.clusterframework.overlays.Krb5ConfOverlay.Builder
 
Builder() - Constructor for class org.apache.flink.runtime.clusterframework.overlays.SSLStoreOverlay.Builder
 
builder - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
 
Builder() - Constructor for class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
 
builder() - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
builder() - Method in class org.apache.flink.table.sources.CsvTableSource$
Return a new builder that builds a CsvTableSource.
builder() - Static method in class org.apache.flink.table.sources.CsvTableSource
Return a new builder that builds a CsvTableSource.
Builder() - Constructor for class org.apache.flink.table.sources.CsvTableSource.Builder
 
BuildFirstCachedJoinDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
 
BuildFirstCachedJoinDriver() - Constructor for class org.apache.flink.runtime.operators.BuildFirstCachedJoinDriver
 
buildFlinkTuple(T, HCatRecord) - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
 
buildFlinkTuple(T, HCatRecord) - Method in class org.apache.flink.hcatalog.java.HCatInputFormat
 
buildFlinkTuple(T, HCatRecord) - Method in class org.apache.flink.hcatalog.scala.HCatInputFormat
 
buildGraph(ExecutionGraph, JobGraph, Configuration, ScheduledExecutorService, Executor, SlotProvider, ClassLoader, CheckpointRecoveryFactory, Time, RestartStrategy, MetricGroup, int, Logger) - Static method in class org.apache.flink.runtime.executiongraph.ExecutionGraphBuilder
Builds the ExecutionGraph from the JobGraph.
buildInitialTable(MutableObjectIterator<BT>) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
Creates the initial hash table.
buildJDBCInputFormat() - Static method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat
A builder used to set parameters to the output format's configuration in a fluent way.
buildJDBCOutputFormat() - Static method in class org.apache.flink.api.java.io.jdbc.JDBCOutputFormat
 
buildLogicalRowType(Seq<String>, Seq<TypeInformation<?>>, Option<Tuple2<Object, String>>, Option<Tuple2<Object, String>>) - Method in class org.apache.flink.table.calcite.FlinkTypeFactory
Creates a struct type with the input fieldNames and input fieldTypes using FlinkTypeFactory
BuildOutgoingEdgeList() - Constructor for class org.apache.flink.examples.java.graph.PageRank.BuildOutgoingEdgeList
 
buildPartialModel(Iterable<Integer>) - Method in class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.PartialModelBuilder
 
buildProgram(ProgramOptions) - Method in class org.apache.flink.client.CliFrontend
Creates a Packaged program from the given command line options.
BuildSecondCachedJoinDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
 
BuildSecondCachedJoinDriver() - Constructor for class org.apache.flink.runtime.operators.BuildSecondCachedJoinDriver
 
buildSideComparator - Variable in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
The utilities to hash and compare the build side data types.
buildSideComparator - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
The utilities to hash and compare the build side data types.
buildSideSerializer - Variable in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
The utilities to serialize the build side data types.
buildSideSerializer - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
The utilities to serialize the build side data types.
buildTableFromSpilledPartition(HashPartition<BT, PT>) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
buildTableWithUniqueKey(MutableObjectIterator<T>) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
 
buildTopology() - Static method in class org.apache.flink.storm.exclamation.ExclamationTopology
 
buildTopology() - Static method in class org.apache.flink.storm.wordcount.WordCountTopology
 
buildTopology(boolean) - Static method in class org.apache.flink.storm.wordcount.WordCountTopology
 
buildUserCodeClassLoader(List<URL>, List<URL>, ClassLoader) - Static method in class org.apache.flink.client.program.JobWithJars
 
buildVolumes(Option<String>) - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
Used to build volume specs for mesos.
builtInFunctions() - Method in class org.apache.flink.table.validate.FunctionCatalog$
 
builtInFunctions() - Static method in class org.apache.flink.table.validate.FunctionCatalog
 
BuiltInMethods - Class in org.apache.flink.table.codegen.calls
 
BuiltInMethods() - Constructor for class org.apache.flink.table.codegen.calls.BuiltInMethods
 
BuiltInMethods$ - Class in org.apache.flink.table.codegen.calls
 
BuiltInMethods$() - Constructor for class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
BulkBlockChannelReader - Interface in org.apache.flink.runtime.io.disk.iomanager
 
BulkFlushBackoffPolicy() - Constructor for class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase.BulkFlushBackoffPolicy
 
BulkIterationBase<T> - Class in org.apache.flink.api.common.operators.base
 
BulkIterationBase(UnaryOperatorInformation<T, T>) - Constructor for class org.apache.flink.api.common.operators.base.BulkIterationBase
 
BulkIterationBase(UnaryOperatorInformation<T, T>, String) - Constructor for class org.apache.flink.api.common.operators.base.BulkIterationBase
 
BulkIterationBase.PartialSolutionPlaceHolder<OT> - Class in org.apache.flink.api.common.operators.base
Specialized operator to use as a recognizable place-holder for the input to the step function when composing the nested data flow.
BulkIterationBase.TerminationCriterionAggregationConvergence - Class in org.apache.flink.api.common.operators.base
Convergence for the termination criterion is reached if no tuple is output at current iteration for the termination criterion branch
BulkIterationBase.TerminationCriterionAggregator - Class in org.apache.flink.api.common.operators.base
Aggregator that basically only adds 1 for every output tuple of the termination criterion branch
BulkIterationBase.TerminationCriterionMapper<X> - Class in org.apache.flink.api.common.operators.base
Special Mapper that is added before a termination criterion and is only a container for an special aggregator
BulkIterationNode - Class in org.apache.flink.optimizer.dag
A node in the optimizer's program representation for a bulk iteration.
BulkIterationNode(BulkIterationBase<?>) - Constructor for class org.apache.flink.optimizer.dag.BulkIterationNode
Creates a new node for the bulk iteration.
BulkIterationPlanNode - Class in org.apache.flink.optimizer.plan
 
BulkIterationPlanNode(BulkIterationNode, String, Channel, BulkPartialSolutionPlanNode, PlanNode) - Constructor for class org.apache.flink.optimizer.plan.BulkIterationPlanNode
 
BulkIterationPlanNode(BulkIterationNode, String, Channel, BulkPartialSolutionPlanNode, PlanNode, PlanNode) - Constructor for class org.apache.flink.optimizer.plan.BulkIterationPlanNode
 
BulkIterationResultSet<T> - Class in org.apache.flink.api.java.operators
 
BulkPartialSolutionNode - Class in org.apache.flink.optimizer.dag
The optimizer's internal representation of the partial solution that is input to a bulk iteration.
BulkPartialSolutionNode(BulkIterationBase.PartialSolutionPlaceHolder<?>, BulkIterationNode) - Constructor for class org.apache.flink.optimizer.dag.BulkPartialSolutionNode
 
BulkPartialSolutionPlanNode - Class in org.apache.flink.optimizer.plan
Plan candidate node for partial solution of a bulk iteration.
BulkPartialSolutionPlanNode(BulkPartialSolutionNode, String, GlobalProperties, LocalProperties, Channel) - Constructor for class org.apache.flink.optimizer.plan.BulkPartialSolutionPlanNode
 
byRowOperation(Function2<Vector, Vector, Vector>, DistributedRowMatrix) - Method in class org.apache.flink.ml.math.distributed.DistributedRowMatrix
Applies a high-order function to couple of rows.
BYTE - Static variable in class org.apache.flink.api.common.typeinfo.Types
 
BYTE() - Method in class org.apache.flink.table.api.Types$
 
BYTE() - Static method in class org.apache.flink.table.api.Types
 
BYTE() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
BYTE() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
byte2Literal(byte) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionConversions
 
BYTE_ARRAY_BASE_OFFSET - Static variable in class org.apache.flink.core.memory.MemorySegment
The beginning of the byte array contents, relative to the byte array object
BYTE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
BYTE_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
BYTE_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
BYTE_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
ByteArrayInputStreamWithPos - Class in org.apache.flink.core.memory
Un-synchronized stream similar to Java's ByteArrayInputStream that also exposes the current position.
ByteArrayInputStreamWithPos(byte[]) - Constructor for class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
 
ByteArrayInputStreamWithPos(byte[], int, int) - Constructor for class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
 
ByteArrayOutputStreamWithPos - Class in org.apache.flink.core.memory
Un-synchronized stream similar to Java's ByteArrayOutputStream that also exposes the current position.
ByteArrayOutputStreamWithPos() - Constructor for class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
ByteArrayOutputStreamWithPos(int) - Constructor for class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
ByteAvgAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Byte Avg aggregate function
ByteAvgAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.ByteAvgAggFunction
 
ByteComparator - Class in org.apache.flink.api.common.typeutils.base
 
ByteComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.ByteComparator
 
ByteExplodeTableFunc - Class in org.apache.flink.table.plan.util
 
ByteExplodeTableFunc() - Constructor for class org.apache.flink.table.plan.util.ByteExplodeTableFunc
 
ByteMaxAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Byte Max aggregate function
ByteMaxAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.ByteMaxAggFunction
 
ByteMaxWithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Byte Max with retraction aggregate function
ByteMaxWithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.ByteMaxWithRetractAggFunction
 
ByteMinAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Byte Min aggregate function
ByteMinAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.ByteMinAggFunction
 
ByteMinWithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Byte Min with retraction aggregate function
ByteMinWithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.ByteMinWithRetractAggFunction
 
ByteParser - Class in org.apache.flink.types.parser
 
ByteParser() - Constructor for class org.apache.flink.types.parser.ByteParser
 
BytePrimitiveArrayComparator - Class in org.apache.flink.api.common.typeutils.base.array
 
BytePrimitiveArrayComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArrayComparator
 
BytePrimitiveArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
A serializer for byte arrays.
BytePrimitiveArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
bytes() - Method in class org.apache.flink.runtime.checkpoint.MasterState
 
BYTES_COPIED_CNT_NAME - Static variable in class org.apache.flink.examples.java.distcp.DistCp
 
ByteSerializer - Class in org.apache.flink.api.common.typeutils.base
 
ByteSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.ByteSerializer
 
ByteSerializer() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.ByteSerializer
 
BytesSerializer() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.BytesSerializer
 
ByteStreamStateHandle - Class in org.apache.flink.migration.runtime.state.memory
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
ByteStreamStateHandle(byte[]) - Constructor for class org.apache.flink.migration.runtime.state.memory.ByteStreamStateHandle
Deprecated.
Creates a new ByteStreamStateHandle containing the given data.
ByteStreamStateHandle - Class in org.apache.flink.runtime.state.memory
A state handle that contains stream state in a byte array.
ByteStreamStateHandle(String, byte[]) - Constructor for class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
Creates a new ByteStreamStateHandle containing the given data.
ByteSum0AggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Byte Sum0 aggregate function
ByteSum0AggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.ByteSum0AggFunction
 
ByteSum0WithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Byte Sum0 with retract aggregate function
ByteSum0WithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.ByteSum0WithRetractAggFunction
 
ByteSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.ByteSumAgg
 
ByteSumAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Byte Sum aggregate function
ByteSumAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.ByteSumAggFunction
 
ByteSumWithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Byte Sum with retract aggregate function
ByteSumWithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.ByteSumWithRetractAggFunction
 
byteToHexString(byte[], int, int) - Static method in class org.apache.flink.util.StringUtils
Given an array of bytes it will convert the bytes to a hex string representation of the bytes.
byteToHexString(byte[]) - Static method in class org.apache.flink.util.StringUtils
Given an array of bytes it will convert the bytes to a hex string representation of the bytes.
ByteValue - Class in org.apache.flink.types
Boxed serializable and comparable byte type, representing the primitive type byte (signed 8 bit integer).
ByteValue() - Constructor for class org.apache.flink.types.ByteValue
Initializes the encapsulated byte with 0.
ByteValue(byte) - Constructor for class org.apache.flink.types.ByteValue
Initializes the encapsulated byte with the provided value.
ByteValueComparator - Class in org.apache.flink.api.common.typeutils.base
Specialized comparator for ByteValue based on CopyableValueComparator.
ByteValueComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
ByteValueParser - Class in org.apache.flink.types.parser
Parses a decimal text field into a ByteValue.
ByteValueParser() - Constructor for class org.apache.flink.types.parser.ByteValueParser
 
ByteValueSerializer - Class in org.apache.flink.api.common.typeutils.base
 
ByteValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
ByteValueSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.ByteValueSumAgg
 
Bzip2InputStreamFactory - Class in org.apache.flink.api.common.io.compression
 
Bzip2InputStreamFactory() - Constructor for class org.apache.flink.api.common.io.compression.Bzip2InputStreamFactory
 

C

c() - Method in class org.apache.flink.api.scala.codegen.MacroContextHolder
 
C - Variable in class org.apache.flink.graph.generator.RMatGraph
 
cachable - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
cachable - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
 
cacheBaseStatistics(BaseStatistics, String) - Method in class org.apache.flink.optimizer.DataStatistics
Caches the given statistics.
cachedPlans - Variable in class org.apache.flink.optimizer.dag.OptimizerNode
 
cacheFile - Variable in class org.apache.flink.api.common.Plan
Hash map for files in the distributed cache: registered name to cache entry.
cacheFile - Variable in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
 
cachePartitionInfo(PartialInputChannelDeploymentDescriptor) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
CalciteConfig - Interface in org.apache.flink.table.calcite
Calcite configuration for defining a custom Calcite configuration for Table and SQL API.
CalciteConfig$ - Class in org.apache.flink.table.calcite
 
CalciteConfig$() - Constructor for class org.apache.flink.table.calcite.CalciteConfig$
 
CalciteConfigBuilder - Class in org.apache.flink.table.calcite
Builder for creating a Calcite configuration.
CalciteConfigBuilder() - Constructor for class org.apache.flink.table.calcite.CalciteConfigBuilder
 
calcOpName(RexProgram, Function3<RexNode, List<String>, Option<List<RexNode>>, String>) - Method in interface org.apache.flink.table.plan.nodes.CommonCalc
 
calcOpName(RexProgram, Function3<RexNode, List<String>, Option<List<RexNode>>, String>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
calcToString(RexProgram, Function3<RexNode, List<String>, Option<List<RexNode>>, String>) - Method in interface org.apache.flink.table.plan.nodes.CommonCalc
 
calcToString(RexProgram, Function3<RexNode, List<String>, Option<List<RexNode>>, String>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
calculateHeapSize(int, Configuration) - Static method in class org.apache.flink.yarn.Utils
See documentation
calculateHeapSizeMB(long, Configuration) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
Calculates the amount of heap memory to use (to set via -Xmx and -Xms) based on the total memory to use and the given configuration parameters.
calculateLearningRate(double, int, double) - Method in class org.apache.flink.ml.optimization.LearningRateMethod.Bottou
 
calculateLearningRate(double, int, double) - Method in class org.apache.flink.ml.optimization.LearningRateMethod.Constant$
 
calculateLearningRate(double, int, double) - Method in class org.apache.flink.ml.optimization.LearningRateMethod.Default$
 
calculateLearningRate(double, int, double) - Method in class org.apache.flink.ml.optimization.LearningRateMethod.InvScaling
 
calculateLearningRate(double, int, double) - Method in interface org.apache.flink.ml.optimization.LearningRateMethod.LearningRateMethodTrait
 
calculateLearningRate(double, int, double) - Method in class org.apache.flink.ml.optimization.LearningRateMethod.Xu
 
calculateNetworkBufferMemory(long, Configuration) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
Calculates the amount of memory used for network buffers based on the total memory to use and the according configuration parameters.
calculateNetworkBufferMemory(TaskManagerServicesConfiguration) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
Calculates the amount of memory used for network buffers inside the current JVM instance based on the available heap or the max heap size and the according configuration parameters.
call() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncIOCallable
This method implements the strategy for the actual IO operation: 1) Open the IO handle 2) Perform IO operation 3) Close IO handle
call(SqlOperator, RexNode[]) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
call(SqlOperator, Iterable<? extends RexNode>) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
Call - Class in org.apache.flink.table.expressions
General expression for unresolved function calls.
Call(String, Seq<Expression>) - Constructor for class org.apache.flink.table.expressions.Call
 
Call$ - Class in org.apache.flink.table.expressions
 
Call$() - Constructor for class org.apache.flink.table.expressions.Call$
 
CallAsync - Class in org.apache.flink.runtime.rpc.akka.messages
Message for asynchronous callable invocations
CallAsync(Callable<?>) - Constructor for class org.apache.flink.runtime.rpc.akka.messages.CallAsync
 
callAsync(Callable<V>, Time) - Method in interface org.apache.flink.runtime.rpc.MainThreadExecutable
Execute the callable in the main thread of the underlying RPC endpoint and return a future for the callable result.
callAsync(Callable<V>, Time) - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
Execute the callable in the main thread of the underlying RPC service, returning a future for the result of the callable.
callback - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraSinkBase
 
callback - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
The callback than handles error propagation or logging callbacks
CallGenerator - Interface in org.apache.flink.table.codegen.calls
 
CallGenerator$ - Class in org.apache.flink.table.codegen.calls
 
CallGenerator$() - Constructor for class org.apache.flink.table.codegen.calls.CallGenerator$
 
callWithNextKey(FlatJoinFunction<V1, V2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstHashJoinIterator
 
callWithNextKey(FlatJoinFunction<V1, V2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondHashJoinIterator
 
callWithNextKey(FlatJoinFunction<V1, V2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildFirstHashJoinIterator
 
callWithNextKey(FlatJoinFunction<V1, V2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildSecondHashJoinIterator
 
callWithNextKey(FlatJoinFunction<T1, T2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeInnerJoinIterator
Calls the JoinFunction#join() method for all two key-value pairs that share the same key and come from different inputs.
callWithNextKey(FlatJoinFunction<T1, T2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
Calls the JoinFunction#join() method for all two key-value pairs that share the same key and come from different inputs.
callWithNextKey(FlatJoinFunction<T1, T2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeOuterJoinIterator
Calls the JoinFunction#join() method for all two key-value pairs that share the same key and come from different inputs.
callWithNextKey(FlatJoinFunction<V1, V2, O>, Collector<O>) - Method in interface org.apache.flink.runtime.operators.util.JoinTaskIterator
Moves the internal pointer to the next key that both inputs share.
canBeSubsumed() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
Checks whether this checkpoint can be subsumed or whether it should always continue, regardless of newer checkpoints in progress.
canCast(TypeInformation<?>, TypeInformation<?>) - Method in class org.apache.flink.table.typeutils.TypeCoercion$
All the supported cast types in flink-table.
canCast(TypeInformation<?>, TypeInformation<?>) - Static method in class org.apache.flink.table.typeutils.TypeCoercion
All the supported cast types in flink-table.
cancel(String[]) - Method in class org.apache.flink.client.CliFrontend
Executes the CANCEL action.
cancel(JobID) - Method in class org.apache.flink.client.program.ClusterClient
Cancels a job identified by the job id.
cancel(boolean) - Method in interface org.apache.flink.runtime.concurrent.Future
Tries to cancel the future's operation.
cancel(boolean) - Method in class org.apache.flink.runtime.concurrent.impl.FlinkCompletableFuture
 
cancel(boolean) - Method in class org.apache.flink.runtime.concurrent.impl.FlinkFuture
 
cancel() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
cancel() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
cancel() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
Cancels all currently running vertex executions.
cancel() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
cancel(boolean) - Method in class org.apache.flink.runtime.io.async.AsyncStoppableTaskWithCallback
 
cancel() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
cancel() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
This method is called when a task is canceled either as a result of a user abort or an execution failure.
cancel() - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.AllReduceDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.BatchTask
 
cancel() - Method in class org.apache.flink.runtime.operators.CoGroupDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.CrossDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.DataSinkTask
 
cancel() - Method in class org.apache.flink.runtime.operators.DataSourceTask
 
cancel() - Method in interface org.apache.flink.runtime.operators.Driver
This method is invoked when the driver must aborted in mid processing.
cancel() - Method in class org.apache.flink.runtime.operators.FlatMapDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.JoinDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.MapDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.NoOpDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.ReduceDriver
 
cancel() - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
 
cancel() - Method in class org.apache.flink.runtime.registration.RetryingRegistration
Cancels the registration procedure.
cancel(boolean) - Method in class org.apache.flink.runtime.state.DoneFuture
 
cancel() - Method in class org.apache.flink.storm.wrappers.SpoutWrapper
Cancels the source.
cancel() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
 
cancel() - Method in class org.apache.flink.streaming.api.functions.source.FileMonitoringFunction
Deprecated.
 
cancel() - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
 
cancel() - Method in class org.apache.flink.streaming.api.functions.source.FromIteratorFunction
 
cancel() - Method in class org.apache.flink.streaming.api.functions.source.FromSplittableIteratorFunction
 
cancel() - Method in class org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
 
cancel() - Method in class org.apache.flink.streaming.api.functions.source.SocketTextStreamFunction
 
cancel() - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction
Cancels the source.
cancel() - Method in class org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
 
cancel() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotResult
 
cancel() - Method in class org.apache.flink.streaming.api.operators.StreamSource
 
cancel() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
 
cancel() - Method in class org.apache.flink.streaming.connectors.kafka.internal.Kafka09Fetcher
 
cancel() - Method in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
 
cancel() - Method in class org.apache.flink.streaming.connectors.kafka.internals.Kafka08Fetcher
 
cancel() - Method in class org.apache.flink.streaming.connectors.nifi.NiFiSource
 
cancel() - Method in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
 
cancel() - Method in class org.apache.flink.streaming.connectors.twitter.TwitterSource
 
cancel() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditsSource
 
cancel() - Method in class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.FiniteNewDataSource
 
cancel() - Method in class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.FiniteTrainingDataSource
 
cancel() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
cancel() - Method in class org.apache.flink.streaming.scala.examples.async.SimpleSource
 
cancelAndReleaseAllSlots() - Method in class org.apache.flink.runtime.instance.Instance
 
cancelChainedTasks(List<ChainedDriver<?, ?>>) - Static method in class org.apache.flink.runtime.operators.BatchTask
Cancels all tasks via their ChainedDriver.cancelTask() method.
CancelCheckpointMarker - Class in org.apache.flink.runtime.io.network.api
The CancelCheckpointMarker travels through the data streams, similar to the CheckpointBarrier, but signals that a certain checkpoint should be canceled.
CancelCheckpointMarker(long) - Constructor for class org.apache.flink.runtime.io.network.api.CancelCheckpointMarker
 
cancelExecution() - Method in class org.apache.flink.runtime.taskmanager.Task
Cancels the task execution.
CancelJob(JobID) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.CancelJob
 
CancelJob$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.CancelJob$
 
CancelJobWithSavepoint(JobID, String) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.CancelJobWithSavepoint
 
CancelJobWithSavepoint$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.CancelJobWithSavepoint$
 
CancellationFailure(JobID, Throwable) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.CancellationFailure
 
CancellationFailure$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.CancellationFailure$
 
CancellationSuccess(JobID, String) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.CancellationSuccess
 
CancellationSuccess$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.CancellationSuccess$
 
CancelOptions - Class in org.apache.flink.client.cli
Command line options for the CANCEL command
CancelOptions(CommandLine) - Constructor for class org.apache.flink.client.cli.CancelOptions
 
cancelStackTraceSample(int, Throwable) - Method in class org.apache.flink.runtime.webmonitor.StackTraceSampleCoordinator
Cancels a pending sample.
cancelStreamRegistry - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
Registry for all opened streams, so they can be closed if the task using this backend is closed
cancelTask(ExecutionAttemptID, Time) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
cancelTask(ExecutionAttemptID, Time) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Cancel the given task.
cancelTask(ExecutionAttemptID, Time) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
CancelTask(ExecutionAttemptID) - Constructor for class org.apache.flink.runtime.messages.TaskMessages.CancelTask
 
cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
 
cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
 
cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
 
cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
 
cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
 
cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
 
cancelTask() - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
 
cancelTask() - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
 
cancelTask(ExecutionAttemptID) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
cancelTask(ExecutionAttemptID, Time) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Cancel the given task.
cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
 
cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
 
cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
 
cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
cancelTask() - Method in class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
 
CancelTask$() - Constructor for class org.apache.flink.runtime.messages.TaskMessages.CancelTask$
 
CancelTaskException - Exception in org.apache.flink.runtime.execution
Thrown to trigger a canceling of the executing task.
CancelTaskException(Throwable) - Constructor for exception org.apache.flink.runtime.execution.CancelTaskException
 
CancelTaskException(String) - Constructor for exception org.apache.flink.runtime.execution.CancelTaskException
 
CancelTaskException() - Constructor for exception org.apache.flink.runtime.execution.CancelTaskException
 
cancelTimer(String) - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
cancelTimer(String) - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
cancelTimer(String) - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
cancelTimer(String) - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
cancelWithFuture() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
Cancels all currently running vertex executions.
canContainFields() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
canContainInput() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
canConvert(RelOptPlanner, AccModeTrait, AccModeTrait) - Method in class org.apache.flink.table.plan.nodes.datastream.AccModeTraitDef
 
canConvert(RelOptPlanner, UpdateAsRetractionTrait, UpdateAsRetractionTrait) - Method in class org.apache.flink.table.plan.nodes.datastream.UpdateAsRetractionTraitDef
 
canEqual(Object) - Method in class org.apache.flink.api.common.ExecutionConfig
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
Returns true if the given object can be equaled with this object.
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.CompositeType
 
canEqual(Object) - Method in interface org.apache.flink.api.common.typeutils.TypeDeserializer
Returns true if the given object can be equaled with this object.
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.TypeDeserializerAdapter
 
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
Returns true if the given object can be equaled with this object.
canEqual(Object) - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.ListTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.PojoField
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.scala.typeutils.CaseClassTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.scala.typeutils.EitherSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.scala.typeutils.EitherTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.scala.typeutils.EnumValueSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.scala.typeutils.EnumValueTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.scala.typeutils.NothingSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.scala.typeutils.OptionSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.scala.typeutils.OptionTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.scala.typeutils.ScalaNothingTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.scala.typeutils.TraversableSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.scala.typeutils.TraversableTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.scala.typeutils.TrySerializer
 
canEqual(Object) - Method in class org.apache.flink.api.scala.typeutils.TryTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.api.scala.typeutils.UnitSerializer
 
canEqual(Object) - Method in class org.apache.flink.api.scala.typeutils.UnitTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
 
canEqual(Object) - Method in class org.apache.flink.cep.nfa.NFA.NFASerializer
 
canEqual(Object) - Method in class org.apache.flink.cep.nfa.NFA.Serializer
 
canEqual(Object) - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
 
canEqual(Object) - Method in class org.apache.flink.cep.NonDuplicatingTypeSerializer
 
canEqual(Object) - Method in class org.apache.flink.graph.types.valuearray.IntValueArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.graph.types.valuearray.LongValueArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.graph.types.valuearray.NullValueArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.graph.types.valuearray.StringValueArraySerializer
 
canEqual(Object) - Method in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
 
canEqual(Object) - Static method in class org.apache.flink.mesos.runtime.clusterframework.RegisteredMesosWorkerNode
 
canEqual(Object) - Method in class org.apache.flink.migration.MigrationNamespaceSerializerProxy
Deprecated.
 
canEqual(Object) - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer
 
canEqual(Object) - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.StreamRecordSerializer
 
canEqual(Object) - Static method in class org.apache.flink.ml.common.Block
 
canEqual(Object) - Static method in class org.apache.flink.ml.common.LabeledVector
 
canEqual(Object) - Static method in class org.apache.flink.ml.common.WeightVector
 
canEqual(Object) - Static method in class org.apache.flink.ml.math.DenseMatrix
 
canEqual(Object) - Static method in class org.apache.flink.ml.math.DenseVector
 
canEqual(Object) - Static method in class org.apache.flink.ml.math.distributed.IndexedRow
 
canEqual(Object) - Static method in class org.apache.flink.ml.math.SparseVector
 
canEqual(Object) - Static method in class org.apache.flink.ml.optimization.GenericLossFunction
 
canEqual(Object) - Static method in class org.apache.flink.ml.pipeline.ChainedPredictor
 
canEqual(Object) - Static method in class org.apache.flink.ml.pipeline.ChainedTransformer
 
canEqual(Object) - Static method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsErroneous
 
canEqual(Object) - Static method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsFound
 
canEqual(Object) - Static method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsNotFound
 
canEqual(Object) - Static method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultStringsFound
 
canEqual(Object) - Static method in class org.apache.flink.runtime.messages.accumulators.RequestAccumulatorResults
 
canEqual(Object) - Static method in class org.apache.flink.runtime.messages.accumulators.RequestAccumulatorResultsStringified
 
canEqual(Object) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
canEqual(Object) - Method in class org.apache.flink.runtime.state.HashMapSerializer
 
canEqual(Object) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
 
canEqual(Object) - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
 
canEqual(Object) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
 
canEqual(Object) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
canEqual(Object) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
canEqual(Object) - Static method in exception org.apache.flink.table.api.AmbiguousTableSourceConverterException
 
canEqual(Object) - Static method in exception org.apache.flink.table.api.CatalogAlreadyExistException
 
canEqual(Object) - Static method in exception org.apache.flink.table.api.CatalogNotExistException
 
canEqual(Object) - Static method in class org.apache.flink.table.api.CurrentRange
 
canEqual(Object) - Static method in class org.apache.flink.table.api.CurrentRow
 
canEqual(Object) - Static method in exception org.apache.flink.table.api.ExpressionParserException
 
canEqual(Object) - Static method in exception org.apache.flink.table.api.ExternalCatalogAlreadyExistException
 
canEqual(Object) - Static method in exception org.apache.flink.table.api.ExternalCatalogNotExistException
 
canEqual(Object) - Static method in exception org.apache.flink.table.api.NoMatchedTableSourceConverterException
 
canEqual(Object) - Static method in class org.apache.flink.table.api.OverWindow
 
canEqual(Object) - Static method in class org.apache.flink.table.api.scala.OverWindowWithOrderBy
 
canEqual(Object) - Static method in class org.apache.flink.table.api.scala.PartitionedOver
 
canEqual(Object) - Static method in exception org.apache.flink.table.api.SqlParserException
 
canEqual(Object) - Static method in exception org.apache.flink.table.api.TableAlreadyExistException
 
canEqual(Object) - Static method in exception org.apache.flink.table.api.TableException
 
canEqual(Object) - Static method in exception org.apache.flink.table.api.TableNotExistException
 
canEqual(Object) - Static method in class org.apache.flink.table.api.UnboundedRange
 
canEqual(Object) - Static method in class org.apache.flink.table.api.UnboundedRow
 
canEqual(Object) - Static method in exception org.apache.flink.table.api.UnresolvedException
 
canEqual(Object) - Static method in exception org.apache.flink.table.api.ValidationException
 
canEqual(Object) - Static method in class org.apache.flink.table.catalog.ExternalCatalogTable
 
canEqual(Object) - Static method in class org.apache.flink.table.codegen.GeneratedAggregationsFunction
 
canEqual(Object) - Static method in class org.apache.flink.table.codegen.GeneratedCollector
 
canEqual(Object) - Static method in class org.apache.flink.table.codegen.GeneratedExpression
 
canEqual(Object) - Static method in class org.apache.flink.table.codegen.GeneratedFunction
 
canEqual(Object) - Static method in class org.apache.flink.table.codegen.GeneratedInput
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Abs
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Acos
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.AggFunctionCall
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Alias
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.And
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.ArrayCardinality
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.ArrayConstructor
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.ArrayElement
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.ArrayElementAt
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Asc
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Asin
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Atan
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Avg
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Call
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Cast
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Ceil
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.CharLength
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Cos
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Cot
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Count
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.CurrentDate
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.CurrentTime
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.CurrentTimestamp
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Degrees
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Desc
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Div
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.EqualTo
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Exp
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Extract
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Flattening
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Floor
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.GetCompositeField
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.GreaterThan
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.GreaterThanOrEqual
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.If
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.InitCap
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.IsFalse
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.IsNotFalse
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.IsNotNull
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.IsNotTrue
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.IsNull
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.IsTrue
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.LessThan
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.LessThanOrEqual
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Like
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Literal
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Ln
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.LocalTime
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.LocalTimestamp
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Log10
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Lower
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Max
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Min
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Minus
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Mod
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Mul
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Not
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.NotEqualTo
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Null
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Or
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.OverCall
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Overlay
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Pi
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Plus
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Position
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Power
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.ProctimeAttribute
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Quarter
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Radians
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.ResolvedFieldReference
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Round
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.RowtimeAttribute
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.ScalarFunctionCall
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Sign
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Similar
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Sin
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Sqrt
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.StddevPop
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.StddevSamp
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Substring
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Sum
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Sum0
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.SymbolExpression
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.TableFunctionCall
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Tan
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.TemporalCeil
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.TemporalFloor
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.TemporalOverlaps
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Trim
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.UDAGGExpression
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.UnaryMinus
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.UnresolvedAlias
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.UnresolvedFieldReference
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.UnresolvedOverCall
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.Upper
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.VarPop
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.VarSamp
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.WindowEnd
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.WindowReference
 
canEqual(Object) - Static method in class org.apache.flink.table.expressions.WindowStart
 
canEqual(Object) - Static method in class org.apache.flink.table.plan.logical.Aggregate
 
canEqual(Object) - Static method in class org.apache.flink.table.plan.logical.AliasNode
 
canEqual(Object) - Static method in class org.apache.flink.table.plan.logical.CatalogNode
 
canEqual(Object) - Static method in class org.apache.flink.table.plan.logical.Distinct
 
canEqual(Object) - Static method in class org.apache.flink.table.plan.logical.Filter
 
canEqual(Object) - Static method in class org.apache.flink.table.plan.logical.Intersect
 
canEqual(Object) - Static method in class org.apache.flink.table.plan.logical.Join
 
canEqual(Object) - Static method in class org.apache.flink.table.plan.logical.Limit
 
canEqual(Object) - Static method in class org.apache.flink.table.plan.logical.LogicalRelNode
 
canEqual(Object) - Static method in class org.apache.flink.table.plan.logical.LogicalTableFunctionCall
 
canEqual(Object) - Static method in class org.apache.flink.table.plan.logical.Minus
 
canEqual(Object) - Static method in class org.apache.flink.table.plan.logical.Project
 
canEqual(Object) - Static method in class org.apache.flink.table.plan.logical.SessionGroupWindow
 
canEqual(Object) - Static method in class org.apache.flink.table.plan.logical.SlidingGroupWindow
 
canEqual(Object) - Static method in class org.apache.flink.table.plan.logical.Sort
 
canEqual(Object) - Static method in class org.apache.flink.table.plan.logical.TumblingGroupWindow
 
canEqual(Object) - Static method in class org.apache.flink.table.plan.logical.Union
 
canEqual(Object) - Static method in class org.apache.flink.table.plan.logical.WindowAggregate
 
canEqual(Object) - Method in class org.apache.flink.table.plan.schema.ArrayRelDataType
 
canEqual(Object) - Method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
canEqual(Object) - Method in class org.apache.flink.table.plan.schema.GenericRelDataType
 
canEqual(Object) - Method in class org.apache.flink.table.plan.schema.MapRelDataType
 
canEqual(Object) - Static method in class org.apache.flink.table.plan.stats.ColumnStats
 
canEqual(Object) - Static method in class org.apache.flink.table.plan.stats.TableStats
 
canEqual(Object) - Method in class org.apache.flink.table.runtime.types.CRowSerializer
 
canEqual(Object) - Method in class org.apache.flink.table.runtime.types.CRowTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.table.typeutils.InternalTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.table.typeutils.RowIntervalTypeInfo
 
canEqual(Object) - Static method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
 
canEqual(Object) - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
 
canEqual(Object) - Static method in class org.apache.flink.table.validate.ValidationFailure
 
canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
 
canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
 
canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
 
canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
 
canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
 
canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
 
canMerge() - Method in class org.apache.flink.streaming.api.windowing.triggers.Trigger
Returns true if this trigger supports merging of trigger state and can therefore be used with a MergingWindowAssigner.
canMerge() - Method in class org.apache.flink.table.runtime.triggers.StateCleaningCountTrigger
 
canNotContainInput() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
canonize(StructKind, List<String>, List<RelDataType>) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
canonize(RelDataType) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
canonize(T) - Static method in class org.apache.flink.table.plan.nodes.datastream.AccModeTraitDef
 
canonize(T) - Static method in class org.apache.flink.table.plan.nodes.datastream.UpdateAsRetractionTraitDef
 
canonizeComposite(org.apache.calcite.plan.RelCompositeTrait) - Static method in class org.apache.flink.table.plan.nodes.datastream.AccModeTraitDef
 
canonizeComposite(org.apache.calcite.plan.RelCompositeTrait) - Static method in class org.apache.flink.table.plan.nodes.datastream.UpdateAsRetractionTraitDef
 
canReadInt() - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
canReadLong() - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
canRestart() - Method in class org.apache.flink.runtime.executiongraph.restart.FailureRateRestartStrategy
 
canRestart() - Method in class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
 
canRestart() - Method in class org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy
 
canRestart() - Method in interface org.apache.flink.runtime.executiongraph.restart.RestartStrategy
True if the restart strategy can be applied to restart the ExecutionGraph.
canSafelyCast(TypeInformation<?>, TypeInformation<?>) - Method in class org.apache.flink.table.typeutils.TypeCoercion$
Test if we can do cast safely without lose of information.
canSafelyCast(TypeInformation<?>, TypeInformation<?>) - Static method in class org.apache.flink.table.typeutils.TypeCoercion
Test if we can do cast safely without lose of information.
CAR_DATA - Static variable in class org.apache.flink.streaming.examples.windowing.util.TopSpeedWindowingExampleData
 
CARDINALITY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The CARDINALITY operator, used to retrieve the number of elements in a MULTISET, ARRAY or MAP.
cardinality() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Returns the number of elements of an array.
CarEvent(int, int, double, long) - Constructor for class org.apache.flink.streaming.scala.examples.windowing.TopSpeedWindowing.CarEvent
 
CarEvent$() - Constructor for class org.apache.flink.streaming.scala.examples.windowing.TopSpeedWindowing.CarEvent$
 
carId() - Method in class org.apache.flink.streaming.scala.examples.windowing.TopSpeedWindowing.CarEvent
 
CartesianProductDescriptor - Class in org.apache.flink.optimizer.operators
 
CartesianProductDescriptor(boolean, boolean) - Constructor for class org.apache.flink.optimizer.operators.CartesianProductDescriptor
 
CASE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
CaseClassComparator<T extends scala.Product> - Class in org.apache.flink.api.scala.typeutils
Comparator for Case Classes.
CaseClassComparator(int[], TypeComparator<?>[], TypeSerializer<?>[]) - Constructor for class org.apache.flink.api.scala.typeutils.CaseClassComparator
 
CaseClassDescriptor(int, scala.reflect.macros.Context.universe, boolean, scala.reflect.macros.Context.universe, Seq<org.apache.flink.api.scala.codegen.TypeDescriptors.FieldDescriptor>) - Constructor for class org.apache.flink.api.scala.codegen.TypeDescriptors.CaseClassDescriptor
 
CaseClassSerializer<T extends scala.Product> - Class in org.apache.flink.api.scala.typeutils
Serializer for Case Classes.
CaseClassSerializer(Class<T>, TypeSerializer<?>[]) - Constructor for class org.apache.flink.api.scala.typeutils.CaseClassSerializer
 
CaseClassTypeInfo<T extends scala.Product> - Class in org.apache.flink.api.scala.typeutils
TypeInformation for Case Classes.
CaseClassTypeInfo(Class<T>, TypeInformation<?>[], Seq<TypeInformation<?>>, Seq<String>) - Constructor for class org.apache.flink.api.scala.typeutils.CaseClassTypeInfo
 
CassandraCommitter - Class in org.apache.flink.streaming.connectors.cassandra
CheckpointCommitter that saves information about completed checkpoints within a separate table in a cassandra database.
CassandraCommitter(ClusterBuilder) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraCommitter
 
CassandraCommitter(ClusterBuilder, String) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraCommitter
 
CassandraInputFormat<OUT extends Tuple> - Class in org.apache.flink.batch.connectors.cassandra
InputFormat to read data from Apache Cassandra and generate $Tuple.
CassandraInputFormat(String, ClusterBuilder) - Constructor for class org.apache.flink.batch.connectors.cassandra.CassandraInputFormat
 
CassandraOutputFormat<OUT extends Tuple> - Class in org.apache.flink.batch.connectors.cassandra
OutputFormat to write Tuple into Apache Cassandra.
CassandraOutputFormat(String, ClusterBuilder) - Constructor for class org.apache.flink.batch.connectors.cassandra.CassandraOutputFormat
 
CassandraPojoSink<IN> - Class in org.apache.flink.streaming.connectors.cassandra
Flink Sink to save data into a Cassandra cluster using Mapper, which it uses annotations from com.datastax.driver.mapping.annotations.
CassandraPojoSink(Class<IN>, ClusterBuilder) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraPojoSink
The main constructor for creating CassandraPojoSink
CassandraPojoSinkBuilder(DataStream<IN>, TypeInformation<IN>, TypeSerializer<IN>) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraPojoSinkBuilder
 
CassandraSink<IN> - Class in org.apache.flink.streaming.connectors.cassandra
This class wraps different Cassandra sink implementations to provide a common interface for all of them.
CassandraSink.CassandraPojoSinkBuilder<IN> - Class in org.apache.flink.streaming.connectors.cassandra
 
CassandraSink.CassandraSinkBuilder<IN> - Class in org.apache.flink.streaming.connectors.cassandra
 
CassandraSink.CassandraTupleSinkBuilder<IN extends Tuple> - Class in org.apache.flink.streaming.connectors.cassandra
 
CassandraSinkBase<IN,V> - Class in org.apache.flink.streaming.connectors.cassandra
CassandraSinkBase is the common abstract class of CassandraPojoSink and CassandraTupleSink.
CassandraSinkBase(ClusterBuilder) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraSinkBase
 
CassandraSinkBuilder(DataStream<IN>, TypeInformation<IN>, TypeSerializer<IN>) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
 
CassandraTupleSink<IN extends Tuple> - Class in org.apache.flink.streaming.connectors.cassandra
Flink Sink to save data into a Cassandra cluster.
CassandraTupleSink(String, ClusterBuilder) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraTupleSink
 
CassandraTupleSinkBuilder(DataStream<IN>, TypeInformation<IN>, TypeSerializer<IN>) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraTupleSinkBuilder
 
CassandraTupleWriteAheadSink<IN extends Tuple> - Class in org.apache.flink.streaming.connectors.cassandra
Sink that emits its input elements into a Cassandra database.
CassandraTupleWriteAheadSink(String, TypeSerializer<IN>, ClusterBuilder, CheckpointCommitter) - Constructor for class org.apache.flink.streaming.connectors.cassandra.CassandraTupleWriteAheadSink
 
CAST - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The SQL CAST operator.
cast(TypeInformation<?>) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Converts a value to a given type.
cast(RexNode, SqlTypeName) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
cast(RexNode, SqlTypeName, int) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
cast(RexNode, SqlTypeName, int, int) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
Cast - Class in org.apache.flink.table.expressions
 
Cast(Expression, TypeInformation<?>) - Constructor for class org.apache.flink.table.expressions.Cast
 
CAST() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
CAST() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
Cast$ - Class in org.apache.flink.table.expressions
 
Cast$() - Constructor for class org.apache.flink.table.expressions.Cast$
 
catalog() - Method in exception org.apache.flink.table.api.CatalogAlreadyExistException
 
catalog() - Method in exception org.apache.flink.table.api.CatalogNotExistException
 
catalog() - Method in exception org.apache.flink.table.api.TableAlreadyExistException
 
catalog() - Method in exception org.apache.flink.table.api.TableNotExistException
 
CatalogAlreadyExistException - Exception in org.apache.flink.table.api
Exception for adding an already existent catalog
CatalogAlreadyExistException(String, Throwable) - Constructor for exception org.apache.flink.table.api.CatalogAlreadyExistException
 
CatalogAlreadyExistException(String) - Constructor for exception org.apache.flink.table.api.CatalogAlreadyExistException
 
CatalogAlreadyExistException$ - Class in org.apache.flink.table.api
 
CatalogAlreadyExistException$() - Constructor for class org.apache.flink.table.api.CatalogAlreadyExistException$
 
catalogName() - Method in exception org.apache.flink.table.api.ExternalCatalogAlreadyExistException
 
catalogName() - Method in exception org.apache.flink.table.api.ExternalCatalogNotExistException
 
CatalogNode - Class in org.apache.flink.table.plan.logical
 
CatalogNode(Seq<String>, RelDataType) - Constructor for class org.apache.flink.table.plan.logical.CatalogNode
 
CatalogNode$ - Class in org.apache.flink.table.plan.logical
 
CatalogNode$() - Constructor for class org.apache.flink.table.plan.logical.CatalogNode$
 
CatalogNotExistException - Exception in org.apache.flink.table.api
Exception for operation on a nonexistent catalog
CatalogNotExistException(String, Throwable) - Constructor for exception org.apache.flink.table.api.CatalogNotExistException
 
CatalogNotExistException(String) - Constructor for exception org.apache.flink.table.api.CatalogNotExistException
 
CatalogNotExistException$ - Class in org.apache.flink.table.api
 
CatalogNotExistException$() - Constructor for class org.apache.flink.table.api.CatalogNotExistException$
 
catalogReader - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
 
cause() - Method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsErroneous
 
cause() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.CancellationFailure
 
cause() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.DisposeSavepointFailure
 
cause() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.JobResultFailure
 
cause() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.StoppingFailure
 
cause() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.TriggerSavepointFailure
 
cause() - Method in class org.apache.flink.runtime.messages.Messages.Disconnect
 
cause() - Method in class org.apache.flink.runtime.messages.TaskManagerMessages.FatalError
 
cause() - Method in class org.apache.flink.runtime.messages.TaskMessages.FailTask
 
cause() - Method in exception org.apache.flink.table.api.AmbiguousTableSourceConverterException
 
cause() - Method in exception org.apache.flink.table.api.CatalogAlreadyExistException
 
cause() - Method in exception org.apache.flink.table.api.CatalogNotExistException
 
cause() - Method in exception org.apache.flink.table.api.ExternalCatalogAlreadyExistException
 
cause() - Method in exception org.apache.flink.table.api.ExternalCatalogNotExistException
 
cause() - Method in exception org.apache.flink.table.api.NoMatchedTableSourceConverterException
 
cause() - Method in exception org.apache.flink.table.api.SqlParserException
 
cause() - Method in exception org.apache.flink.table.api.TableAlreadyExistException
 
cause() - Method in exception org.apache.flink.table.api.TableException
 
cause() - Method in exception org.apache.flink.table.api.TableNotExistException
 
cause() - Method in exception org.apache.flink.table.api.ValidationException
 
cbf() - Method in class org.apache.flink.api.scala.typeutils.TraversableSerializer
 
CCMessenger(TypeInformation<VV>) - Constructor for class org.apache.flink.graph.library.ConnectedComponents.CCMessenger
 
CCUpdater() - Constructor for class org.apache.flink.graph.library.ConnectedComponents.CCUpdater
 
CEIL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The CEIL function.
ceil() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Calculates the smallest integer greater than or equal to a given number.
ceil(TableSymbols.TableSymbolValue) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Rounds up a time point to the given unit.
Ceil - Class in org.apache.flink.table.expressions
 
Ceil(Expression) - Constructor for class org.apache.flink.table.expressions.Ceil
 
CEIL() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
CEIL() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
Ceil$ - Class in org.apache.flink.table.expressions
 
Ceil$() - Constructor for class org.apache.flink.table.expressions.Ceil$
 
CENTERS_2D_AFTER_20_ITERATIONS_DOUBLE_DIGIT - Static variable in class org.apache.flink.test.testdata.KMeansData
 
CENTERS_2D_AFTER_SINGLE_ITERATION_DOUBLE_DIGIT - Static variable in class org.apache.flink.test.testdata.KMeansData
 
CENTERS_AFTER_20_ITERATIONS_DOUBLE_DIGIT - Static variable in class org.apache.flink.test.testdata.KMeansData
 
CENTERS_AFTER_20_ITERATIONS_SINGLE_DIGIT - Static variable in class org.apache.flink.test.testdata.KMeansData
 
CENTERS_AFTER_ONE_STEP - Static variable in class org.apache.flink.test.testdata.KMeansData
 
CENTERS_AFTER_ONE_STEP_SINGLE_DIGIT - Static variable in class org.apache.flink.test.testdata.KMeansData
 
Centroid() - Constructor for class org.apache.flink.examples.java.clustering.KMeans.Centroid
 
Centroid(int, double, double) - Constructor for class org.apache.flink.examples.java.clustering.KMeans.Centroid
 
Centroid(int, KMeans.Point) - Constructor for class org.apache.flink.examples.java.clustering.KMeans.Centroid
 
Centroid(int, double, double) - Constructor for class org.apache.flink.examples.scala.clustering.KMeans.Centroid
 
Centroid(int, KMeans.Point) - Constructor for class org.apache.flink.examples.scala.clustering.KMeans.Centroid
 
Centroid$() - Constructor for class org.apache.flink.examples.scala.clustering.KMeans.Centroid$
 
CentroidAccumulator() - Constructor for class org.apache.flink.examples.java.clustering.KMeans.CentroidAccumulator
 
CentroidAverager() - Constructor for class org.apache.flink.examples.java.clustering.KMeans.CentroidAverager
 
CENTROIDS - Static variable in class org.apache.flink.examples.java.clustering.util.KMeansData
 
CEP - Class in org.apache.flink.cep
Utility class for complex event processing.
CEP() - Constructor for class org.apache.flink.cep.CEP
 
CEP - Class in org.apache.flink.cep.scala
Utility method to transform a DataStream into a PatternStream to do CEP.
CEP() - Constructor for class org.apache.flink.cep.scala.CEP
 
CEP$ - Class in org.apache.flink.cep.scala
Utility method to transform a DataStream into a PatternStream to do CEP.
CEP$() - Constructor for class org.apache.flink.cep.scala.CEP$
 
CEPOperatorUtils - Class in org.apache.flink.cep.operator
 
CEPOperatorUtils() - Constructor for class org.apache.flink.cep.operator.CEPOperatorUtils
 
ChainedAllReduceDriver<IT> - Class in org.apache.flink.runtime.operators.chaining
 
ChainedAllReduceDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
 
ChainedDriver<IT,OT> - Class in org.apache.flink.runtime.operators.chaining
The interface to be implemented by drivers that do not run in an own task context, but are chained to other tasks.
ChainedDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
chainedEvaluationOperation(TransformDataSetOperation<T, Testing, Intermediate>, EvaluateDataSetOperation<P, Intermediate, PredictionValue>, TypeInformation<Testing>, TypeInformation<PredictionValue>) - Method in class org.apache.flink.ml.pipeline.ChainedPredictor$
 
chainedEvaluationOperation(TransformDataSetOperation<T, Testing, Intermediate>, EvaluateDataSetOperation<P, Intermediate, PredictionValue>, TypeInformation<Testing>, TypeInformation<PredictionValue>) - Static method in class org.apache.flink.ml.pipeline.ChainedPredictor
 
chainedFitOperation(FitOperation<L, I>, TransformDataSetOperation<L, I, T>, FitOperation<R, T>) - Method in class org.apache.flink.ml.pipeline.ChainedPredictor$
chainedFitOperation(FitOperation<L, I>, TransformDataSetOperation<L, I, T>, FitOperation<R, T>) - Static method in class org.apache.flink.ml.pipeline.ChainedPredictor
chainedFitOperation(FitOperation<L, I>, TransformDataSetOperation<L, I, T>, FitOperation<R, T>) - Method in class org.apache.flink.ml.pipeline.ChainedTransformer$
FitOperation implementation for ChainedTransformer.
chainedFitOperation(FitOperation<L, I>, TransformDataSetOperation<L, I, T>, FitOperation<R, T>) - Static method in class org.apache.flink.ml.pipeline.ChainedTransformer
FitOperation implementation for ChainedTransformer.
ChainedFlatMapDriver<IT,OT> - Class in org.apache.flink.runtime.operators.chaining
 
ChainedFlatMapDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
 
ChainedMapDriver<IT,OT> - Class in org.apache.flink.runtime.operators.chaining
 
ChainedMapDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
 
chainedPredictOperation(TransformDataSetOperation<T, Testing, Intermediate>, PredictDataSetOperation<P, Intermediate, Prediction>) - Method in class org.apache.flink.ml.pipeline.ChainedPredictor$
chainedPredictOperation(TransformDataSetOperation<T, Testing, Intermediate>, PredictDataSetOperation<P, Intermediate, Prediction>) - Static method in class org.apache.flink.ml.pipeline.ChainedPredictor
ChainedPredictor<T extends Transformer<T>,P extends Predictor<P>> - Class in org.apache.flink.ml.pipeline
Predictor which represents a pipeline of possibly multiple Transformer and a trailing Predictor.
ChainedPredictor(T, P) - Constructor for class org.apache.flink.ml.pipeline.ChainedPredictor
 
ChainedPredictor$ - Class in org.apache.flink.ml.pipeline
 
ChainedPredictor$() - Constructor for class org.apache.flink.ml.pipeline.ChainedPredictor$
 
ChainedReduceCombineDriver<T> - Class in org.apache.flink.runtime.operators.chaining
Chained version of ReduceCombineDriver.
ChainedReduceCombineDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
 
ChainedStateHandle<T extends StateObject> - Class in org.apache.flink.runtime.state
Handle to state handles for the operators in an operator chain.
ChainedStateHandle(List<? extends T>) - Constructor for class org.apache.flink.runtime.state.ChainedStateHandle
Wraps a list to the state handles for the operators in a chain.
chainedTasks - Variable in class org.apache.flink.runtime.operators.BatchTask
A list of chained drivers, if there are any.
ChainedTerminationCriterionDriver<IT,OT> - Class in org.apache.flink.runtime.operators.chaining
 
ChainedTerminationCriterionDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
 
ChainedTransformer<L extends Transformer<L>,R extends Transformer<R>> - Class in org.apache.flink.ml.pipeline
Transformer which represents the chaining of two Transformer.
ChainedTransformer(L, R) - Constructor for class org.apache.flink.ml.pipeline.ChainedTransformer
 
ChainedTransformer$ - Class in org.apache.flink.ml.pipeline
 
ChainedTransformer$() - Constructor for class org.apache.flink.ml.pipeline.ChainedTransformer$
 
chainedTransformOperation(TransformDataSetOperation<L, I, T>, TransformDataSetOperation<R, T, O>) - Method in class org.apache.flink.ml.pipeline.ChainedTransformer$
chainedTransformOperation(TransformDataSetOperation<L, I, T>, TransformDataSetOperation<R, T, O>) - Static method in class org.apache.flink.ml.pipeline.ChainedTransformer
chainingStrategy - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
ChainingStrategy - Enum in org.apache.flink.streaming.api.operators
Defines the chaining scheme for the operator.
chainl1(Function0<Parsers.Parser<T>>, Function0<Parsers.Parser<Function2<T, T, T>>>) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
chainl1(Function0<Parsers.Parser<T>>, Function0<Parsers.Parser<U>>, Function0<Parsers.Parser<Function2<T, U, T>>>) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
chainPredictor(P) - Static method in class org.apache.flink.ml.outlier.StochasticOutlierSelection
 
chainPredictor(P) - Static method in class org.apache.flink.ml.pipeline.ChainedTransformer
 
chainPredictor(P) - Method in interface org.apache.flink.ml.pipeline.Transformer
Chains a Transformer with a Predictor to form a ChainedPredictor.
chainPredictor(P) - Static method in class org.apache.flink.ml.preprocessing.MinMaxScaler
 
chainPredictor(P) - Static method in class org.apache.flink.ml.preprocessing.PolynomialFeatures
 
chainPredictor(P) - Static method in class org.apache.flink.ml.preprocessing.StandardScaler
 
chainr1(Function0<Parsers.Parser<T>>, Function0<Parsers.Parser<Function2<T, U, U>>>, Function2<T, U, U>, U) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
chainTransformer(T) - Static method in class org.apache.flink.ml.outlier.StochasticOutlierSelection
 
chainTransformer(T) - Static method in class org.apache.flink.ml.pipeline.ChainedTransformer
 
chainTransformer(T) - Method in interface org.apache.flink.ml.pipeline.Transformer
Chains two Transformer to form a ChainedTransformer.
chainTransformer(T) - Static method in class org.apache.flink.ml.preprocessing.MinMaxScaler
 
chainTransformer(T) - Static method in class org.apache.flink.ml.preprocessing.PolynomialFeatures
 
chainTransformer(T) - Static method in class org.apache.flink.ml.preprocessing.StandardScaler
 
change() - Method in class org.apache.flink.table.runtime.types.CRow
 
Channel - Class in org.apache.flink.optimizer.plan
A Channel represents the result produced by an operator and the data exchange before the consumption by the target operator.
Channel(PlanNode) - Constructor for class org.apache.flink.optimizer.plan.Channel
 
Channel(PlanNode, TempMode) - Constructor for class org.apache.flink.optimizer.plan.Channel
 
channel - Variable in class org.apache.flink.streaming.connectors.rabbitmq.RMQSink
 
channel - Variable in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
 
channelIndex - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
 
channelRead0(ChannelHandlerContext, Object) - Method in class org.apache.flink.mesos.util.MesosArtifactServer.UnknownFileHandler
 
channelRead0(ChannelHandlerContext, Routed) - Method in class org.apache.flink.mesos.util.MesosArtifactServer.VirtualFileServerHandler
 
channelRead0(ChannelHandlerContext, Routed) - Method in class org.apache.flink.runtime.webmonitor.files.StaticFileServerHandler
 
channelRead0(ChannelHandlerContext, Routed) - Method in class org.apache.flink.runtime.webmonitor.handlers.ConstantTextHandler
 
channelRead0(ChannelHandlerContext, Routed) - Method in class org.apache.flink.runtime.webmonitor.history.HistoryServerStaticFileServerHandler
 
channelRead0(ChannelHandlerContext, HttpObject) - Method in class org.apache.flink.runtime.webmonitor.HttpRequestHandler
 
channelRead0(ChannelHandlerContext, Object) - Method in class org.apache.flink.runtime.webmonitor.PipelineErrorHandler
 
channelRead0(ChannelHandlerContext, Routed) - Method in class org.apache.flink.runtime.webmonitor.RuntimeMonitorHandlerBase
 
ChannelReaderInputView - Class in org.apache.flink.runtime.io.disk.iomanager
A DataInputView that is backed by a BlockChannelReader, making it effectively a data input stream.
ChannelReaderInputView(BlockChannelReader<MemorySegment>, List<MemorySegment>, boolean) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
Creates a new channel reader that reads from the given channel until the last block (as marked by a ChannelWriterOutputView) is found.
ChannelReaderInputView(BlockChannelReader<MemorySegment>, List<MemorySegment>, int, boolean) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
Creates a new channel reader that reads from the given channel, expecting a specified number of blocks in the channel.
ChannelReaderInputViewIterator<E> - Class in org.apache.flink.runtime.io.disk
A simple iterator over the input read though an I/O channel.
ChannelReaderInputViewIterator(IOManager, FileIOChannel.ID, List<MemorySegment>, List<MemorySegment>, TypeSerializer<E>, int) - Constructor for class org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator
 
ChannelReaderInputViewIterator(IOManager, FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>, List<MemorySegment>, List<MemorySegment>, TypeSerializer<E>, int) - Constructor for class org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator
 
ChannelReaderInputViewIterator(BlockChannelReader<MemorySegment>, LinkedBlockingQueue<MemorySegment>, List<MemorySegment>, List<MemorySegment>, TypeSerializer<E>, int) - Constructor for class org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator
 
ChannelReaderInputViewIterator(ChannelReaderInputView, List<MemorySegment>, TypeSerializer<E>) - Constructor for class org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator
 
ChannelSelector<T extends IOReadableWritable> - Interface in org.apache.flink.runtime.io.network.api.writer
The ChannelSelector determines to which logical channels a record should be written to.
channelUnregistered(ChannelHandlerContext) - Method in class org.apache.flink.runtime.webmonitor.HttpRequestHandler
 
ChannelWithBlockCount(FileIOChannel.ID, int) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ChannelWithBlockCount
 
ChannelWriterOutputView - Class in org.apache.flink.runtime.io.disk.iomanager
A DataOutputView that is backed by a BlockChannelWriter, making it effectively a data output stream.
ChannelWriterOutputView(BlockChannelWriter<MemorySegment>, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
Creates an new ChannelWriterOutputView that writes to the given channel and buffers data in the given memory segments.
ChannelWriterOutputView(BlockChannelWriter<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
Creates an new ChannelWriterOutputView that writes to the given channel.
CHAR_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
CHAR_LENGTH - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
CHAR_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
CHAR_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
CHAR_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
CHARACTER_LENGTH - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
CharacterFilter - Interface in org.apache.flink.metrics
Interface for a character filter function.
charAt(int) - Method in class org.apache.flink.types.StringValue
 
CharComparator - Class in org.apache.flink.api.common.typeutils.base
 
CharComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.CharComparator
 
charLength() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Returns the length of a string.
CharLength - Class in org.apache.flink.table.expressions
Returns the length of this str.
CharLength(Expression) - Constructor for class org.apache.flink.table.expressions.CharLength
 
CharLength$ - Class in org.apache.flink.table.expressions
 
CharLength$() - Constructor for class org.apache.flink.table.expressions.CharLength$
 
CharPrimitiveArrayComparator - Class in org.apache.flink.api.common.typeutils.base.array
 
CharPrimitiveArrayComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArrayComparator
 
CharPrimitiveArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
A serializer for char arrays.
CharPrimitiveArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
CharSerializer - Class in org.apache.flink.api.common.typeutils.base
 
CharSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.CharSerializer
 
CharValue - Class in org.apache.flink.types
Boxed serializable and comparable character type, representing the primitive type char.
CharValue() - Constructor for class org.apache.flink.types.CharValue
Initializes the encapsulated char with 0.
CharValue(char) - Constructor for class org.apache.flink.types.CharValue
Initializes the encapsulated char with the provided value.
CharValueComparator - Class in org.apache.flink.api.common.typeutils.base
Specialized comparator for CharValue based on CopyableValueComparator.
CharValueComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
CharValueSerializer - Class in org.apache.flink.api.common.typeutils.base
 
CharValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
ChebyshevDistanceMetric - Class in org.apache.flink.ml.metrics.distances
This class implements a Chebyshev distance metric.
ChebyshevDistanceMetric() - Constructor for class org.apache.flink.ml.metrics.distances.ChebyshevDistanceMetric
 
ChebyshevDistanceMetric$ - Class in org.apache.flink.ml.metrics.distances
 
ChebyshevDistanceMetric$() - Constructor for class org.apache.flink.ml.metrics.distances.ChebyshevDistanceMetric$
 
CheckAndAllocateContainers - Class in org.apache.flink.runtime.clusterframework.messages
This message signals the resource master to check how many TaskManagers are desired, how many are available, and to trigger adjustments if needed.
checkAndCoSort(int[], Class<?>[]) - Static method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
checkAndExtractLambda(Function) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils
Checks if the given function has been implemented using a Java 8 lambda.
checkAndExtractMethods(UserDefinedFunction, String) - Method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils$
Extracts methods and throws a ValidationException if no implementation can be found, or implementation does not match the requirements.
checkAndExtractMethods(UserDefinedFunction, String) - Static method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils
Extracts methods and throws a ValidationException if no implementation can be found, or implementation does not match the requirements.
checkAndGetNewWatermark(T, long) - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionStateWithPunctuatedWatermarks
 
checkAndGetNextWatermark(T, long) - Method in interface org.apache.flink.streaming.api.functions.AssignerWithPunctuatedWatermarks
Asks this implementation if it wants to emit a watermark.
checkAndGetNextWatermark(Integer, long) - Method in class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.LinearTimestamp
 
checkAndThrowException() - Method in class org.apache.flink.streaming.connectors.kafka.internals.ExceptionProxy
Checks whether an exception has been set via ExceptionProxy.reportError(Throwable).
checkArgument(boolean) - Static method in class org.apache.flink.util.Preconditions
Checks the given boolean condition, and throws an IllegalArgumentException if the condition is not met (evaluates to false).
checkArgument(boolean, Object) - Static method in class org.apache.flink.util.Preconditions
Checks the given boolean condition, and throws an IllegalArgumentException if the condition is not met (evaluates to false).
checkArgument(boolean, String, Object...) - Static method in class org.apache.flink.util.Preconditions
Checks the given boolean condition, and throws an IllegalArgumentException if the condition is not met (evaluates to false).
checkCollection(Collection<X>, Class<X>) - Static method in class org.apache.flink.api.java.io.CollectionInputFormat
 
checkCollection(Collection<OUT>, Class<OUT>) - Static method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
Verifies that all elements in the collection are non-null, and are of the given class, or a subclass thereof.
checkedDownCast(long) - Static method in class org.apache.flink.util.MathUtils
Casts the given value to a 32 bit integer, if it can be safely done.
CheckedThread - Class in org.apache.flink.core.testutils
A thread that additionally catches exceptions and offers a joining method that re-throws the exceptions.
CheckedThread() - Constructor for class org.apache.flink.core.testutils.CheckedThread
Unnamed checked thread.
CheckedThread(String) - Constructor for class org.apache.flink.core.testutils.CheckedThread
Checked thread with a name.
checkElementIndex(int, int) - Static method in class org.apache.flink.util.Preconditions
Ensures that the given index is valid for an array, list or string of the given size.
checkElementIndex(int, int, String) - Static method in class org.apache.flink.util.Preconditions
Ensures that the given index is valid for an array, list or string of the given size.
checkEquals(Expression) - Static method in class org.apache.flink.table.api.CurrentRange
 
checkEquals(Expression) - Static method in class org.apache.flink.table.api.CurrentRow
 
checkEquals(Expression) - Static method in class org.apache.flink.table.api.UnboundedRange
 
checkEquals(Expression) - Static method in class org.apache.flink.table.api.UnboundedRow
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Abs
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Acos
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.AggFunctionCall
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Alias
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.And
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.ArrayCardinality
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.ArrayConstructor
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.ArrayElement
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.ArrayElementAt
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Asc
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Asin
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Atan
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Avg
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Call
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Cast
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Ceil
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.CharLength
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Cos
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Cot
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Count
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.CurrentDate
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.CurrentTime
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.CurrentTimestamp
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Degrees
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Desc
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Div
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.EqualTo
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Exp
 
checkEquals(Expression) - Method in class org.apache.flink.table.expressions.Expression
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Extract
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Flattening
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Floor
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.GetCompositeField
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.GreaterThan
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.GreaterThanOrEqual
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.If
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.InitCap
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.IsFalse
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.IsNotFalse
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.IsNotNull
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.IsNotTrue
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.IsNull
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.IsTrue
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.LessThan
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.LessThanOrEqual
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Like
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Literal
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Ln
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.LocalTime
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.LocalTimestamp
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Log10
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Lower
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Max
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Min
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Minus
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Mod
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Mul
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Not
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.NotEqualTo
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Null
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Or
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.OverCall
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Overlay
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Pi
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Plus
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Position
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Power
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.ProctimeAttribute
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Quarter
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Radians
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.ResolvedFieldReference
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Round
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.RowtimeAttribute
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.ScalarFunctionCall
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Sign
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Similar
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Sin
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Sqrt
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.StddevPop
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.StddevSamp
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Substring
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Sum
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Sum0
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.SymbolExpression
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.TableFunctionCall
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Tan
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.TemporalCeil
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.TemporalFloor
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.TemporalOverlaps
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Trim
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.UnaryMinus
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.UnresolvedAlias
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.UnresolvedFieldReference
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.UnresolvedOverCall
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.Upper
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.VarPop
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.VarSamp
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.WindowEnd
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.WindowReference
 
checkEquals(Expression) - Static method in class org.apache.flink.table.expressions.WindowStart
 
checkEquivalentFieldPositionsInKeyFields(FieldList, FieldList) - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
 
checkEquivalentFieldPositionsInKeyFields(FieldList, FieldList, int) - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
 
checkErroneous() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
Checks the exception state of this channel.
checkErroneous() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
 
checkError() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
Checks for an error and rethrows it if one was reported.
checkForInstantiation(Class<?>) - Method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils$
Checks if a user-defined function can be easily instantiated.
checkForInstantiation(Class<?>) - Static method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils
Checks if a user-defined function can be easily instantiated.
checkForInstantiation(Class<?>) - Static method in class org.apache.flink.util.InstantiationUtil
Performs a standard check whether the class can be instantiated by Class#newInstance().
checkForInstantiationError(Class<?>) - Static method in class org.apache.flink.util.InstantiationUtil
 
checkForMonotonousOrder(int[], Class<?>[]) - Static method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
CheckForUserCommand$() - Constructor for class org.apache.flink.yarn.YarnMessages.CheckForUserCommand$
 
checkJarFile(URL) - Static method in class org.apache.flink.client.program.JobWithJars
 
checkJoinKeyFields(int[]) - Method in class org.apache.flink.api.java.operators.DeltaIteration.SolutionSetPlaceHolder
 
checkLinesAgainstRegexp(String, String) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
checkNameUniqueness(String) - Method in class org.apache.flink.cep.nfa.compiler.NFAStateNameHandler
Checks if the given name is already used or not.
checkNetworkBufferConfig(int, float, long, long) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
Validates the (new) network buffer configuration.
checkNetworkConfigOld(int) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
Validates the (old) network buffer configuration.
checkNotNull(T) - Static method in class org.apache.flink.util.Preconditions
Ensures that the given object reference is not null.
checkNotNull(T, String) - Static method in class org.apache.flink.util.Preconditions
Ensures that the given object reference is not null.
checkNotNull(T, String, Object...) - Static method in class org.apache.flink.util.Preconditions
Ensures that the given object reference is not null.
checkNotShutdown() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
 
checkNotSingleton(Class<?>) - Method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils$
Check whether this is a Scala object.
checkNotSingleton(Class<?>) - Static method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils
Check whether this is a Scala object.
checkOddEvenResult(BufferedReader) - Static method in class org.apache.flink.test.testdata.ConnectedComponentsData
 
checkOddEvenResult(List<Tuple2<Long, Long>>) - Static method in class org.apache.flink.test.testdata.ConnectedComponentsData
 
checkOddEvenResult(BufferedReader) - Static method in class org.apache.flink.test.testdata.TransitiveClosureData
 
checkOperandCount(SqlValidator, SqlOperandTypeChecker, SqlCall) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
checkOperandCount(SqlValidator, SqlOperandTypeChecker, SqlCall) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
checkOperandCount(SqlValidator, SqlOperandTypeChecker, SqlCall) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
checkOperandCount(SqlValidator, SqlOperandTypeChecker, SqlCall) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
checkOperandTypes(SqlCallBinding, boolean) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
checkOperandTypes(SqlCallBinding, boolean) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
checkOperandTypes(SqlCallBinding, boolean) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
checkOperandTypes(SqlCallBinding, boolean) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
checkParallelismPreconditions(List<OperatorState>, ExecutionJobVertex) - Method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
 
checkParallelismPreconditions(int) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
 
checkParameter(boolean, Object) - Static method in class org.apache.flink.graph.drivers.parameter.Util
Checks the given boolean condition, and throws an ProgramParametrizationException if the condition is not met (evaluates to false).
checkPartialSolutionPropertiesMet(PlanNode, GlobalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.plan.PlanNode
 
CHECKPOINT_DIRECTORY_URI_CONF_KEY - Static variable in class org.apache.flink.contrib.streaming.state.RocksDBStateBackendFactory
The key under which the config stores the directory where checkpoints should be stored
CHECKPOINT_DIRECTORY_URI_CONF_KEY - Static variable in class org.apache.flink.runtime.state.filesystem.FsStateBackendFactory
The key under which the config stores the directory where checkpoints should be stored
CheckpointableInputFormat<S extends InputSplit,T extends Serializable> - Interface in org.apache.flink.api.common.io
An interface that describes InputFormats that allow checkpointing/restoring their state.
CheckpointBarrier - Class in org.apache.flink.runtime.io.network.api
Checkpoint barriers are used to align checkpoints throughout the streaming topology.
CheckpointBarrier(long, long, CheckpointOptions) - Constructor for class org.apache.flink.runtime.io.network.api.CheckpointBarrier
 
CheckpointBarrierHandler - Interface in org.apache.flink.streaming.runtime.io
The CheckpointBarrierHandler reacts to checkpoint barrier arriving from the input channels.
CheckpointCommitter - Class in org.apache.flink.streaming.runtime.operators
This class is used to save information about which sink operator instance has committed checkpoints to a backend.
CheckpointCommitter() - Constructor for class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
 
CheckpointConfig - Class in org.apache.flink.streaming.api.environment
Configuration that captures all checkpointing related settings.
CheckpointConfig() - Constructor for class org.apache.flink.streaming.api.environment.CheckpointConfig
 
CheckpointConfig.ExternalizedCheckpointCleanup - Enum in org.apache.flink.streaming.api.environment
Cleanup behaviour for externalized checkpoints when the job is cancelled.
CheckpointConfigHandler - Class in org.apache.flink.runtime.webmonitor.handlers.checkpoints
Handler that returns a job's snapshotting settings.
CheckpointConfigHandler(ExecutionGraphHolder) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.checkpoints.CheckpointConfigHandler
 
CheckpointConfigHandler.CheckpointConfigJsonArchivist - Class in org.apache.flink.runtime.webmonitor.handlers.checkpoints
 
CheckpointConfigJsonArchivist() - Constructor for class org.apache.flink.runtime.webmonitor.handlers.checkpoints.CheckpointConfigHandler.CheckpointConfigJsonArchivist
 
CheckpointCoordinator - Class in org.apache.flink.runtime.checkpoint
The checkpoint coordinator coordinates the distributed snapshots of operators and state.
CheckpointCoordinator(JobID, long, long, long, int, ExternalizedCheckpointSettings, ExecutionVertex[], ExecutionVertex[], ExecutionVertex[], CheckpointIDCounter, CompletedCheckpointStore, String, Executor, SharedStateRegistryFactory) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
CheckpointCoordinatorDeActivator - Class in org.apache.flink.runtime.checkpoint
This actor listens to changes in the JobStatus and activates or deactivates the periodic checkpoint scheduler.
CheckpointCoordinatorDeActivator(CheckpointCoordinator) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointCoordinatorDeActivator
 
CheckpointCoordinatorGateway - Interface in org.apache.flink.runtime.checkpoint
 
CheckpointDeclineException - Exception in org.apache.flink.runtime.checkpoint.decline
Base class of all exceptions that indicate a declined checkpoint.
CheckpointDeclineException(String) - Constructor for exception org.apache.flink.runtime.checkpoint.decline.CheckpointDeclineException
 
CheckpointDeclineException(String, Throwable) - Constructor for exception org.apache.flink.runtime.checkpoint.decline.CheckpointDeclineException
 
CheckpointDeclineOnCancellationBarrierException - Exception in org.apache.flink.runtime.checkpoint.decline
Exception indicating that a checkpoint was declined because a cancellation barrier was received.
CheckpointDeclineOnCancellationBarrierException() - Constructor for exception org.apache.flink.runtime.checkpoint.decline.CheckpointDeclineOnCancellationBarrierException
 
CheckpointDeclineReason - Enum in org.apache.flink.runtime.checkpoint
Various reasons why a checkpoint was declined.
CheckpointDeclineSubsumedException - Exception in org.apache.flink.runtime.checkpoint.decline
Exception indicating that a checkpoint was declined because a newer checkpoint barrier was received on an input before the pending checkpoint's barrier.
CheckpointDeclineSubsumedException(long) - Constructor for exception org.apache.flink.runtime.checkpoint.decline.CheckpointDeclineSubsumedException
 
CheckpointDeclineTaskNotCheckpointingException - Exception in org.apache.flink.runtime.checkpoint.decline
Exception indicating that a checkpoint was declined because a task does not support checkpointing.
CheckpointDeclineTaskNotCheckpointingException(String) - Constructor for exception org.apache.flink.runtime.checkpoint.decline.CheckpointDeclineTaskNotCheckpointingException
 
CheckpointDeclineTaskNotReadyException - Exception in org.apache.flink.runtime.checkpoint.decline
Exception indicating that a checkpoint was declined because a task was not ready to perform a checkpoint.
CheckpointDeclineTaskNotReadyException(String) - Constructor for exception org.apache.flink.runtime.checkpoint.decline.CheckpointDeclineTaskNotReadyException
 
Checkpointed<T extends Serializable> - Interface in org.apache.flink.streaming.api.checkpoint
Deprecated.
Please use ListCheckpointed as illustrated above, or CheckpointedFunction for more control over the checkpointing process.
CheckpointedAsynchronously<T extends Serializable> - Interface in org.apache.flink.streaming.api.checkpoint
Deprecated.
Please use ListCheckpointed and CheckpointedFunction instead, as illustrated in the example above.
CheckpointedFunction - Interface in org.apache.flink.streaming.api.checkpoint
This is the core interface for stateful transformation functions, meaning functions that maintain state across individual stream records.
CheckpointedRestoring<T extends Serializable> - Interface in org.apache.flink.streaming.api.checkpoint
Deprecated.
Please use CheckpointedFunction or ListCheckpointed after restoring your legacy state.
CheckpointedRestoringOperator - Interface in org.apache.flink.streaming.api.operators
Deprecated.
Checkpointed has been deprecated as well. This class can be removed when we remove that interface.
CheckpointException - Exception in org.apache.flink.runtime.checkpoint
Base class for checkpoint related exceptions.
CheckpointException(String, Throwable) - Constructor for exception org.apache.flink.runtime.checkpoint.CheckpointException
 
CheckpointException(String) - Constructor for exception org.apache.flink.runtime.checkpoint.CheckpointException
 
CheckpointException - Exception in org.apache.flink.runtime.taskexecutor.exceptions
Exception indicating a problem with checkpointing on the TaskExecutor side.
CheckpointException(String) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.CheckpointException
 
CheckpointException(String, Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.CheckpointException
 
CheckpointException(Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.CheckpointException
 
checkpointId - Variable in class org.apache.flink.runtime.checkpoint.AbstractAsyncSnapshotIOCallable
 
checkpointId() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.TriggerSavepointSuccess
 
CheckpointIDCounter - Interface in org.apache.flink.runtime.checkpoint
A checkpoint ID counter.
checkpointIdToPath(long) - Static method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
Convert a checkpoint id into a ZooKeeper path.
checkpointingLock - Variable in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
CheckpointingMode - Enum in org.apache.flink.streaming.api
The checkpointing mode defines what consistency guarantees the system gives in the presence of failures.
CheckpointListener - Interface in org.apache.flink.runtime.state
This interface must be implemented by functions/operations that want to receive a commit notification once a checkpoint has been completely acknowledged by all participants.
checkpointLock - Variable in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
The lock that guarantees that record emission and state updates are atomic, from the view of taking a checkpoint
CheckpointMetaData - Class in org.apache.flink.runtime.checkpoint
Encapsulates all the meta data for a checkpoint.
CheckpointMetaData(long, long) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointMetaData
 
CheckpointMetrics - Class in org.apache.flink.runtime.checkpoint
A collection of simple metrics, around the triggering of a checkpoint.
CheckpointMetrics() - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
CheckpointMetrics(long, long, long, long) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
CheckpointOptions - Class in org.apache.flink.runtime.checkpoint
Options for performing the checkpoint.
CheckpointOptions.CheckpointType - Enum in org.apache.flink.runtime.checkpoint
The type of checkpoint to perform.
CheckpointProperties - Class in org.apache.flink.runtime.checkpoint
The configuration of a checkpoint, such as whether The checkpoint should be persisted The checkpoint must be full, or may be incremental (not yet implemented) The checkpoint format must be the common (cross backend) format, or may be state-backend specific (not yet implemented) when the checkpoint should be garbage collected
CheckpointRecoveryFactory - Interface in org.apache.flink.runtime.checkpoint
A factory for per Job checkpoint recovery components.
checkpointRecoveryFactory() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
CheckpointResponder - Interface in org.apache.flink.runtime.taskmanager
Responder for checkpoint acknowledge and decline messages in the Task.
CHECKPOINTS_DIRECTORY_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
The default directory used for persistent checkpoints.
checkpointsMatch(Collection<CompletedCheckpoint>, Collection<CompletedCheckpoint>) - Static method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
CheckpointStateOutputStream() - Constructor for class org.apache.flink.runtime.state.CheckpointStreamFactory.CheckpointStateOutputStream
 
CheckpointStatsCache - Class in org.apache.flink.runtime.webmonitor.handlers.checkpoints
A size-based cache of accessed checkpoints for completed and failed checkpoints.
CheckpointStatsCache(int) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.checkpoints.CheckpointStatsCache
 
CheckpointStatsCounts - Class in org.apache.flink.runtime.checkpoint
Counts of checkpoints.
CheckpointStatsDetailsHandler - Class in org.apache.flink.runtime.webmonitor.handlers.checkpoints
Request handler that returns checkpoint stats for a single job vertex.
CheckpointStatsDetailsHandler(ExecutionGraphHolder, CheckpointStatsCache) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.checkpoints.CheckpointStatsDetailsHandler
 
CheckpointStatsDetailsHandler.CheckpointStatsDetailsJsonArchivist - Class in org.apache.flink.runtime.webmonitor.handlers.checkpoints
 
CheckpointStatsDetailsJsonArchivist() - Constructor for class org.apache.flink.runtime.webmonitor.handlers.checkpoints.CheckpointStatsDetailsHandler.CheckpointStatsDetailsJsonArchivist
 
CheckpointStatsDetailsSubtasksHandler - Class in org.apache.flink.runtime.webmonitor.handlers.checkpoints
Request handler that returns checkpoint stats for a single job vertex with the summary stats and all subtasks.
CheckpointStatsDetailsSubtasksHandler(ExecutionGraphHolder, CheckpointStatsCache) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.checkpoints.CheckpointStatsDetailsSubtasksHandler
 
CheckpointStatsDetailsSubtasksHandler.CheckpointStatsDetailsSubtasksJsonArchivist - Class in org.apache.flink.runtime.webmonitor.handlers.checkpoints
 
CheckpointStatsDetailsSubtasksJsonArchivist() - Constructor for class org.apache.flink.runtime.webmonitor.handlers.checkpoints.CheckpointStatsDetailsSubtasksHandler.CheckpointStatsDetailsSubtasksJsonArchivist
 
CheckpointStatsHandler - Class in org.apache.flink.runtime.webmonitor.handlers.checkpoints
Handler that returns checkpoint statistics for a job.
CheckpointStatsHandler(ExecutionGraphHolder) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.checkpoints.CheckpointStatsHandler
 
CheckpointStatsHandler.CheckpointStatsJsonArchivist - Class in org.apache.flink.runtime.webmonitor.handlers.checkpoints
 
CheckpointStatsHistory - Class in org.apache.flink.runtime.checkpoint
An array based history of checkpoint stats.
CheckpointStatsJsonArchivist() - Constructor for class org.apache.flink.runtime.webmonitor.handlers.checkpoints.CheckpointStatsHandler.CheckpointStatsJsonArchivist
 
CheckpointStatsSnapshot - Class in org.apache.flink.runtime.checkpoint
A snapshot of the checkpoint stats.
CheckpointStatsStatus - Enum in org.apache.flink.runtime.checkpoint
Status of the tracked checkpoint.
CheckpointStatsTracker - Class in org.apache.flink.runtime.checkpoint
Tracker for checkpoint statistics.
CheckpointStatsTracker(int, List<ExecutionJobVertex>, JobCheckpointingSettings, MetricGroup) - Constructor for class org.apache.flink.runtime.checkpoint.CheckpointStatsTracker
Creates a new checkpoint stats tracker.
CheckpointStreamFactory - Interface in org.apache.flink.runtime.state
 
CheckpointStreamFactory.CheckpointStateOutputStream - Class in org.apache.flink.runtime.state
A dedicated output stream that produces a StreamStateHandle when closed.
checkResultsWithDelta(String, List<String>, double) - Static method in class org.apache.flink.test.testdata.KMeansData
 
checkSameExecutionContext(DataSet<?>, DataSet<?>) - Static method in class org.apache.flink.api.java.DataSet
 
checkSameOrdering(GlobalProperties, GlobalProperties, int) - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
 
checkSameOrdering(LocalProperties, LocalProperties, int) - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
 
checkState(boolean) - Static method in class org.apache.flink.util.Preconditions
Checks the given boolean condition, and throws an IllegalStateException if the condition is not met (evaluates to false).
checkState(boolean, Object) - Static method in class org.apache.flink.util.Preconditions
Checks the given boolean condition, and throws an IllegalStateException if the condition is not met (evaluates to false).
checkState(boolean, String, Object...) - Static method in class org.apache.flink.util.Preconditions
Checks the given boolean condition, and throws an IllegalStateException if the condition is not met (evaluates to false).
checkStreamClosedAndDoTransitionToOpen() - Method in class org.apache.flink.runtime.checkpoint.AbstractAsyncSnapshotIOCallable
 
checkStreamOpenAndDoTransitionToClose() - Method in class org.apache.flink.runtime.checkpoint.AbstractAsyncSnapshotIOCallable
 
Checksum(long, long) - Constructor for class org.apache.flink.graph.asm.dataset.ChecksumHashCode.Checksum
Instantiate an immutable result.
ChecksumHashCode() - Constructor for class org.apache.flink.api.java.Utils.ChecksumHashCode
 
ChecksumHashCode(long, long) - Constructor for class org.apache.flink.api.java.Utils.ChecksumHashCode
 
checksumHashCode(DataSet<T>) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Deprecated.
replaced with org.apache.flink.graph.asm.dataset.ChecksumHashCode in Gelly
ChecksumHashCode<T> - Class in org.apache.flink.graph.asm.dataset
Convenience method to get the count (number of elements) of a DataSet as well as the checksum (sum over element hashes).
ChecksumHashCode() - Constructor for class org.apache.flink.graph.asm.dataset.ChecksumHashCode
 
ChecksumHashCode<K,VV,EV> - Class in org.apache.flink.graph.library.metric
Convenience method to get the count (number of elements) of a Graph as well as the checksum (sum over element hashes).
ChecksumHashCode() - Constructor for class org.apache.flink.graph.library.metric.ChecksumHashCode
 
ChecksumHashCode.Checksum - Class in org.apache.flink.graph.asm.dataset
Wraps checksum and count.
ChecksumHashCodeHelper(String) - Constructor for class org.apache.flink.api.java.Utils.ChecksumHashCodeHelper
 
checkValidArguments(Vector, Vector) - Static method in class org.apache.flink.ml.metrics.distances.ChebyshevDistanceMetric
 
checkValidArguments(Vector, Vector) - Static method in class org.apache.flink.ml.metrics.distances.CosineDistanceMetric
 
checkValidArguments(Vector, Vector) - Method in interface org.apache.flink.ml.metrics.distances.DistanceMetric
 
checkValidArguments(Vector, Vector) - Static method in class org.apache.flink.ml.metrics.distances.EuclideanDistanceMetric
 
checkValidArguments(Vector, Vector) - Static method in class org.apache.flink.ml.metrics.distances.ManhattanDistanceMetric
 
checkValidArguments(Vector, Vector) - Static method in class org.apache.flink.ml.metrics.distances.MinkowskiDistanceMetric
 
checkValidArguments(Vector, Vector) - Static method in class org.apache.flink.ml.metrics.distances.SquaredEuclideanDistanceMetric
 
checkValidArguments(Vector, Vector) - Static method in class org.apache.flink.ml.metrics.distances.TanimotoDistanceMetric
 
checkValidTableName(String) - Method in class org.apache.flink.table.api.BatchTableEnvironment
Checks if the chosen table name is valid.
checkValidTableName(String) - Method in class org.apache.flink.table.api.StreamTableEnvironment
Checks if the chosen table name is valid.
checkValidTableName(String) - Method in class org.apache.flink.table.api.TableEnvironment
Checks if the chosen table name is valid.
child() - Method in class org.apache.flink.table.expressions.Abs
 
child() - Method in class org.apache.flink.table.expressions.Acos
 
child() - Method in class org.apache.flink.table.expressions.Alias
 
child() - Method in class org.apache.flink.table.expressions.Asc
 
child() - Method in class org.apache.flink.table.expressions.Asin
 
child() - Method in class org.apache.flink.table.expressions.Atan
 
child() - Method in class org.apache.flink.table.expressions.Avg
 
child() - Method in class org.apache.flink.table.expressions.Cast
 
child() - Method in class org.apache.flink.table.expressions.Ceil
 
child() - Method in class org.apache.flink.table.expressions.CharLength
 
child() - Method in class org.apache.flink.table.expressions.Cos
 
child() - Method in class org.apache.flink.table.expressions.Cot
 
child() - Method in class org.apache.flink.table.expressions.Count
 
child() - Method in class org.apache.flink.table.expressions.Degrees
 
child() - Method in class org.apache.flink.table.expressions.Desc
 
child() - Method in class org.apache.flink.table.expressions.Exp
 
child() - Method in class org.apache.flink.table.expressions.Flattening
 
child() - Method in class org.apache.flink.table.expressions.Floor
 
child() - Method in class org.apache.flink.table.expressions.GetCompositeField
 
child() - Method in class org.apache.flink.table.expressions.InitCap
 
child() - Method in class org.apache.flink.table.expressions.IsFalse
 
child() - Method in class org.apache.flink.table.expressions.IsNotFalse
 
child() - Method in class org.apache.flink.table.expressions.IsNotNull
 
child() - Method in class org.apache.flink.table.expressions.IsNotTrue
 
child() - Method in class org.apache.flink.table.expressions.IsNull
 
child() - Method in class org.apache.flink.table.expressions.IsTrue
 
child() - Method in class org.apache.flink.table.expressions.Ln
 
child() - Method in class org.apache.flink.table.expressions.Log10
 
child() - Method in class org.apache.flink.table.expressions.Lower
 
child() - Method in class org.apache.flink.table.expressions.Max
 
child() - Method in class org.apache.flink.table.expressions.Min
 
child() - Method in class org.apache.flink.table.expressions.Not
 
child() - Static method in class org.apache.flink.table.expressions.ProctimeAttribute
 
child() - Method in class org.apache.flink.table.expressions.Quarter
 
child() - Method in class org.apache.flink.table.expressions.Radians
 
child() - Static method in class org.apache.flink.table.expressions.RowtimeAttribute
 
child() - Method in class org.apache.flink.table.expressions.Sign
 
child() - Method in class org.apache.flink.table.expressions.Sin
 
child() - Method in class org.apache.flink.table.expressions.Sqrt
 
child() - Method in class org.apache.flink.table.expressions.StddevPop
 
child() - Method in class org.apache.flink.table.expressions.StddevSamp
 
child() - Method in class org.apache.flink.table.expressions.Sum
 
child() - Method in class org.apache.flink.table.expressions.Sum0
 
child() - Method in class org.apache.flink.table.expressions.Tan
 
child() - Method in class org.apache.flink.table.expressions.TimeAttribute
 
child() - Method in class org.apache.flink.table.expressions.UnaryExpression
 
child() - Method in class org.apache.flink.table.expressions.UnaryMinus
 
child() - Method in class org.apache.flink.table.expressions.UnresolvedAlias
 
child() - Method in class org.apache.flink.table.expressions.Upper
 
child() - Method in class org.apache.flink.table.expressions.VarPop
 
child() - Method in class org.apache.flink.table.expressions.VarSamp
 
child() - Method in class org.apache.flink.table.expressions.WindowEnd
 
child() - Method in class org.apache.flink.table.expressions.WindowStart
 
child() - Method in class org.apache.flink.table.plan.logical.Aggregate
 
child() - Method in class org.apache.flink.table.plan.logical.AliasNode
 
child() - Method in class org.apache.flink.table.plan.logical.Distinct
 
child() - Method in class org.apache.flink.table.plan.logical.Filter
 
child() - Method in class org.apache.flink.table.plan.logical.Limit
 
child() - Method in class org.apache.flink.table.plan.logical.LogicalTableFunctionCall
 
child() - Method in class org.apache.flink.table.plan.logical.Project
 
child() - Method in class org.apache.flink.table.plan.logical.Sort
 
child() - Method in class org.apache.flink.table.plan.logical.UnaryNode
 
child() - Method in class org.apache.flink.table.plan.logical.WindowAggregate
 
children() - Method in class org.apache.flink.ml.nn.QuadTree.Node
 
children() - Method in class org.apache.flink.table.api.CurrentRange
 
children() - Method in class org.apache.flink.table.api.CurrentRow
 
children() - Method in class org.apache.flink.table.api.UnboundedRange
 
children() - Method in class org.apache.flink.table.api.UnboundedRow
 
children() - Static method in class org.apache.flink.table.expressions.Abs
 
children() - Static method in class org.apache.flink.table.expressions.Acos
 
children() - Method in class org.apache.flink.table.expressions.AggFunctionCall
 
children() - Static method in class org.apache.flink.table.expressions.Alias
 
children() - Static method in class org.apache.flink.table.expressions.And
 
children() - Method in class org.apache.flink.table.expressions.ArrayCardinality
 
children() - Method in class org.apache.flink.table.expressions.ArrayConstructor
 
children() - Method in class org.apache.flink.table.expressions.ArrayElement
 
children() - Method in class org.apache.flink.table.expressions.ArrayElementAt
 
children() - Static method in class org.apache.flink.table.expressions.Asc
 
children() - Static method in class org.apache.flink.table.expressions.Asin
 
children() - Static method in class org.apache.flink.table.expressions.Atan
 
children() - Method in class org.apache.flink.table.expressions.Avg
 
children() - Method in class org.apache.flink.table.expressions.BinaryExpression
 
children() - Method in class org.apache.flink.table.expressions.Call
 
children() - Static method in class org.apache.flink.table.expressions.Cast
 
children() - Static method in class org.apache.flink.table.expressions.Ceil
 
children() - Static method in class org.apache.flink.table.expressions.CharLength
 
children() - Static method in class org.apache.flink.table.expressions.Cos
 
children() - Static method in class org.apache.flink.table.expressions.Cot
 
children() - Method in class org.apache.flink.table.expressions.Count
 
children() - Static method in class org.apache.flink.table.expressions.CurrentDate
 
children() - Static method in class org.apache.flink.table.expressions.CurrentTime
 
children() - Static method in class org.apache.flink.table.expressions.CurrentTimestamp
 
children() - Static method in class org.apache.flink.table.expressions.Degrees
 
children() - Static method in class org.apache.flink.table.expressions.Desc
 
children() - Static method in class org.apache.flink.table.expressions.Div
 
children() - Static method in class org.apache.flink.table.expressions.EqualTo
 
children() - Static method in class org.apache.flink.table.expressions.Exp
 
children() - Method in class org.apache.flink.table.expressions.Extract
 
children() - Static method in class org.apache.flink.table.expressions.Flattening
 
children() - Static method in class org.apache.flink.table.expressions.Floor
 
children() - Static method in class org.apache.flink.table.expressions.GetCompositeField
 
children() - Static method in class org.apache.flink.table.expressions.GreaterThan
 
children() - Static method in class org.apache.flink.table.expressions.GreaterThanOrEqual
 
children() - Method in class org.apache.flink.table.expressions.If
 
children() - Static method in class org.apache.flink.table.expressions.InitCap
 
children() - Static method in class org.apache.flink.table.expressions.IsFalse
 
children() - Static method in class org.apache.flink.table.expressions.IsNotFalse
 
children() - Static method in class org.apache.flink.table.expressions.IsNotNull
 
children() - Static method in class org.apache.flink.table.expressions.IsNotTrue
 
children() - Static method in class org.apache.flink.table.expressions.IsNull
 
children() - Static method in class org.apache.flink.table.expressions.IsTrue
 
children() - Method in class org.apache.flink.table.expressions.LeafExpression
 
children() - Static method in class org.apache.flink.table.expressions.LessThan
 
children() - Static method in class org.apache.flink.table.expressions.LessThanOrEqual
 
children() - Static method in class org.apache.flink.table.expressions.Like
 
children() - Static method in class org.apache.flink.table.expressions.Literal
 
children() - Static method in class org.apache.flink.table.expressions.Ln
 
children() - Static method in class org.apache.flink.table.expressions.LocalTime
 
children() - Static method in class org.apache.flink.table.expressions.LocalTimestamp
 
children() - Static method in class org.apache.flink.table.expressions.Log10
 
children() - Static method in class org.apache.flink.table.expressions.Lower
 
children() - Method in class org.apache.flink.table.expressions.Max
 
children() - Method in class org.apache.flink.table.expressions.Min
 
children() - Static method in class org.apache.flink.table.expressions.Minus
 
children() - Static method in class org.apache.flink.table.expressions.Mod
 
children() - Static method in class org.apache.flink.table.expressions.Mul
 
children() - Static method in class org.apache.flink.table.expressions.Not
 
children() - Static method in class org.apache.flink.table.expressions.NotEqualTo
 
children() - Static method in class org.apache.flink.table.expressions.Null
 
children() - Static method in class org.apache.flink.table.expressions.Or
 
children() - Method in class org.apache.flink.table.expressions.OverCall
 
children() - Method in class org.apache.flink.table.expressions.Overlay
 
children() - Static method in class org.apache.flink.table.expressions.Pi
 
children() - Static method in class org.apache.flink.table.expressions.Plus
 
children() - Method in class org.apache.flink.table.expressions.Position
 
children() - Static method in class org.apache.flink.table.expressions.Power
 
children() - Static method in class org.apache.flink.table.expressions.ProctimeAttribute
 
children() - Static method in class org.apache.flink.table.expressions.Quarter
 
children() - Static method in class org.apache.flink.table.expressions.Radians
 
children() - Static method in class org.apache.flink.table.expressions.ResolvedFieldReference
 
children() - Static method in class org.apache.flink.table.expressions.Round
 
children() - Static method in class org.apache.flink.table.expressions.RowtimeAttribute
 
children() - Method in class org.apache.flink.table.expressions.ScalarFunctionCall
 
children() - Static method in class org.apache.flink.table.expressions.Sign
 
children() - Static method in class org.apache.flink.table.expressions.Similar
 
children() - Static method in class org.apache.flink.table.expressions.Sin
 
children() - Static method in class org.apache.flink.table.expressions.Sqrt
 
children() - Method in class org.apache.flink.table.expressions.StddevPop
 
children() - Method in class org.apache.flink.table.expressions.StddevSamp
 
children() - Method in class org.apache.flink.table.expressions.Substring
 
children() - Method in class org.apache.flink.table.expressions.Sum
 
children() - Method in class org.apache.flink.table.expressions.Sum0
 
children() - Static method in class org.apache.flink.table.expressions.SymbolExpression
 
children() - Method in class org.apache.flink.table.expressions.TableFunctionCall
 
children() - Static method in class org.apache.flink.table.expressions.Tan
 
children() - Static method in class org.apache.flink.table.expressions.TemporalCeil
 
children() - Method in class org.apache.flink.table.expressions.TemporalCeilFloor
 
children() - Static method in class org.apache.flink.table.expressions.TemporalFloor
 
children() - Method in class org.apache.flink.table.expressions.TemporalOverlaps
 
children() - Method in class org.apache.flink.table.expressions.Trim
 
children() - Method in class org.apache.flink.table.expressions.UnaryExpression
 
children() - Static method in class org.apache.flink.table.expressions.UnaryMinus
 
children() - Static method in class org.apache.flink.table.expressions.UnresolvedAlias
 
children() - Static method in class org.apache.flink.table.expressions.UnresolvedFieldReference
 
children() - Method in class org.apache.flink.table.expressions.UnresolvedOverCall
 
children() - Static method in class org.apache.flink.table.expressions.Upper
 
children() - Method in class org.apache.flink.table.expressions.VarPop
 
children() - Method in class org.apache.flink.table.expressions.VarSamp
 
children() - Static method in class org.apache.flink.table.expressions.WindowEnd
 
children() - Static method in class org.apache.flink.table.expressions.WindowReference
 
children() - Static method in class org.apache.flink.table.expressions.WindowStart
 
children() - Static method in class org.apache.flink.table.plan.logical.Aggregate
 
children() - Static method in class org.apache.flink.table.plan.logical.AliasNode
 
children() - Method in class org.apache.flink.table.plan.logical.BinaryNode
 
children() - Static method in class org.apache.flink.table.plan.logical.CatalogNode
 
children() - Static method in class org.apache.flink.table.plan.logical.Distinct
 
children() - Static method in class org.apache.flink.table.plan.logical.Filter
 
children() - Static method in class org.apache.flink.table.plan.logical.Intersect
 
children() - Static method in class org.apache.flink.table.plan.logical.Join
 
children() - Method in class org.apache.flink.table.plan.logical.LeafNode
 
children() - Static method in class org.apache.flink.table.plan.logical.Limit
 
children() - Static method in class org.apache.flink.table.plan.logical.LogicalRelNode
 
children() - Static method in class org.apache.flink.table.plan.logical.LogicalTableFunctionCall
 
children() - Static method in class org.apache.flink.table.plan.logical.Minus
 
children() - Static method in class org.apache.flink.table.plan.logical.Project
 
children() - Static method in class org.apache.flink.table.plan.logical.Sort
 
children() - Method in class org.apache.flink.table.plan.logical.UnaryNode
 
children() - Static method in class org.apache.flink.table.plan.logical.Union
 
children() - Static method in class org.apache.flink.table.plan.logical.WindowAggregate
 
children() - Method in class org.apache.flink.table.plan.TreeNode
List of child nodes that should be considered when doing transformations.
childrenAccept(RelVisitor) - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
childrenAccept(RelVisitor) - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
childrenAccept(RelVisitor) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
childrenAccept(RelVisitor) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
childrenAccept(RelVisitor) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
childrenAccept(RelVisitor) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
childrenAccept(RelVisitor) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
childrenAccept(RelVisitor) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
childrenAccept(RelVisitor) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
childrenAccept(RelVisitor) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
childrenAccept(RelVisitor) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
childrenAccept(RelVisitor) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
childrenAccept(RelVisitor) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
childrenAccept(RelVisitor) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
childrenAccept(RelVisitor) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
childrenAccept(RelVisitor) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
childrenValid() - Static method in class org.apache.flink.table.api.CurrentRange
 
childrenValid() - Static method in class org.apache.flink.table.api.CurrentRow
 
childrenValid() - Static method in class org.apache.flink.table.api.UnboundedRange
 
childrenValid() - Static method in class org.apache.flink.table.api.UnboundedRow
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Abs
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Acos
 
childrenValid() - Static method in class org.apache.flink.table.expressions.AggFunctionCall
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Alias
 
childrenValid() - Static method in class org.apache.flink.table.expressions.And
 
childrenValid() - Static method in class org.apache.flink.table.expressions.ArrayCardinality
 
childrenValid() - Static method in class org.apache.flink.table.expressions.ArrayConstructor
 
childrenValid() - Static method in class org.apache.flink.table.expressions.ArrayElement
 
childrenValid() - Static method in class org.apache.flink.table.expressions.ArrayElementAt
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Asc
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Asin
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Atan
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Avg
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Call
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Cast
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Ceil
 
childrenValid() - Static method in class org.apache.flink.table.expressions.CharLength
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Cos
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Cot
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Count
 
childrenValid() - Static method in class org.apache.flink.table.expressions.CurrentDate
 
childrenValid() - Static method in class org.apache.flink.table.expressions.CurrentTime
 
childrenValid() - Static method in class org.apache.flink.table.expressions.CurrentTimestamp
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Degrees
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Desc
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Div
 
childrenValid() - Static method in class org.apache.flink.table.expressions.EqualTo
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Exp
 
childrenValid() - Method in class org.apache.flink.table.expressions.Expression
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Extract
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Flattening
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Floor
 
childrenValid() - Static method in class org.apache.flink.table.expressions.GetCompositeField
 
childrenValid() - Static method in class org.apache.flink.table.expressions.GreaterThan
 
childrenValid() - Static method in class org.apache.flink.table.expressions.GreaterThanOrEqual
 
childrenValid() - Static method in class org.apache.flink.table.expressions.If
 
childrenValid() - Static method in class org.apache.flink.table.expressions.InitCap
 
childrenValid() - Static method in class org.apache.flink.table.expressions.IsFalse
 
childrenValid() - Static method in class org.apache.flink.table.expressions.IsNotFalse
 
childrenValid() - Static method in class org.apache.flink.table.expressions.IsNotNull
 
childrenValid() - Static method in class org.apache.flink.table.expressions.IsNotTrue
 
childrenValid() - Static method in class org.apache.flink.table.expressions.IsNull
 
childrenValid() - Static method in class org.apache.flink.table.expressions.IsTrue
 
childrenValid() - Static method in class org.apache.flink.table.expressions.LessThan
 
childrenValid() - Static method in class org.apache.flink.table.expressions.LessThanOrEqual
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Like
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Literal
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Ln
 
childrenValid() - Static method in class org.apache.flink.table.expressions.LocalTime
 
childrenValid() - Static method in class org.apache.flink.table.expressions.LocalTimestamp
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Log10
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Lower
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Max
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Min
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Minus
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Mod
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Mul
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Not
 
childrenValid() - Static method in class org.apache.flink.table.expressions.NotEqualTo
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Null
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Or
 
childrenValid() - Static method in class org.apache.flink.table.expressions.OverCall
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Overlay
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Pi
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Plus
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Position
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Power
 
childrenValid() - Static method in class org.apache.flink.table.expressions.ProctimeAttribute
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Quarter
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Radians
 
childrenValid() - Static method in class org.apache.flink.table.expressions.ResolvedFieldReference
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Round
 
childrenValid() - Static method in class org.apache.flink.table.expressions.RowtimeAttribute
 
childrenValid() - Static method in class org.apache.flink.table.expressions.ScalarFunctionCall
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Sign
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Similar
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Sin
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Sqrt
 
childrenValid() - Static method in class org.apache.flink.table.expressions.StddevPop
 
childrenValid() - Static method in class org.apache.flink.table.expressions.StddevSamp
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Substring
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Sum
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Sum0
 
childrenValid() - Static method in class org.apache.flink.table.expressions.SymbolExpression
 
childrenValid() - Static method in class org.apache.flink.table.expressions.TableFunctionCall
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Tan
 
childrenValid() - Static method in class org.apache.flink.table.expressions.TemporalCeil
 
childrenValid() - Static method in class org.apache.flink.table.expressions.TemporalFloor
 
childrenValid() - Static method in class org.apache.flink.table.expressions.TemporalOverlaps
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Trim
 
childrenValid() - Static method in class org.apache.flink.table.expressions.UnaryMinus
 
childrenValid() - Static method in class org.apache.flink.table.expressions.UnresolvedAlias
 
childrenValid() - Static method in class org.apache.flink.table.expressions.UnresolvedFieldReference
 
childrenValid() - Static method in class org.apache.flink.table.expressions.UnresolvedOverCall
 
childrenValid() - Static method in class org.apache.flink.table.expressions.Upper
 
childrenValid() - Static method in class org.apache.flink.table.expressions.VarPop
 
childrenValid() - Static method in class org.apache.flink.table.expressions.VarSamp
 
childrenValid() - Static method in class org.apache.flink.table.expressions.WindowEnd
 
childrenValid() - Static method in class org.apache.flink.table.expressions.WindowReference
 
childrenValid() - Static method in class org.apache.flink.table.expressions.WindowStart
 
ChoiceParameter - Class in org.apache.flink.graph.drivers.parameter
A Parameter storing a list of String choices and parsing the user's configured selection.
ChoiceParameter(ParameterizedBase, String) - Constructor for class org.apache.flink.graph.drivers.parameter.ChoiceParameter
Set the parameter name and add this parameter to the list of parameters stored by owner.
choices(String...) - Method in class org.apache.flink.api.java.utils.Option
Restrict the list of possible values of the parameter.
CirculantGraph - Class in org.apache.flink.graph.drivers.input
Generate a CirculantGraph.
CirculantGraph() - Constructor for class org.apache.flink.graph.drivers.input.CirculantGraph
 
CirculantGraph - Class in org.apache.flink.graph.generator
 
CirculantGraph(ExecutionEnvironment, long) - Constructor for class org.apache.flink.graph.generator.CirculantGraph
An oriented Graph with n vertices where each vertex vi is connected to vertex v(i+j)%n for each configured offset j.
CirculantGraph.OffsetRange - Class in org.apache.flink.graph.generator
Stores the start offset and length configuration for an offset range.
CircularElement() - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.CircularElement
 
CircularElement(int, InMemorySorter<E>, List<MemorySegment>) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.CircularElement
 
CircularQueues() - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.CircularQueues
 
CircularQueues(int) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.CircularQueues
 
classLoader - Variable in class org.apache.flink.util.InstantiationUtil.ClassLoaderObjectInputStream
 
ClassLoaderObjectInputStream(InputStream, ClassLoader) - Constructor for class org.apache.flink.migration.util.MigrationInstantiationUtil.ClassLoaderObjectInputStream
 
ClassLoaderObjectInputStream(InputStream, ClassLoader) - Constructor for class org.apache.flink.util.InstantiationUtil.ClassLoaderObjectInputStream
 
ClassLoaderUtil - Class in org.apache.flink.runtime.util
Utilities for information with respect to class loaders, specifically class loaders for the dynamic loading of user defined classes.
ClassloadingProps - Class in org.apache.flink.runtime.jobmaster.message
The response of classloading props request to JobManager.
ClassloadingProps(int, Collection<BlobKey>, Collection<URL>) - Constructor for class org.apache.flink.runtime.jobmaster.message.ClassloadingProps
Constructor of ClassloadingProps.
ClassloadingProps(Integer, Collection<BlobKey>, Collection<URL>) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.ClassloadingProps
 
ClassloadingProps$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.ClassloadingProps$
 
CLASSPATH_INCLUDE_USER_JAR - Static variable in class org.apache.flink.yarn.configuration.YarnConfigOptions
Defines whether user-jars are included in the system class path for per-job-clusters as well as their positioning in the path.
classpathsToAttach - Variable in class org.apache.flink.client.program.ContextEnvironment
 
clazz() - Method in class org.apache.flink.api.scala.typeutils.EitherTypeInfo
 
clazz() - Method in class org.apache.flink.api.scala.typeutils.EnumValueTypeInfo
 
clazz() - Method in class org.apache.flink.api.scala.typeutils.TraversableTypeInfo
 
clazz - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraPojoSink
 
clazz() - Method in class org.apache.flink.table.typeutils.InternalTypeInfo
 
clazz() - Static method in class org.apache.flink.table.typeutils.RowIntervalTypeInfo
 
clazz() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
 
clean(Object, boolean) - Static method in class org.apache.flink.api.java.ClosureCleaner
Tries to clean the closure of the given object, if the object is a non-static inner class.
clean(F) - Method in class org.apache.flink.api.java.DataSet
 
clean(Object, boolean) - Method in class org.apache.flink.api.scala.ClosureCleaner$
 
clean(Object, boolean) - Static method in class org.apache.flink.api.scala.ClosureCleaner
 
clean(F, boolean) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
clean(F, boolean) - Method in class org.apache.flink.api.scala.DataSet
Clean a closure to make it ready to serialized and send to tasks (removes unreferenced variables in $outer's, updates REPL variables) If checkSerializable is set, clean will also proactively check to see if f is serializable and throw a SparkException if not.
clean(F, boolean) - Method in class org.apache.flink.graph.scala.Graph
 
clean(F) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Invokes the ClosureCleaner on the given function if closure cleaning is enabled in the ExecutionConfig.
clean(F) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Returns a "closure-cleaned" version of the given function.
clean(F) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Returns a "closure-cleaned" version of the given function.
clean(F) - Method in class org.apache.flink.streaming.api.scala.CoGroupedStreams
Returns a "closure-cleaned" version of the given function.
clean(F) - Method in class org.apache.flink.streaming.api.scala.ConnectedStreams
Returns a "closure-cleaned" version of the given function.
clean(F) - Method in class org.apache.flink.streaming.api.scala.DataStream
Returns a "closure-cleaned" version of the given function.
clean(F) - Method in class org.apache.flink.streaming.api.scala.JoinedStreams
Returns a "closure-cleaned" version of the given function.
clean(F) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Returns a "closure-cleaned" version of the given function.
clean$default$2() - Static method in class org.apache.flink.api.scala.CrossDataSet
 
cleanDirectory(File) - Static method in class org.apache.flink.util.FileUtils
Removes all files contained within a directory, without removing the directory itself.
cleanFile(String) - Method in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
Creates target file if it does not exist, cleans it if it exists.
cleanup() - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
 
cleanup() - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
cleanup() - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
 
cleanup() - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
 
cleanup() - Method in class org.apache.flink.runtime.operators.AllReduceDriver
 
cleanup() - Method in class org.apache.flink.runtime.operators.CoGroupDriver
 
cleanup() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
 
cleanup() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
 
cleanup() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
 
cleanup() - Method in class org.apache.flink.runtime.operators.CrossDriver
 
cleanup() - Method in interface org.apache.flink.runtime.operators.Driver
This method is invoked in any case (clean termination and exception) at the end of the tasks operation.
cleanup() - Method in class org.apache.flink.runtime.operators.FlatMapDriver
 
cleanup() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
 
cleanup() - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
 
cleanup() - Method in class org.apache.flink.runtime.operators.JoinDriver
 
cleanup() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
 
cleanup() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
 
cleanup() - Method in class org.apache.flink.runtime.operators.MapDriver
 
cleanup() - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
 
cleanup() - Method in class org.apache.flink.runtime.operators.NoOpDriver
 
cleanup() - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
 
cleanup() - Method in class org.apache.flink.runtime.operators.ReduceDriver
 
cleanup() - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
 
cleanup() - Method in class org.apache.flink.storm.exclamation.operators.ExclamationBolt
 
cleanup() - Method in class org.apache.flink.storm.util.AbstractBoltSink
 
cleanup() - Method in class org.apache.flink.storm.util.BoltFileSink
 
cleanup() - Method in class org.apache.flink.storm.wordcount.operators.BoltCounter
 
cleanup() - Method in class org.apache.flink.storm.wordcount.operators.BoltCounterByName
 
cleanup() - Method in class org.apache.flink.storm.wordcount.operators.BoltTokenizer
 
cleanup() - Method in class org.apache.flink.storm.wordcount.operators.BoltTokenizerByName
 
cleanup() - Method in class org.apache.flink.streaming.connectors.elasticsearch.Elasticsearch1ApiCallBridge
 
cleanup() - Method in interface org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchApiCallBridge
Perform any necessary state cleanup.
cleanup() - Method in class org.apache.flink.streaming.connectors.elasticsearch2.Elasticsearch2ApiCallBridge
 
cleanup() - Method in class org.apache.flink.streaming.connectors.elasticsearch5.Elasticsearch5ApiCallBridge
 
cleanup() - Method in class org.apache.flink.streaming.runtime.io.BarrierBuffer
 
cleanup() - Method in class org.apache.flink.streaming.runtime.io.BarrierTracker
 
cleanup() - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller.SpilledBufferOrEventSequence
Cleans up all file resources held by this spilled sequence.
cleanup() - Method in interface org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
Cleans up all internally held resources.
cleanup() - Method in class org.apache.flink.streaming.runtime.io.StreamInputProcessor
 
cleanup() - Method in class org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor
 
cleanup() - Method in class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
 
cleanup() - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
 
cleanup() - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
 
cleanup() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
cleanup() - Method in class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
 
cleanup() - Static method in class org.apache.flink.test.util.SecureTestEnvironment
 
cleanup(Logger, AutoCloseable...) - Static method in class org.apache.flink.util.IOUtils
Close the AutoCloseable objects and ignore any Exception or null pointers.
cleanUpOperatorStatsCache() - Method in class org.apache.flink.runtime.webmonitor.BackPressureStatsTracker
Cleans up the operator stats cache if it contains timed out entries.
cleanupState(Seq<State>) - Method in class org.apache.flink.table.runtime.aggregate.ProcessFunctionWithCleanupState
 
CleanupWhenUnsuccessful - Interface in org.apache.flink.api.common.io
OutputFormats may implement this interface to run a cleanup hook when the execution is not successful.
clear() - Method in interface org.apache.flink.api.common.state.State
Removes the value mapped under the current key.
clear() - Method in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
 
clear() - Method in class org.apache.flink.contrib.streaming.state.RocksDBMapState
 
clear() - Method in class org.apache.flink.examples.java.clustering.KMeans.Point
 
clear() - Method in interface org.apache.flink.examples.scala.clustering.KMeans.Coordinate
 
clear() - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
 
clear() - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
 
clear() - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
 
clear() - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
 
clear() - Method in interface org.apache.flink.graph.types.valuearray.ValueArray
Resets the array to the empty state.
clear() - Method in class org.apache.flink.runtime.io.network.api.serialization.AdaptiveSpanningRecordDeserializer
 
clear() - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
 
clear() - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
Resets the target buffer to null and resets internal state set up for the record to serialize.
clear() - Method in class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
 
clear() - Method in class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
 
clear() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
clear() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
Clears the internal state of the view.
clear() - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
Clears the internal state.
clear() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
Removes all entries from the PriorityQueue.
clear() - Method in class org.apache.flink.runtime.operators.util.BitSet
Clear the bit set.
clear() - Method in class org.apache.flink.runtime.operators.util.BloomFilter.BitSet
Clear the bit set.
clear() - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
Stop and clear the currently registered job leader id listeners.
clear() - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
 
clear() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
Removes all tasks from this task slot.
clear() - Method in class org.apache.flink.runtime.util.DataOutputSerializer
 
clear() - Method in class org.apache.flink.runtime.util.EvictingBoundedList
 
clear() - Method in class org.apache.flink.runtime.util.IntArrayList
 
clear() - Method in class org.apache.flink.runtime.util.LongArrayList
 
clear() - Method in class org.apache.flink.storm.util.StormConfig
 
clear(ProcessAllWindowFunction<T, R, W>.Context) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessAllWindowFunction
Deprecated.
 
clear(ProcessWindowFunction<T, R, K, W>.Context) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessWindowFunction
Deprecated.
 
clear(ProcessAllWindowFunction<IN, OUT, W>.Context) - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction
Deletes any state in the Context when the Window is purged.
clear(ProcessWindowFunction<IN, OUT, KEY, W>.Context) - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction
Deletes any state in the Context when the Window is purged.
clear(ProcessAllWindowFunction<T, R, W>.Context) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
 
clear(ProcessWindowFunction<T, R, K, W>.Context) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
 
clear() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
Remove all registered nodes etc.
clear(ProcessAllWindowFunction<IN, OUT, W>.Context) - Method in class org.apache.flink.streaming.api.scala.function.ProcessAllWindowFunction
Deletes any state in the ProcessAllWindowFunction.Context when the Window is purged.
clear(ProcessWindowFunction<IN, OUT, KEY, W>.Context) - Method in class org.apache.flink.streaming.api.scala.function.ProcessWindowFunction
Deletes any state in the ProcessWindowFunction.Context when the Window is purged.
clear(ProcessAllWindowFunction<IN, OUT, W>.Context) - Method in class org.apache.flink.streaming.api.scala.function.util.ScalaProcessAllWindowFunctionWrapper
 
clear(ProcessWindowFunction<IN, OUT, KEY, W>.Context) - Method in class org.apache.flink.streaming.api.scala.function.util.ScalaProcessWindowFunctionWrapper
 
clear(GlobalWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
 
clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
 
clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
 
clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
 
clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
 
clear(TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
 
clear(TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
 
clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
 
clear(W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.Trigger
Clears any state that the trigger might still hold for the given window.
clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
 
clear(W, InternalWindowFunction.InternalWindowContext) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction
Deletes any state in the Context when the Window is purged.
clear() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
clear() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
 
clear() - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
clear(GlobalWindow, Trigger.TriggerContext) - Method in class org.apache.flink.table.runtime.triggers.StateCleaningCountTrigger
 
clear() - Method in class org.apache.flink.table.validate.FunctionCatalog
Drop all registered functions.
clear() - Method in class org.apache.flink.types.ListValue
 
clear() - Method in class org.apache.flink.types.MapValue
 
clear() - Method in class org.apache.flink.types.Record
Clears the record.
clear() - Method in class org.apache.flink.util.UnionIterator
 
clearAll() - Method in class org.apache.flink.runtime.io.network.TaskEventDispatcher
 
clearAllBroadcastVariables() - Method in class org.apache.flink.api.common.functions.util.RuntimeUDFContext
 
clearAllBroadcastVariables() - Method in class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
 
clearAllMemory(List<MemorySegment>) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
 
clearAllMemory(List<MemorySegment>) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
releases all of the partition's segments (pages and overflow buckets)
clearAllMemory(List<MemorySegment>) - Method in class org.apache.flink.runtime.operators.hash.ReOpenableHashPartition
 
clearBroadcastVariable(String) - Method in class org.apache.flink.api.common.functions.util.RuntimeUDFContext
 
clearBroadcastVariable(String) - Method in class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
 
clearBuffers() - Method in interface org.apache.flink.runtime.io.network.api.reader.MutableReader
 
clearBuffers() - Method in class org.apache.flink.runtime.io.network.api.reader.MutableRecordReader
 
clearBuffers() - Method in interface org.apache.flink.runtime.io.network.api.reader.Reader
 
clearBuffers() - Method in class org.apache.flink.runtime.io.network.api.reader.RecordReader
 
clearBuffers() - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
 
clearBuffers() - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
clearContainerMappingMarkedFields() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
clearCurrentBuffer() - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
Resets the target buffer to null.
clearCurrentBuffer() - Method in class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
 
clearFirstInput() - Method in class org.apache.flink.api.common.operators.DualInputOperator
Clears this operator's first input.
clearInputs() - Method in class org.apache.flink.api.common.operators.SingleInputOperator
Removes all inputs.
clearInterestingProperties() - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
 
clearInterestingProperties() - Method in class org.apache.flink.optimizer.dag.DagConnection
 
clearInterestingProperties() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
clearInterestingProperties() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
 
clearJob(JobID) - Method in class org.apache.flink.runtime.highavailability.FsNegativeRunningJobsRegistry
 
clearJob(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneRunningJobsRegistry
 
clearJob(JobID) - Method in interface org.apache.flink.runtime.highavailability.RunningJobsRegistry
Clear job state form the registry, usually called after job finish
clearJob(JobID) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperRunningJobsRegistry
 
clearLeader() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
clearPartitions() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
This method clears all partitions currently residing (partially) in memory.
clearReaders(MutableReader<?>[]) - Static method in class org.apache.flink.runtime.operators.BatchTask
 
clearReferences() - Method in class org.apache.flink.cep.NonDuplicatingTypeSerializer
Clears the data structures containing the already serialized/deserialized objects.
clearSecondInput() - Method in class org.apache.flink.api.common.operators.DualInputOperator
Clears this operator's second input.
clearTaskAssignment() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
 
clearUniqueFieldCombinations() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
 
clearUniqueFields() - Method in class org.apache.flink.api.common.operators.CompilerHints
 
clearUniqueFieldSets() - Method in class org.apache.flink.optimizer.dataproperties.LocalProperties
 
clearWriters(List<RecordWriter<?>>) - Static method in class org.apache.flink.runtime.operators.BatchTask
 
CliArgsException - Exception in org.apache.flink.client.cli
Special exception that is thrown when the command line parsing fails.
CliArgsException(String) - Constructor for exception org.apache.flink.client.cli.CliArgsException
 
client - Variable in class org.apache.flink.client.program.ContextEnvironment
 
client - Variable in class org.apache.flink.runtime.client.JobClientActor
The client which the actor is responsible for
CLIENT_BUFFER_SIZE - Static variable in class org.apache.flink.streaming.connectors.twitter.TwitterSource
 
CLIENT_CONNECT_TIMEOUT_SECONDS - Static variable in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
CLIENT_HOSTS - Static variable in class org.apache.flink.streaming.connectors.twitter.TwitterSource
 
CLIENT_LOOKUP_RETRIES - Static variable in class org.apache.flink.configuration.QueryableStateOptions
Number of retries on location lookup failures.
CLIENT_LOOKUP_RETRY_DELAY - Static variable in class org.apache.flink.configuration.QueryableStateOptions
Retry delay on location lookup failures (millis).
CLIENT_NAME - Static variable in class org.apache.flink.streaming.connectors.twitter.TwitterSource
 
CLIENT_NETWORK_THREADS - Static variable in class org.apache.flink.configuration.QueryableStateOptions
Number of network (event loop) threads for the KvState client (0 => Use number of available cores).
clientConfig() - Method in class org.apache.flink.api.scala.FlinkILoop
 
clientConfiguration - Variable in class org.apache.flink.api.java.RemoteEnvironment
The configuration used by the client that connects to the cluster
clients() - Method in class org.apache.flink.runtime.jobmanager.JobInfo
 
ClientSecurityConfiguration(String, String) - Constructor for class org.apache.flink.test.util.TestingSecurityContext.ClientSecurityConfiguration
 
ClientUtils - Class in org.apache.flink.client
A class that provides some utility methods
ClientUtils() - Constructor for class org.apache.flink.client.ClientUtils
 
CliFrontend - Class in org.apache.flink.client
Implementation of a simple command line frontend for executing programs.
CliFrontend() - Constructor for class org.apache.flink.client.CliFrontend
 
CliFrontend(String) - Constructor for class org.apache.flink.client.CliFrontend
 
CliFrontendParser - Class in org.apache.flink.client.cli
A simple command line parser (based on Apache Commons CLI) that extracts command line options.
CliFrontendParser() - Constructor for class org.apache.flink.client.cli.CliFrontendParser
 
Clock - Class in org.apache.flink.runtime.util.clock
A clock that gives access to time.
Clock() - Constructor for class org.apache.flink.runtime.util.clock.Clock
 
Clock - Interface in org.apache.flink.streaming.connectors.fs
A clock that can provide the current time.
clone() - Method in interface org.apache.flink.api.common.accumulators.Accumulator
Duplicates the accumulator.
clone() - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
 
clone() - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
 
clone() - Method in class org.apache.flink.api.common.accumulators.DoubleMaximum
 
clone() - Method in class org.apache.flink.api.common.accumulators.DoubleMinimum
 
clone() - Method in class org.apache.flink.api.common.accumulators.Histogram
 
clone() - Method in class org.apache.flink.api.common.accumulators.IntCounter
 
clone() - Method in class org.apache.flink.api.common.accumulators.IntMaximum
 
clone() - Method in class org.apache.flink.api.common.accumulators.IntMinimum
 
clone() - Method in class org.apache.flink.api.common.accumulators.ListAccumulator
 
clone() - Method in class org.apache.flink.api.common.accumulators.LongCounter
 
clone() - Method in class org.apache.flink.api.common.accumulators.LongMaximum
 
clone() - Method in class org.apache.flink.api.common.accumulators.LongMinimum
 
clone() - Method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
clone() - Method in class org.apache.flink.api.common.operators.Ordering
 
clone() - Method in class org.apache.flink.api.common.operators.util.FieldSet
Since instances of FieldSet are strictly immutable, this method does not actually clone, but it only returns the original instance.
clone() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
 
clone() - Method in class org.apache.flink.api.java.utils.ParameterTool
 
clone() - Method in class org.apache.flink.api.scala.typeutils.CaseClassSerializer
 
clone() - Method in class org.apache.flink.configuration.Configuration
 
clone() - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
clone() - Method in class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator.VectorAccumulator
 
clone() - Method in class org.apache.flink.graph.asm.dataset.ChecksumHashCode.Checksum
 
clone() - Method in class org.apache.flink.optimizer.costs.Costs
 
clone() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
 
clone() - Method in class org.apache.flink.optimizer.dataproperties.InterestingProperties
 
clone() - Method in class org.apache.flink.optimizer.dataproperties.LocalProperties
 
clone() - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
 
clone() - Method in class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
 
clone() - Method in class org.apache.flink.optimizer.plan.Channel
 
clone() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification
 
clone(T) - Static method in class org.apache.flink.util.InstantiationUtil
Clones the given serializable object using Java serialization.
clone(T, ClassLoader) - Static method in class org.apache.flink.util.InstantiationUtil
Clones the given serializable object using Java serialization, using the given classloader to resolve the cloned classes.
ClosableBlockingQueue<E> - Class in org.apache.flink.streaming.connectors.kafka.internals
A special form of blocking queue with two additions: The queue can be closed atomically when empty.
ClosableBlockingQueue() - Constructor for class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
Creates a new empty queue.
ClosableBlockingQueue(int) - Constructor for class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
Creates a new empty queue, reserving space for at least the specified number of elements.
ClosableBlockingQueue(Collection<? extends E>) - Constructor for class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
Creates a new queue that contains the given elements.
close() - Method in class org.apache.flink.addons.hbase.AbstractTableInputFormat
 
close() - Method in class org.apache.flink.api.avro.FSDataInputStreamWrapper
 
close() - Method in class org.apache.flink.api.common.functions.AbstractRichFunction
 
close() - Method in interface org.apache.flink.api.common.functions.RichFunction
Tear-down method for the user code.
close() - Method in class org.apache.flink.api.common.functions.util.CopyingListCollector
 
close() - Method in class org.apache.flink.api.common.functions.util.ListCollector
 
close() - Method in class org.apache.flink.api.common.io.BinaryOutputFormat.BlockBasedOutput
 
close() - Method in class org.apache.flink.api.common.io.BinaryOutputFormat
 
close() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
Closes the input by releasing all buffers and closing the file input stream.
close() - Method in class org.apache.flink.api.common.io.FileInputFormat
Closes the file input stream of the input format.
close() - Method in class org.apache.flink.api.common.io.FileOutputFormat
 
close() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
close() - Method in class org.apache.flink.api.common.io.GenericInputFormat
 
close() - Method in interface org.apache.flink.api.common.io.InputFormat
Method that marks the end of the life-cycle of an input split.
close() - Method in class org.apache.flink.api.common.io.InputStreamFSInputWrapper
 
close() - Method in interface org.apache.flink.api.common.io.OutputFormat
Method that marks the end of the life-cycle of parallel output instance.
close() - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
 
close() - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
close() - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
commit the task by moving the output file out from the temporary directory.
close() - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
close() - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
commit the task by moving the output file out from the temporary directory.
close() - Method in class org.apache.flink.api.java.io.AvroOutputFormat
 
close() - Method in class org.apache.flink.api.java.io.CsvOutputFormat
 
close() - Method in class org.apache.flink.api.java.io.DiscardingOutputFormat
 
close() - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat
Closes all resources used.
close() - Method in class org.apache.flink.api.java.io.jdbc.JDBCOutputFormat
Executes prepared statement and closes all resources of this instance.
close() - Method in class org.apache.flink.api.java.io.LocalCollectionOutputFormat
 
close() - Method in class org.apache.flink.api.java.io.PrintingOutputFormat
 
close() - Method in class org.apache.flink.api.java.operators.translation.Tuple3WrappingCollector
 
close() - Method in class org.apache.flink.api.java.operators.translation.TupleWrappingCollector
 
close() - Method in class org.apache.flink.api.java.operators.translation.WrappingFunction
 
close() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCodeHelper
 
close() - Method in class org.apache.flink.api.java.Utils.CollectHelper
 
close() - Method in class org.apache.flink.api.java.Utils.CountHelper
 
close() - Method in class org.apache.flink.api.scala.operators.ScalaCsvOutputFormat
 
close() - Method in class org.apache.flink.batch.connectors.cassandra.CassandraInputFormat
Closes all resources used.
close() - Method in class org.apache.flink.batch.connectors.cassandra.CassandraOutputFormat
Closes all resources used.
close() - Method in class org.apache.flink.core.fs.AbstractMultiFSDataInputStream
 
close() - Method in class org.apache.flink.core.fs.ClosingFSDataInputStream
 
close() - Method in class org.apache.flink.core.fs.ClosingFSDataOutputStream
 
close() - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
 
close() - Method in class org.apache.flink.core.fs.FSDataOutputStream
Closes the output stream.
close() - Method in class org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
close() - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
 
close() - Method in class org.apache.flink.core.fs.local.LocalDataOutputStream
 
close() - Method in class org.apache.flink.core.fs.SafetyNetCloseableRegistry
 
close() - Method in class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
 
close() - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
close() - Method in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
 
close() - Method in class org.apache.flink.examples.java.distcp.FileCopyTaskInputFormat
 
close() - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
 
close(boolean) - Method in interface org.apache.flink.mesos.runtime.clusterframework.services.MesosServices
Closes all state maintained by the mesos services implementation.
close(boolean) - Method in class org.apache.flink.mesos.runtime.clusterframework.services.StandaloneMesosServices
 
close(boolean) - Method in class org.apache.flink.mesos.runtime.clusterframework.services.ZooKeeperMesosServices
 
close() - Method in class org.apache.flink.metrics.datadog.DatadogHttpClient
 
close() - Method in class org.apache.flink.metrics.datadog.DatadogHttpReporter
 
close() - Method in class org.apache.flink.metrics.jmx.JMXReporter
 
close() - Method in interface org.apache.flink.metrics.reporter.MetricReporter
Closes this reporter.
close() - Method in class org.apache.flink.metrics.statsd.StatsDReporter
 
close() - Method in class org.apache.flink.migration.contrib.streaming.state.RocksDBStateBackend.FinalFullyAsyncSnapshot
Deprecated.
 
close() - Method in class org.apache.flink.migration.runtime.state.AbstractCloseableHandle
Deprecated.
Closes the handle.
close() - Method in class org.apache.flink.migration.runtime.state.AbstractStateBackend.DataInputViewHandle
Deprecated.
 
close() - Method in class org.apache.flink.migration.runtime.state.memory.AbstractMemStateSnapshot
Deprecated.
 
close() - Method in class org.apache.flink.migration.streaming.runtime.tasks.StreamTaskState
Deprecated.
 
close() - Method in class org.apache.flink.migration.streaming.runtime.tasks.StreamTaskStateList
Deprecated.
 
close() - Method in class org.apache.flink.python.api.functions.PythonCoGroup
Closes this function.
close() - Method in class org.apache.flink.python.api.functions.PythonMapPartition
Closes this function.
close() - Method in class org.apache.flink.python.api.streaming.data.PythonReceiver
 
close() - Method in class org.apache.flink.python.api.streaming.data.PythonSender
 
close() - Method in class org.apache.flink.python.api.streaming.data.PythonStreamer
Closes this streamer.
close() - Method in class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
 
close() - Method in class org.apache.flink.runtime.blob.BlobCache
 
close() - Method in class org.apache.flink.runtime.blob.BlobClient
 
close() - Method in class org.apache.flink.runtime.blob.BlobServer
Shuts down the BLOB server.
close() - Method in class org.apache.flink.runtime.blob.FileSystemBlobStore
 
close() - Method in class org.apache.flink.runtime.blob.VoidBlobStore
 
close() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
 
close() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataOutputStream
 
close() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
Closes the high availability services, releasing all resources.
close() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
 
close() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
 
close() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
close() - Method in class org.apache.flink.runtime.io.disk.FileChannelInputView
 
close() - Method in class org.apache.flink.runtime.io.disk.FileChannelOutputView
Closes this output, writing pending data and releasing the memory.
close() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
 
close() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
Closes the channel and waits until all pending asynchronous requests are processed.
close() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
Closes this InputView, closing the underlying reader and returning all memory segments.
close() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
Closes this OutputView, closing the underlying writer and returning all memory segments.
close() - Method in interface org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
Closes the channel.
close() - Method in class org.apache.flink.runtime.io.disk.iomanager.RequestQueue
Closes this request queue.
close() - Method in class org.apache.flink.runtime.io.disk.iomanager.SynchronousFileIOChannel
 
close() - Method in class org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
 
close() - Method in class org.apache.flink.runtime.io.disk.SpillingBuffer
 
close(RemoteInputChannel) - Method in class org.apache.flink.runtime.io.network.netty.PartitionRequestClient
 
close() - Method in class org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
 
close() - Method in class org.apache.flink.runtime.iterative.io.SolutionSetFastUpdateOutputCollector
 
close() - Method in class org.apache.flink.runtime.iterative.io.SolutionSetObjectsUpdateOutputCollector
 
close() - Method in class org.apache.flink.runtime.iterative.io.SolutionSetUpdateOutputCollector
 
close() - Method in class org.apache.flink.runtime.iterative.io.WorksetUpdateOutputCollector
 
close() - Method in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricDumpSerializer
 
close() - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
close() - Method in class org.apache.flink.runtime.metrics.groups.ComponentMetricGroup
Closes the component group by removing and closing all metrics and subgroups (inherited from AbstractMetricGroup), plus closing and removing all dedicated component subgroups.
close() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
close() - Method in class org.apache.flink.runtime.minicluster.StandaloneMiniCluster
 
close() - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
 
close() - Method in class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
 
close() - Method in class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
 
close() - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
 
close() - Method in class org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
 
close() - Method in class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
 
close() - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
 
close() - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
Closes the hash table.
close() - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
Closes the hash table.
close() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
 
close() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
Closes the hash table.
close() - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstHashJoinIterator
 
close() - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondHashJoinIterator
 
close() - Method in class org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
 
close() - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildFirstHashJoinIterator
 
close() - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildSecondHashJoinIterator
 
close() - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
 
close() - Method in class org.apache.flink.runtime.operators.resettable.BlockResettableMutableObjectIterator
 
close() - Method in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
close() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
close() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
close() - Method in class org.apache.flink.runtime.operators.shipping.OutputCollector
 
close() - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
close() - Method in class org.apache.flink.runtime.operators.sort.LargeRecordHandler
Closes all structures and deletes all temporary files.
close() - Method in class org.apache.flink.runtime.operators.sort.NonReusingSortMergeCoGroupIterator
 
close() - Method in class org.apache.flink.runtime.operators.sort.ReusingSortMergeCoGroupIterator
 
close() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
Shuts down all the threads initiated by this sort/merger.
close() - Method in class org.apache.flink.runtime.operators.TempBarrier
 
close() - Method in interface org.apache.flink.runtime.operators.util.CoGroupTaskIterator
General-purpose close method.
close() - Method in interface org.apache.flink.runtime.operators.util.JoinTaskIterator
General-purpose close method.
close() - Method in class org.apache.flink.runtime.operators.util.metrics.CountingCollector
 
close() - Method in class org.apache.flink.runtime.operators.util.SimpleCloseableInputProvider
 
close() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
close connection
close() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Closes the slot manager.
close() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
close() - Method in class org.apache.flink.runtime.state.BoundedInputStream
 
close() - Method in interface org.apache.flink.runtime.state.CheckpointStreamFactory
Closes the stream factory, releasing all internal resources, but does not delete any persistent checkpoint data.
close() - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
 
close() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory
 
close() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
If the stream is only closed, we remove the produced file (cleanup through the auto close feature, for example).
close() - Method in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
 
close() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory
 
close() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
 
close() - Method in class org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
 
close() - Method in class org.apache.flink.runtime.state.RetrievableStreamStateHandle
 
close() - Method in class org.apache.flink.runtime.state.SharedStateRegistry
 
close() - Method in class org.apache.flink.runtime.state.StateInitializationContextImpl
 
close() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
 
close() - Method in class org.apache.flink.runtime.util.NonClosingStreamDecorator
 
close() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedCount
 
close() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedValue
 
close(boolean) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperUtilityFactory
Closes the ZooKeeperUtilityFactory.
close() - Method in class org.apache.flink.storm.util.AbstractLineSpout
 
close() - Method in class org.apache.flink.storm.util.FileSpout
 
close() - Method in class org.apache.flink.storm.util.NullTerminatingSpout
 
close() - Method in class org.apache.flink.storm.wrappers.SpoutWrapper
 
close() - Method in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
close() - Method in class org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
 
close() - Method in class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
 
close() - Method in class org.apache.flink.streaming.api.functions.sink.SocketClientSink
Closes the connection with the Socket server.
close() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
 
close() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
 
close() - Method in class org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
 
close() - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
 
close() - Method in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
 
close() - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
This method is called by the system to shut down the context.
close() - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessAllWindowFunction
Deprecated.
 
close() - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessWindowFunction
Deprecated.
 
close() - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
 
close() - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
 
close() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
close() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator.CountingOutput
 
close() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
close() - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
close() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
close() - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
 
close() - Method in class org.apache.flink.streaming.api.scala.function.util.ScalaProcessAllWindowFunctionWrapper
 
close() - Method in class org.apache.flink.streaming.api.scala.function.util.ScalaProcessWindowFunctionWrapper
 
close() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraCommitter
 
close() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSinkBase
 
close() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraTupleWriteAheadSink
 
close() - Method in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase
 
close() - Method in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter
 
close() - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
 
close() - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
Deprecated.
 
close() - Method in class org.apache.flink.streaming.connectors.fs.SequenceFileWriter
 
close() - Method in class org.apache.flink.streaming.connectors.fs.StreamWriterBase
 
close() - Method in interface org.apache.flink.streaming.connectors.fs.Writer
Closes the Writer.
close() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
 
close() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
 
close() - Method in class org.apache.flink.streaming.connectors.kafka.internal.Handover
Closes the handover.
close() - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
Tries to close the queue.
close() - Method in class org.apache.flink.streaming.connectors.kafka.internals.ZookeeperOffsetHandler
Closes the offset handler.
close() - Method in class org.apache.flink.streaming.connectors.nifi.NiFiSink
 
close() - Method in class org.apache.flink.streaming.connectors.nifi.NiFiSource
 
close() - Method in class org.apache.flink.streaming.connectors.rabbitmq.RMQSink
 
close() - Method in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
 
close() - Method in class org.apache.flink.streaming.connectors.twitter.TwitterSource
 
close() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditsSource
 
close() - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller
Cleans up the current spilling channel and file.
close() - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
close() - Method in class org.apache.flink.streaming.runtime.io.StreamRecordWriter
Closes the writer.
close() - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
Closes the resource/connection to it.
close() - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
 
close() - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndPeriodicWatermarksOperator
 
close() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
Deprecated.
 
close() - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
 
close() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
close() - Method in class org.apache.flink.table.functions.UserDefinedFunction
Tear-down method for user-defined function.
close() - Method in class org.apache.flink.table.runtime.aggregate.TimeWindowPropertyCollector
 
close() - Method in class org.apache.flink.table.runtime.CorrelateFlatMapRunner
 
close() - Method in class org.apache.flink.table.runtime.CRowCorrelateProcessRunner
 
close() - Method in class org.apache.flink.table.runtime.CRowProcessRunner
 
close() - Method in class org.apache.flink.table.runtime.CRowWrappingCollector
 
close() - Method in class org.apache.flink.table.runtime.FlatMapRunner
 
close() - Method in class org.apache.flink.util.AbstractCloseableRegistry
 
close() - Method in interface org.apache.flink.util.Collector
Closes the collector.
close() - Method in class org.apache.flink.yarn.highavailability.YarnHighAvailabilityServices
 
close() - Method in class org.apache.flink.yarn.highavailability.YarnIntraNonHaMasterServices
 
CLOSE_MUTEX - Static variable in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
 
CLOSE_MUTEX - Static variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
 
CloseableInputProvider<E> - Interface in org.apache.flink.runtime.operators.util
Utility interface for a provider of an input that can be closed.
CloseableRegistry - Class in org.apache.flink.core.fs
This class allows to register instances of Closeable, which are all closed if this registry is closed.
CloseableRegistry() - Constructor for class org.apache.flink.core.fs.CloseableRegistry
 
closeableToRef - Variable in class org.apache.flink.util.AbstractCloseableRegistry
 
closeAll(Iterable<? extends AutoCloseable>) - Static method in class org.apache.flink.util.IOUtils
Closes all AutoCloseable objects in the parameter, suppressing exceptions.
closeAllQuietly(Iterable<? extends AutoCloseable>) - Static method in class org.apache.flink.util.IOUtils
Closes all elements in the iterable with closeQuietly().
closeAndCleanupAllData() - Method in interface org.apache.flink.runtime.blob.BlobStoreService
Closes and cleans up the store.
closeAndCleanupAllData() - Method in class org.apache.flink.runtime.blob.FileSystemBlobStore
 
closeAndCleanupAllData() - Method in class org.apache.flink.runtime.blob.VoidBlobStore
 
closeAndCleanupAllData() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
Closes the high availability services (releasing all resources) and deletes all data stored by these services in external stores.
closeAndCleanupAllData() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
 
closeAndCleanupAllData() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
closeAndCleanupAllData() - Method in class org.apache.flink.yarn.highavailability.YarnHighAvailabilityServices
 
closeAndDelete() - Method in class org.apache.flink.runtime.io.disk.FileChannelInputView
 
closeAndDelete() - Method in class org.apache.flink.runtime.io.disk.FileChannelOutputView
Closes this output, writing pending data and releasing the memory.
closeAndDelete() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
 
closeAndDelete() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
This method waits for all pending asynchronous requests to return.
closeAndDelete() - Method in interface org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
Closes the channel and deletes the underlying file.
closeAndDelete() - Method in class org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
 
closeAndGetBytes() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
Closes the stream and returns the byte array containing the stream's data.
closeAndGetHandle() - Method in class org.apache.flink.runtime.state.CheckpointStreamFactory.CheckpointStateOutputStream
Closes the stream and gets a state handle that can create an input stream producing the data written to this stream.
closeAndGetHandle() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
 
closeAndGetHandle() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
 
closeChainedTasks(List<ChainedDriver<?, ?>>, AbstractInvokable) - Static method in class org.apache.flink.runtime.operators.BatchTask
Closes all chained tasks, in the order as they are stored in the array.
closeConnection(KvStateServerAddress) - Method in class org.apache.flink.runtime.query.netty.KvStateClient
Closes the connection to the given server address if it exists.
closed - Variable in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
Flag marking this channel as closed
closed - Variable in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
Flag to mark the table as open / closed.
closed - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
Flag indicating that the closing logic has been invoked.
closed - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
Flag indicating that the sorter was closed.
closedBranchingNodes - Variable in class org.apache.flink.optimizer.dag.OptimizerNode
 
ClosedException() - Constructor for exception org.apache.flink.streaming.connectors.kafka.internal.Handover.ClosedException
 
closeFunction(Function) - Static method in class org.apache.flink.api.common.functions.util.FunctionUtils
 
closeInputFormat() - Method in class org.apache.flink.addons.hbase.AbstractTableInputFormat
 
closeInputFormat() - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
 
closeInputFormat() - Method in class org.apache.flink.api.common.io.RichInputFormat
Closes this InputFormat instance.
closeInputFormat() - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat
 
closeJobManagerConnection(JobID, Exception) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
This method should be called by the framework once it detects that a currently registered job manager has failed.
closeLocalStrategiesAndCaches() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
closeLocalStrategiesAndCaches() - Method in class org.apache.flink.runtime.operators.BatchTask
 
closeLock - Variable in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
The lock that is used during closing to synchronize the thread that waits for all requests to be handled with the asynchronous I/O thread.
closeOpenChannelConnections(ConnectionID) - Method in interface org.apache.flink.runtime.io.network.ConnectionManager
Closes opened ChannelConnections in case of a resource release
closeOpenChannelConnections(ConnectionID) - Method in class org.apache.flink.runtime.io.network.LocalConnectionManager
 
closeOpenChannelConnections(ConnectionID) - Method in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager
 
closeQuietly(AutoCloseable) - Static method in class org.apache.flink.util.IOUtils
Important: This method is expected to never throw an exception.
closeSafetyNetAndGuardedResourcesForThread() - Static method in class org.apache.flink.core.fs.FileSystemSafetyNet
Closes the safety net for a thread.
closeSocket(Socket) - Static method in class org.apache.flink.util.IOUtils
Closes the socket ignoring IOException.
closeStream(Closeable) - Static method in class org.apache.flink.util.IOUtils
Closes the stream ignoring IOException.
closeStreamAndGetStateHandle() - Method in class org.apache.flink.runtime.checkpoint.AbstractAsyncSnapshotIOCallable
 
closeStreamOnCancelRegistry - Variable in class org.apache.flink.runtime.checkpoint.AbstractAsyncSnapshotIOCallable
 
closeTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
 
closeTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
closeTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
 
closeTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
 
closeTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
 
closeTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
 
closeTask() - Method in class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
 
closeTask() - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
 
closeTask() - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
 
closeTaskManagerConnection(ResourceID, Exception) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
This method should be called by the framework once it detects that a currently registered task executor has failed.
closeUserCode(Function) - Static method in class org.apache.flink.runtime.operators.BatchTask
Closes the given stub using its RichFunction.close() method.
closeWith(DataSet<ST>, DataSet<WT>) - Method in class org.apache.flink.api.java.operators.DeltaIteration
Closes the delta iteration.
closeWith(DataSet<T>) - Method in class org.apache.flink.api.java.operators.IterativeDataSet
Closes the iteration.
closeWith(DataSet<T>, DataSet<?>) - Method in class org.apache.flink.api.java.operators.IterativeDataSet
Closes the iteration and specifies a termination criterion.
closeWith(DataStream<T>) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream
Closes the iteration.
closeWith(DataStream<F>) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream.ConnectedIterativeStreams
Closes the iteration.
ClosingFSDataInputStream - Class in org.apache.flink.core.fs
This class is a WrappingProxy for FSDataInputStream that is used to implement a safety net against unclosed streams.
ClosingFSDataOutputStream - Class in org.apache.flink.core.fs
This class is a WrappingProxy for FSDataOutputStream that is used to implement a safety net against unclosed streams.
ClosingFSDataOutputStream(FSDataOutputStream, SafetyNetCloseableRegistry) - Constructor for class org.apache.flink.core.fs.ClosingFSDataOutputStream
 
ClosureCleaner - Class in org.apache.flink.api.java
The closure cleaner is a utility that tries to truncate the closure (enclosing instance) of non-static inner classes (created for inline transformation functions).
ClosureCleaner() - Constructor for class org.apache.flink.api.java.ClosureCleaner
 
ClosureCleaner - Class in org.apache.flink.api.scala
 
ClosureCleaner() - Constructor for class org.apache.flink.api.scala.ClosureCleaner
 
ClosureCleaner$ - Class in org.apache.flink.api.scala
 
ClosureCleaner$() - Constructor for class org.apache.flink.api.scala.ClosureCleaner$
 
cluster - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
 
cluster - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraSinkBase
 
cluster - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraTupleWriteAheadSink
 
cluster - Static variable in class org.apache.flink.streaming.util.StreamingMultipleProgramsTestBase
 
cluster - Static variable in class org.apache.flink.test.util.MultipleProgramsTestBase
 
ClusterBuilder - Class in org.apache.flink.streaming.connectors.cassandra
This class is used to configure a Cluster after deployment.
ClusterBuilder() - Constructor for class org.apache.flink.streaming.connectors.cassandra.ClusterBuilder
 
ClusterClient - Class in org.apache.flink.client.program
Encapsulates the functionality necessary to submit a program to a remote cluster.
ClusterClient(Configuration) - Constructor for class org.apache.flink.client.program.ClusterClient
Creates a instance that submits the programs to the JobManager defined in the configuration.
ClusterClient(Configuration, HighAvailabilityServices) - Constructor for class org.apache.flink.client.program.ClusterClient
Creates a instance that submits the programs to the JobManager defined in the configuration.
ClusterClient.LazyActorSystemLoader - Class in org.apache.flink.client.program
 
ClusterDescriptor<ClientType extends ClusterClient> - Interface in org.apache.flink.client.deployment
A descriptor to deploy a cluster (e.g.
ClusteringCoefficient<K extends Comparable<K> & CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.drivers
Driver for directed and undirected clustering coefficient algorithm and analytics.
ClusteringCoefficient() - Constructor for class org.apache.flink.graph.drivers.ClusteringCoefficient
 
ClusterOverviewHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Responder that returns the status of the Flink cluster, such as how many TaskManagers are currently connected, and how many jobs are running.
ClusterOverviewHandler(FiniteDuration) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.ClusterOverviewHandler
 
COALESCE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The COALESCE builtin function.
code() - Method in class org.apache.flink.table.codegen.GeneratedAggregationsFunction
 
code() - Method in class org.apache.flink.table.codegen.GeneratedCollector
 
code() - Method in class org.apache.flink.table.codegen.GeneratedExpression
 
code() - Method in class org.apache.flink.table.codegen.GeneratedFunction
 
code() - Method in class org.apache.flink.table.codegen.GeneratedInput
 
CodeAnalysisMode - Enum in org.apache.flink.api.common
Specifies to which extent user-defined functions are analyzed in order to give the Flink optimizer an insight of UDF internals and inform the user about common implementation mistakes.
CodeAnalyzerException - Exception in org.apache.flink.api.java.sca
Exception that is thrown if code analysis could not run properly.
CodeAnalyzerException() - Constructor for exception org.apache.flink.api.java.sca.CodeAnalyzerException
 
CodeAnalyzerException(String, Throwable) - Constructor for exception org.apache.flink.api.java.sca.CodeAnalyzerException
 
CodeAnalyzerException(String) - Constructor for exception org.apache.flink.api.java.sca.CodeAnalyzerException
 
CodeAnalyzerException(Throwable) - Constructor for exception org.apache.flink.api.java.sca.CodeAnalyzerException
 
CodeErrorException - Exception in org.apache.flink.api.java.sca
Exception that is thrown if code errors could be found during analysis.
CodeErrorException() - Constructor for exception org.apache.flink.api.java.sca.CodeErrorException
 
CodeErrorException(String, Throwable) - Constructor for exception org.apache.flink.api.java.sca.CodeErrorException
 
CodeErrorException(String) - Constructor for exception org.apache.flink.api.java.sca.CodeErrorException
 
CodeErrorException(Throwable) - Constructor for exception org.apache.flink.api.java.sca.CodeErrorException
 
CodeGenerator - Class in org.apache.flink.table.codegen
A code generator for generating Flink Functions.
CodeGenerator(TableConfig, boolean, TypeInformation<?>, Option<TypeInformation<?>>, Option<int[]>, Option<int[]>) - Constructor for class org.apache.flink.table.codegen.CodeGenerator
 
CodeGenerator(TableConfig, boolean, TypeInformation<Object>, int[]) - Constructor for class org.apache.flink.table.codegen.CodeGenerator
A code generator for generating unary Flink Functions with one input.
CodeGenerator(TableConfig) - Constructor for class org.apache.flink.table.codegen.CodeGenerator
A code generator for generating Flink input formats.
CodeGenerator$ - Class in org.apache.flink.table.codegen
 
CodeGenerator$() - Constructor for class org.apache.flink.table.codegen.CodeGenerator$
 
CodeGenException - Exception in org.apache.flink.table.codegen
Exception for all errors occurring during code generation.
CodeGenException(String) - Constructor for exception org.apache.flink.table.codegen.CodeGenException
 
CodeGenUtils - Class in org.apache.flink.table.codegen
 
CodeGenUtils() - Constructor for class org.apache.flink.table.codegen.CodeGenUtils
 
CodeGenUtils$ - Class in org.apache.flink.table.codegen
 
CodeGenUtils$() - Constructor for class org.apache.flink.table.codegen.CodeGenUtils$
 
CodeGenUtils.FieldAccessor - Class in org.apache.flink.table.codegen
 
CodeGenUtils.ObjectFieldAccessor - Class in org.apache.flink.table.codegen
 
CodeGenUtils.ObjectFieldAccessor$ - Class in org.apache.flink.table.codegen
 
CodeGenUtils.ObjectGenericFieldAccessor - Class in org.apache.flink.table.codegen
 
CodeGenUtils.ObjectGenericFieldAccessor$ - Class in org.apache.flink.table.codegen
 
CodeGenUtils.ObjectMethodAccessor - Class in org.apache.flink.table.codegen
 
CodeGenUtils.ObjectMethodAccessor$ - Class in org.apache.flink.table.codegen
 
CodeGenUtils.ObjectPrivateFieldAccessor - Class in org.apache.flink.table.codegen
 
CodeGenUtils.ObjectPrivateFieldAccessor$ - Class in org.apache.flink.table.codegen
 
CodeGenUtils.ProductAccessor - Class in org.apache.flink.table.codegen
 
CodeGenUtils.ProductAccessor$ - Class in org.apache.flink.table.codegen
 
CoFeedbackTransformation<F> - Class in org.apache.flink.streaming.api.transformations
This represents a feedback point in a topology.
CoFeedbackTransformation(int, TypeInformation<F>, Long) - Constructor for class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
Creates a new CoFeedbackTransformation from the given input.
CoFlatMapFunction<IN1,IN2,OUT> - Interface in org.apache.flink.streaming.api.functions.co
A CoFlatMapFunction implements a flat-map transformation over two connected streams.
coGroup(Iterable<IN1>, Iterable<IN2>, Collector<O>) - Method in interface org.apache.flink.api.common.functions.CoGroupFunction
This method must be implemented to provide a user implementation of a coGroup.
coGroup(Iterable<IN1>, Iterable<IN2>, Collector<OUT>) - Method in class org.apache.flink.api.common.functions.RichCoGroupFunction
 
coGroup(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
Initiates a CoGroup transformation.
A CoGroup transformation combines the elements of two DataSets into one DataSet.
coGroup(Iterable<Tuple2<K, I1>>, Iterable<Tuple2<K, I2>>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.PlanBothUnwrappingCoGroupOperator.TupleBothUnwrappingCoGrouper
 
coGroup(Iterable<Tuple2<K, I1>>, Iterable<I2>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.PlanLeftUnwrappingCoGroupOperator.TupleLeftUnwrappingCoGrouper
 
coGroup(Iterable<I1>, Iterable<Tuple2<K, I2>>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.PlanRightUnwrappingCoGroupOperator.TupleRightUnwrappingCoGrouper
 
coGroup(DataSet<O>, ClassTag<O>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
coGroup(DataSet<O>, ClassTag<O>) - Method in class org.apache.flink.api.scala.DataSet
For each key in this DataSet and the other DataSet, create a tuple containing a list of elements for that key from both DataSets.
coGroup(Iterable<Tuple3<Integer, String, Integer>>, Iterable<Tuple1<String>>, Collector<Tuple3<Integer, String, Integer>>) - Method in class org.apache.flink.examples.java.relational.WebLogAnalysis.AntiJoinVisits
If the visit iterator is empty, all pairs of the rank iterator are emitted.
coGroup(Iterable<Tuple3<String, String, Integer>>, Iterable<Tuple1<String>>, Collector<Tuple3<String, String, Integer>>) - Method in class org.apache.flink.graph.examples.MusicProfiles.FilterOutMismatches
 
coGroup(Iterable<IN1>, Iterable<IN2>, Collector<OUT>) - Method in class org.apache.flink.python.api.functions.PythonCoGroup
Calls the external python function.
coGroup(DataStream<T2>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Creates a join operation.
coGroup(DataStream<T2>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Creates a co-group operation.
coGroup(Iterable<T>, Iterable<T>, Collector<T>) - Method in class org.apache.flink.table.runtime.IntersectCoGroupFunction
 
coGroup(Iterable<T>, Iterable<T>, Collector<T>) - Method in class org.apache.flink.table.runtime.MinusCoGroupFunction
 
CoGroupDataSet<L,R> - Class in org.apache.flink.api.scala
A specific DataSet that results from a coGroup operation.
CoGroupDataSet(CoGroupOperator<L, R, Tuple2<Object, Object>>, DataSet<L>, DataSet<R>, Keys<L>, Keys<R>) - Constructor for class org.apache.flink.api.scala.CoGroupDataSet
 
CoGroupDescriptor - Class in org.apache.flink.optimizer.operators
 
CoGroupDescriptor(FieldList, FieldList) - Constructor for class org.apache.flink.optimizer.operators.CoGroupDescriptor
 
CoGroupDescriptor(FieldList, FieldList, Ordering, Ordering) - Constructor for class org.apache.flink.optimizer.operators.CoGroupDescriptor
 
CoGroupDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
CoGroup task which is executed by a Task Manager.
CoGroupDriver() - Constructor for class org.apache.flink.runtime.operators.CoGroupDriver
 
CoGroupedStreams<T1,T2> - Class in org.apache.flink.streaming.api.datastream
CoGroupedStreams represents two DataStreams that have been co-grouped.
CoGroupedStreams(DataStream<T1>, DataStream<T2>) - Constructor for class org.apache.flink.streaming.api.datastream.CoGroupedStreams
Creates new CoGrouped data streams, which are the first step towards building a streaming co-group.
CoGroupedStreams<T1,T2> - Class in org.apache.flink.streaming.api.scala
CoGroupedStreams represents two DataStreams that have been co-grouped.
CoGroupedStreams(DataStream<T1>, DataStream<T2>) - Constructor for class org.apache.flink.streaming.api.scala.CoGroupedStreams
 
CoGroupedStreams.TaggedUnion<T1,T2> - Class in org.apache.flink.streaming.api.datastream
Internal class for implementing tagged union co-group.
CoGroupedStreams.UnionSerializerConfigSnapshot<T1,T2> - Class in org.apache.flink.streaming.api.datastream
The TypeSerializerConfigSnapshot for the UnionSerializer.
CoGroupedStreams.Where<KEY> - Class in org.apache.flink.streaming.api.datastream
CoGrouped streams that have the key for one side defined.
CoGroupedStreams.Where<KEY> - Class in org.apache.flink.streaming.api.scala
A co-group operation that has KeySelectors defined for the first input.
CoGroupedStreams.Where.EqualTo - Class in org.apache.flink.streaming.api.datastream
A co-group operation that has KeySelectors defined for both inputs.
CoGroupedStreams.Where.EqualTo - Class in org.apache.flink.streaming.api.scala
A co-group operation that a KeySelector defined for the first and the second input.
CoGroupedStreams.Where.EqualTo.WithWindow<W extends Window> - Class in org.apache.flink.streaming.api.scala
A co-group operation that has KeySelectors defined for both inputs as well as a WindowAssigner.
CoGroupedStreams.WithWindow<T1,T2,KEY,W extends Window> - Class in org.apache.flink.streaming.api.datastream
A co-group operation that has KeySelectors defined for both inputs as well as a WindowAssigner.
CoGroupFunction<IN1,IN2,O> - Interface in org.apache.flink.api.common.functions
The interface for CoGroup functions.
CoGroupNode - Class in org.apache.flink.optimizer.dag
The Optimizer representation of a CoGroup operator.
CoGroupNode(CoGroupOperatorBase<?, ?, ?, ?>) - Constructor for class org.apache.flink.optimizer.dag.CoGroupNode
 
CoGroupOperator<I1,I2,OUT> - Class in org.apache.flink.api.java.operators
A DataSet that is the result of a CoGroup transformation.
CoGroupOperator(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, CoGroupFunction<I1, I2, OUT>, TypeInformation<OUT>, Partitioner<?>, String) - Constructor for class org.apache.flink.api.java.operators.CoGroupOperator
 
CoGroupOperator(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, CoGroupFunction<I1, I2, OUT>, TypeInformation<OUT>, List<Pair<Integer, Order>>, List<Pair<Integer, Order>>, Partitioner<?>, String) - Constructor for class org.apache.flink.api.java.operators.CoGroupOperator
 
CoGroupOperator.CoGroupOperatorSets<I1,I2> - Class in org.apache.flink.api.java.operators
Intermediate step of a CoGroup transformation.
CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate - Class in org.apache.flink.api.java.operators
Intermediate step of a CoGroup transformation.
CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction - Class in org.apache.flink.api.java.operators
 
CoGroupOperatorBase<IN1,IN2,OUT,FT extends CoGroupFunction<IN1,IN2,OUT>> - Class in org.apache.flink.api.common.operators.base
 
CoGroupOperatorBase(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
CoGroupOperatorBase(FT, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
CoGroupOperatorBase(Class<? extends FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
CoGroupOperatorSets(DataSet<I1>, DataSet<I2>) - Constructor for class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets
 
CoGroupRawDescriptor - Class in org.apache.flink.optimizer.operators
 
CoGroupRawDescriptor(FieldList, FieldList) - Constructor for class org.apache.flink.optimizer.operators.CoGroupRawDescriptor
 
CoGroupRawDescriptor(FieldList, FieldList, Ordering, Ordering) - Constructor for class org.apache.flink.optimizer.operators.CoGroupRawDescriptor
 
CoGroupRawDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
 
CoGroupRawDriver() - Constructor for class org.apache.flink.runtime.operators.CoGroupRawDriver
 
CoGroupRawDriver.SimpleIterable<IN> - Class in org.apache.flink.runtime.operators
 
CoGroupRawDriver.SimpleIterable.SimpleIterator<IN> - Class in org.apache.flink.runtime.operators
 
CoGroupRawNode - Class in org.apache.flink.optimizer.dag
The Optimizer representation of a CoGroupRaw operator.
CoGroupRawNode(CoGroupRawOperatorBase<?, ?, ?, ?>) - Constructor for class org.apache.flink.optimizer.dag.CoGroupRawNode
 
CoGroupRawOperator<I1,I2,OUT> - Class in org.apache.flink.api.java.operators
A DataSet that is the result of a CoGroup transformation.
CoGroupRawOperator(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, CoGroupFunction<I1, I2, OUT>, TypeInformation<OUT>, String) - Constructor for class org.apache.flink.api.java.operators.CoGroupRawOperator
 
CoGroupRawOperatorBase<IN1,IN2,OUT,FT extends CoGroupFunction<IN1,IN2,OUT>> - Class in org.apache.flink.api.common.operators.base
 
CoGroupRawOperatorBase(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
 
CoGroupRawOperatorBase(FT, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
 
CoGroupRawOperatorBase(Class<? extends FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
 
CoGroupRawOperatorBase.SimpleListIterable<IN> - Class in org.apache.flink.api.common.operators.base
 
CoGroupRawOperatorBase.SimpleListIterable.SimpleListIterator<IN> - Class in org.apache.flink.api.common.operators.base
 
CoGroupTaskIterator<T1,T2> - Interface in org.apache.flink.runtime.operators.util
Interface describing the methods that have to be implemented by local strategies for the CoGroup Pact.
CoGroupWithSolutionSetFirstDescriptor - Class in org.apache.flink.optimizer.operators
 
CoGroupWithSolutionSetFirstDescriptor(FieldList, FieldList) - Constructor for class org.apache.flink.optimizer.operators.CoGroupWithSolutionSetFirstDescriptor
 
CoGroupWithSolutionSetFirstDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
 
CoGroupWithSolutionSetFirstDriver() - Constructor for class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
 
CoGroupWithSolutionSetSecondDescriptor - Class in org.apache.flink.optimizer.operators
 
CoGroupWithSolutionSetSecondDescriptor(FieldList, FieldList) - Constructor for class org.apache.flink.optimizer.operators.CoGroupWithSolutionSetSecondDescriptor
 
CoGroupWithSolutionSetSecondDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
 
CoGroupWithSolutionSetSecondDriver() - Constructor for class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
 
COLLECT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The COLLECT operator.
collect(T) - Method in class org.apache.flink.api.common.functions.util.CopyingListCollector
 
collect(T) - Method in class org.apache.flink.api.common.functions.util.ListCollector
 
collect() - Method in class org.apache.flink.api.java.DataSet
Convenience method to get the elements of a DataSet as a List.
collect(IN) - Method in class org.apache.flink.api.java.operators.translation.Tuple3WrappingCollector
 
collect(IN) - Method in class org.apache.flink.api.java.operators.translation.TupleWrappingCollector
 
collect() - Static method in class org.apache.flink.api.scala.CrossDataSet
 
collect() - Method in class org.apache.flink.api.scala.DataSet
Convenience method to get the elements of a DataSet as a List As DataSet can contain a lot of data, this method should be used with caution.
collect(DataStream<OUT>) - Static method in class org.apache.flink.contrib.streaming.DataStreamUtils
Returns an iterator to iterate over the elements of the DataStream.
Collect<T> - Class in org.apache.flink.graph.asm.dataset
Collect the elements of a DataSet into a List.
Collect() - Constructor for class org.apache.flink.graph.asm.dataset.Collect
 
collect(KEY, VALUE) - Method in class org.apache.flink.hadoopcompatibility.mapred.wrapper.HadoopOutputCollector
Use the wrapped Flink collector to collect a key-value pair for Flink.
collect(Channel, List<Channel>) - Method in class org.apache.flink.optimizer.traversals.BinaryUnionReplacer
 
collect(T) - Method in class org.apache.flink.runtime.iterative.io.SolutionSetFastUpdateOutputCollector
 
collect(T) - Method in class org.apache.flink.runtime.iterative.io.SolutionSetObjectsUpdateOutputCollector
 
collect(T) - Method in class org.apache.flink.runtime.iterative.io.SolutionSetUpdateOutputCollector
 
collect(T) - Method in class org.apache.flink.runtime.iterative.io.WorksetUpdateOutputCollector
 
collect(IT) - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
 
collect(IT) - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
collect(IT) - Method in class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
 
collect(IT) - Method in class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
 
collect(T) - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
 
collect(IT) - Method in class org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
 
collect(IN) - Method in class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
 
collect(IN) - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
 
collect(IT) - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
 
collect(T) - Method in class org.apache.flink.runtime.operators.shipping.OutputCollector
Collects a record and emits it to all writers.
collect(OUT) - Method in class org.apache.flink.runtime.operators.util.metrics.CountingCollector
 
collect(StreamRecord<OUT>) - Method in class org.apache.flink.streaming.api.collector.selector.CopyingDirectedOutput
 
collect(StreamRecord<OUT>) - Method in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
collect(OutputTag<X>, StreamRecord<X>) - Method in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
collect(Collection<OUT>) - Method in interface org.apache.flink.streaming.api.functions.async.collector.AsyncCollector
Set result.
collect(Throwable) - Method in interface org.apache.flink.streaming.api.functions.async.collector.AsyncCollector
Set error.
collect(T) - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
Emits one element from the source, without attaching a timestamp.
collect(StreamRecord<OUT>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator.CountingOutput
 
collect(OutputTag<X>, StreamRecord<X>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator.CountingOutput
 
collect(Collection<OUT>) - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamRecordQueueEntry
 
collect(Throwable) - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamRecordQueueEntry
 
collect(OutputTag<X>, StreamRecord<X>) - Method in interface org.apache.flink.streaming.api.operators.Output
Emits a record the the side output identified by the given OutputTag.
collect(T) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
 
collect(Iterable<OUT>) - Method in interface org.apache.flink.streaming.api.scala.async.AsyncCollector
Complete the async collector with a set of result elements.
collect(Throwable) - Method in interface org.apache.flink.streaming.api.scala.async.AsyncCollector
Complete this async collector with an error.
collect(Iterable<OUT>) - Method in class org.apache.flink.streaming.api.scala.async.JavaAsyncCollectorWrapper
 
collect(Throwable) - Method in class org.apache.flink.streaming.api.scala.async.JavaAsyncCollectorWrapper
 
collect(StreamRecord<OUT>) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
collect(OutputTag<X>, StreamRecord<X>) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
collect(T) - Method in class org.apache.flink.table.functions.TableFunction
Emit an output row.
collect(T) - Method in class org.apache.flink.table.runtime.aggregate.TimeWindowPropertyCollector
 
collect(Row) - Method in class org.apache.flink.table.runtime.CRowWrappingCollector
 
collect(T) - Method in class org.apache.flink.table.runtime.TableFunctionCollector
 
collect(T) - Method in interface org.apache.flink.util.Collector
Emits a record.
collectBuffer(Collector<OUT>, int) - Method in class org.apache.flink.python.api.streaming.data.PythonReceiver
Reads a buffer of the given size from the memory-mapped file, and collects all records contained.
CollectHelper(String, TypeSerializer<T>) - Constructor for class org.apache.flink.api.java.Utils.CollectHelper
 
collectInsertTargets(SqlInsert, RexNode, List<String>, List<RexNode>) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Given an INSERT statement, collects the list of names to be populated and the expressions to put in them.
collection - Variable in class org.apache.flink.api.common.operators.util.FieldSet
 
COLLECTION_TABLE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The "table function derived table" operator, which a table-valued function into a relation, e.g.
CollectionEnvironment - Class in org.apache.flink.api.java
 
CollectionEnvironment() - Constructor for class org.apache.flink.api.java.CollectionEnvironment
 
CollectionExecutionExample - Class in org.apache.flink.examples.java.misc
This example shows how to use the collection based execution of Flink.
CollectionExecutionExample() - Constructor for class org.apache.flink.examples.java.misc.CollectionExecutionExample
 
CollectionExecutionExample.EMail - Class in org.apache.flink.examples.java.misc
POJO for an EMail.
CollectionExecutionExample.User - Class in org.apache.flink.examples.java.misc
POJO class representing a user
CollectionExecutor - Class in org.apache.flink.api.common.operators
Execution utility for serial, local, collection-based executions of Flink programs.
CollectionExecutor(ExecutionConfig) - Constructor for class org.apache.flink.api.common.operators.CollectionExecutor
 
CollectionInputFormat<T> - Class in org.apache.flink.api.java.io
An input format that returns objects from a collection.
CollectionInputFormat(Collection<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.api.java.io.CollectionInputFormat
 
CollectionSerializerConfigSnapshot<T> - Class in org.apache.flink.api.common.typeutils.base
Configuration snapshot of a serializer for collection types.
CollectionSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.CollectionSerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
CollectionSerializerConfigSnapshot(TypeSerializer<T>) - Constructor for class org.apache.flink.api.common.typeutils.base.CollectionSerializerConfigSnapshot
 
CollectionTestEnvironment - Class in org.apache.flink.test.util
 
CollectionTestEnvironment() - Constructor for class org.apache.flink.test.util.CollectionTestEnvironment
 
CollectionUtil - Class in org.apache.flink.util
 
collector - Variable in class org.apache.flink.storm.util.AbstractLineSpout
 
Collector<T> - Interface in org.apache.flink.util
Collects a record and forwards it.
collectorTerm() - Method in class org.apache.flink.table.codegen.CodeGenerator
 
collectStackTraces(int, ExecutionAttemptID, List<StackTraceElement[]>) - Method in class org.apache.flink.runtime.webmonitor.StackTraceSampleCoordinator
Collects stack traces of a task.
collectVariablesSet(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
collectVariablesSet(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
collectVariablesSet(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
collectVariablesSet(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
collectVariablesSet(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
collectVariablesSet(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
collectVariablesSet(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
collectVariablesSet(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
collectVariablesSet(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
collectVariablesSet(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
collectVariablesSet(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
collectVariablesSet(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
collectVariablesSet(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
collectVariablesSet(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
collectVariablesSet(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
collectVariablesSet(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
collectVariablesUsed(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
collectVariablesUsed(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
collectVariablesUsed(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
collectVariablesUsed(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
collectVariablesUsed(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
collectVariablesUsed(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
collectVariablesUsed(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
collectVariablesUsed(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
collectVariablesUsed(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
collectVariablesUsed(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
collectVariablesUsed(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
collectVariablesUsed(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
collectVariablesUsed(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
collectVariablesUsed(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
collectVariablesUsed(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
collectVariablesUsed(Set<CorrelationId>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
collectWithTimestamp(T, long) - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
Emits one element from the source, and attaches the given timestamp.
CoLocationConstraint - Class in org.apache.flink.runtime.jobmanager.scheduler
A CoLocationConstraint manages the location of a set of tasks (Execution Vertices).
CoLocationGroup - Class in org.apache.flink.runtime.jobmanager.scheduler
A Co-location group is a group of JobVertices, where the i-th subtask of one vertex has to be executed on the same TaskManager as the i-th subtask of all other JobVertices in the same group.
CoLocationGroup() - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
 
CoLocationGroup(JobVertex...) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
 
colPtrs() - Method in class org.apache.flink.ml.math.SparseMatrix
 
colStats() - Method in class org.apache.flink.table.plan.stats.TableStats
 
COLUMN_LIST - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The COLUMN_LIST constructor.
columnFamily - Variable in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
The column family of this particular instance of state
columnNameToIndex() - Method in class org.apache.flink.table.api.TableSchema
 
ColumnStats - Class in org.apache.flink.table.plan.stats
column statistics
ColumnStats(Long, Long, Double, Integer, Number, Number) - Constructor for class org.apache.flink.table.plan.stats.ColumnStats
 
ColumnStats$ - Class in org.apache.flink.table.plan.stats
 
ColumnStats$() - Constructor for class org.apache.flink.table.plan.stats.ColumnStats$
 
ColumnSummary - Class in org.apache.flink.api.java.summarize
Summary for a column of values
ColumnSummary() - Constructor for class org.apache.flink.api.java.summarize.ColumnSummary
 
CoMapFunction<IN1,IN2,OUT> - Interface in org.apache.flink.streaming.api.functions.co
A CoFlatMapFunction implements a map() transformation over two connected streams.
combinations() - Method in class org.apache.flink.cep.pattern.Quantifier
 
combine(Iterable<IN>) - Method in interface org.apache.flink.api.common.functions.CombineFunction
The combine method, called (potentially multiple timed) with subgroups of elements.
combine(Iterable<IN>, Collector<OUT>) - Method in interface org.apache.flink.api.common.functions.GroupCombineFunction
The combine method, called (potentially multiple timed) with subgroups of elements.
combine(Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.api.common.functions.RichGroupCombineFunction
 
combine(Iterable<T>, Collector<T>) - Method in class org.apache.flink.api.java.functions.FirstReducer
 
combine(Iterable<T>, Collector<T>) - Method in class org.apache.flink.api.java.operators.AggregateOperator.AggregatingUdf
 
combine(Iterable<IN>, Collector<IN>) - Method in class org.apache.flink.api.java.operators.translation.CombineToGroupCombineWrapper
 
combine(Iterable<Tuple2<K, IN>>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingGroupCombineOperator.TupleUnwrappingGroupCombiner
 
combine(Iterable<Tuple2<K, IN>>, Collector<Tuple2<K, IN>>) - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingReduceGroupOperator.TupleUnwrappingGroupCombinableGroupReducer
 
combine(Iterable<Tuple3<K1, K2, IN>>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingSortedGroupCombineOperator.TupleUnwrappingGroupReducer
 
combine(Iterable<Tuple3<K1, K2, IN>>, Collector<Tuple3<K1, K2, IN>>) - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingSortedReduceGroupOperator.TupleUnwrappingGroupCombinableGroupReducer
 
combine(Iterable<IN>, Collector<IN>) - Method in class org.apache.flink.api.java.operators.translation.RichCombineToGroupCombineWrapper
 
combine(Aggregator<T, R>) - Method in interface org.apache.flink.api.java.summarize.aggregation.Aggregator
Combine two aggregations of the same type.
combine(Aggregator<Boolean, BooleanColumnSummary>) - Method in class org.apache.flink.api.java.summarize.aggregation.BooleanSummaryAggregator
 
combine(Aggregator<Double, Double>) - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MaxDoubleAggregator
 
combine(Aggregator<Double, Double>) - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MinDoubleAggregator
 
combine(Aggregator<Double, Double>) - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.SumDoubleAggregator
 
combine(Aggregator<Float, Float>) - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MaxFloatAggregator
 
combine(Aggregator<Float, Float>) - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MinFloatAggregator
 
combine(Aggregator<Float, Float>) - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.SumFloatAggregator
 
combine(Aggregator<Integer, Integer>) - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MaxIntegerAggregator
 
combine(Aggregator<Integer, Integer>) - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MinIntegerAggregator
 
combine(Aggregator<Integer, Integer>) - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.SumIntegerAggregator
 
combine(Aggregator<Long, Long>) - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MaxLongAggregator
 
combine(Aggregator<Long, Long>) - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MinLongAggregator
 
combine(Aggregator<Long, Long>) - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.SumLongAggregator
 
combine(Aggregator<T, NumericColumnSummary<T>>) - Method in class org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
combine two aggregations
combine(Aggregator<Object, ObjectColumnSummary>) - Method in class org.apache.flink.api.java.summarize.aggregation.ObjectSummaryAggregator
 
combine(Aggregator<Short, Short>) - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MaxShortAggregator
 
combine(Aggregator<Short, Short>) - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MinShortAggregator
 
combine(Aggregator<Short, Short>) - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.SumShortAggregator
 
combine(Aggregator<String, StringColumnSummary>) - Method in class org.apache.flink.api.java.summarize.aggregation.StringSummaryAggregator
 
combine(Aggregator<Tuple, R>) - Method in class org.apache.flink.api.java.summarize.aggregation.TupleSummaryAggregator
 
combine(Aggregator<VT, R>) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator
 
combine(Iterable<T>, Collector<T>) - Method in class org.apache.flink.api.scala.operators.ScalaAggregateOperator.AggregatingUdf
 
combine(Iterable<Tuple2<K, Either<NullValue, Message>>>, Collector<Tuple2<K, Either<NullValue, Message>>>) - Method in class org.apache.flink.graph.pregel.VertexCentricIteration.MessageCombinerUdf
 
combine(Iterable<Tuple2<KEYIN, VALUEIN>>, Collector<Tuple2<KEYIN, VALUEIN>>) - Method in class org.apache.flink.hadoopcompatibility.mapred.HadoopReduceCombineFunction
 
combine(GlobalProperties, GlobalProperties) - Static method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
 
combine(LocalProperties, LocalProperties) - Static method in class org.apache.flink.optimizer.dataproperties.LocalProperties
 
combine(Iterable<Row>, Collector<Row>) - Method in class org.apache.flink.table.runtime.aggregate.DataSetPreAggFunction
 
combine(Iterable<Row>, Collector<Row>) - Method in class org.apache.flink.table.runtime.aggregate.DataSetSessionWindowAggregatePreProcessor
For sub-grouped intermediate aggregate Rows, divide window based on the rowtime (current'rowtime - previous&rsquo;rowtime > gap), and then merge data (within a unified window) into an aggregate buffer.
combine(Iterable<Row>) - Method in class org.apache.flink.table.runtime.aggregate.DataSetSlideTimeWindowAggReduceGroupFunction
 
combine(Iterable<Row>) - Method in class org.apache.flink.table.runtime.aggregate.DataSetSlideWindowAggReduceCombineFunction
 
combine(Iterable<Row>) - Method in class org.apache.flink.table.runtime.aggregate.DataSetTumbleTimeWindowAggReduceCombineFunction
For sub-grouped intermediate aggregate Rows, merge all of them into aggregate buffer,
combineAll(Collection<? extends Future<? extends T>>) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
Creates a future that is complete once multiple other futures completed.
CombineFunction<IN,OUT> - Interface in org.apache.flink.api.common.functions
Generic interface used for combine functions ("combiners").
combineGroup(GroupCombineFunction<T, R>) - Method in class org.apache.flink.api.java.DataSet
Applies a GroupCombineFunction on a non-grouped DataSet.
combineGroup(GroupCombineFunction<T, R>) - Method in class org.apache.flink.api.java.operators.SortedGrouping
Applies a GroupCombineFunction on a grouped DataSet.
combineGroup(GroupCombineFunction<T, R>) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Applies a GroupCombineFunction on a grouped DataSet.
combineGroup(GroupCombineFunction<T, R>, TypeInformation<R>, ClassTag<R>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
combineGroup(Function2<Iterator<T>, Collector<R>, BoxedUnit>, TypeInformation<R>, ClassTag<R>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
combineGroup(GroupCombineFunction<T, R>, TypeInformation<R>, ClassTag<R>) - Method in class org.apache.flink.api.scala.DataSet
Applies a GroupCombineFunction on a grouped DataSet.
combineGroup(Function2<Iterator<T>, Collector<R>, BoxedUnit>, TypeInformation<R>, ClassTag<R>) - Method in class org.apache.flink.api.scala.DataSet
Applies a GroupCombineFunction on a grouped DataSet.
combineGroup(Function2<Iterator<T>, Collector<R>, BoxedUnit>, TypeInformation<R>, ClassTag<R>) - Method in class org.apache.flink.api.scala.GroupedDataSet
Applies a CombineFunction on a grouped DataSet.
combineGroup(GroupCombineFunction<T, R>, TypeInformation<R>, ClassTag<R>) - Method in class org.apache.flink.api.scala.GroupedDataSet
Applies a CombineFunction on a grouped DataSet.
combineGroupWith(Function1<Stream<T>, R>, TypeInformation<R>, ClassTag<R>) - Method in class org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions.OnGroupedDataSet
Same as a reducing operation but only acts locally, ideal to perform pre-aggregation before a reduction.
combineMessages(MessageIterator<Double>) - Method in class org.apache.flink.graph.examples.PregelSSSP.SSSPCombiner
 
combineMessages(MessageIterator<Message>) - Method in class org.apache.flink.graph.pregel.MessageCombiner
Combines messages sent from different vertices to a target vertex.
CombineToGroupCombineWrapper<IN,OUT,F extends CombineFunction<IN,IN> & GroupReduceFunction<IN,OUT>> - Class in org.apache.flink.api.java.operators.translation
A wrapper the wraps a function that implements both CombineFunction and GroupReduceFunction interfaces and makes it look like a function that implements GroupCombineFunction and GroupReduceFunction to the runtime.
CombineToGroupCombineWrapper(F) - Constructor for class org.apache.flink.api.java.operators.translation.CombineToGroupCombineWrapper
 
CombiningSpillingThread(ExceptionHandler<IOException>, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable, MemoryManager, IOManager, TypeSerializer<E>, TypeComparator<E>, List<MemorySegment>, List<MemorySegment>, int, boolean) - Constructor for class org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger.CombiningSpillingThread
 
CombiningUnilateralSortMerger<E> - Class in org.apache.flink.runtime.operators.sort
The CombiningUnilateralSortMerger is part of a merge-sort implementation.
CombiningUnilateralSortMerger(GroupCombineFunction<E, E>, MemoryManager, IOManager, MutableObjectIterator<E>, AbstractInvokable, TypeSerializerFactory<E>, TypeComparator<E>, double, int, float, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger
Creates a new sorter that reads the data from a given reader and provides an iterator returning that data in a sorted manner.
CombiningUnilateralSortMerger(GroupCombineFunction<E, E>, MemoryManager, IOManager, MutableObjectIterator<E>, AbstractInvokable, TypeSerializerFactory<E>, TypeComparator<E>, double, int, int, float, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger
Creates a new sorter that reads the data from a given reader and provides an iterator returning that data in a sorted manner.
CombiningUnilateralSortMerger.CombiningSpillingThread - Class in org.apache.flink.runtime.operators.sort
 
CommandLineOptions - Class in org.apache.flink.client.cli
Base class for all options parsed from the command line.
CommandLineOptions(CommandLine) - Constructor for class org.apache.flink.client.cli.CommandLineOptions
 
comment() - Method in class org.apache.flink.table.catalog.ExternalCatalogTable
 
commentCount - Variable in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
commentPrefix - Variable in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
commentPrefix - Variable in class org.apache.flink.api.java.io.CsvReader
 
commentPrefix(String) - Method in class org.apache.flink.table.sources.CsvTableSource.Builder
Sets a prefix to indicate comments, null by default.
commit(Function0<Parsers.Parser<T>>) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
commitCheckpoint(int, long) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraCommitter
 
commitCheckpoint(int, long) - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
Mark the given checkpoint as completed in the resource.
commitDate - Variable in class org.apache.flink.runtime.util.EnvironmentInformation.RevisionInformation
The git commit date
commitId - Variable in class org.apache.flink.runtime.util.EnvironmentInformation.RevisionInformation
The git commit id (hash)
commitInternalOffsetsToKafka(Map<KafkaTopicPartition, Long>, KafkaCommitCallback) - Method in class org.apache.flink.streaming.connectors.kafka.internal.Kafka09Fetcher
 
commitInternalOffsetsToKafka(Map<KafkaTopicPartition, Long>, KafkaCommitCallback) - Method in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
Commits the given partition offsets to the Kafka brokers (or to ZooKeeper for older Kafka versions).
commitInternalOffsetsToKafka(Map<KafkaTopicPartition, Long>, KafkaCommitCallback) - Method in class org.apache.flink.streaming.connectors.kafka.internals.Kafka08Fetcher
 
committer - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
 
CommonAggregate - Interface in org.apache.flink.table.plan.nodes
 
CommonCalc - Interface in org.apache.flink.table.plan.nodes
 
CommonCorrelate - Interface in org.apache.flink.table.plan.nodes
Join a user-defined table function
CommonRangeBoundaries<T> - Class in org.apache.flink.api.common.distributions
 
CommonRangeBoundaries(TypeComparator<T>, Object[][]) - Constructor for class org.apache.flink.api.common.distributions.CommonRangeBoundaries
 
CommonScan<T> - Interface in org.apache.flink.table.plan.nodes
Common class for batch and stream scans.
CommonTestUtils - Class in org.apache.flink.core.testutils
This class contains reusable utility methods for unit tests.
CommonTestUtils() - Constructor for class org.apache.flink.core.testutils.CommonTestUtils
 
COMMUNITIES_RESULT - Static variable in class org.apache.flink.graph.examples.data.MusicProfilesData
 
COMMUNITIES_SINGLE_ITERATION - Static variable in class org.apache.flink.graph.examples.data.CommunityDetectionData
 
COMMUNITIES_WITH_TIE - Static variable in class org.apache.flink.graph.examples.data.CommunityDetectionData
 
CommunityDetection<K> - Class in org.apache.flink.graph.library
Community Detection Algorithm.
CommunityDetection(int, double) - Constructor for class org.apache.flink.graph.library.CommunityDetection
Creates a new Community Detection algorithm instance.
CommunityDetection.AddScoreToVertexValuesMapper<K> - Class in org.apache.flink.graph.library
 
CommunityDetection.LabelMessenger<K> - Class in org.apache.flink.graph.library
 
CommunityDetection.RemoveScoreFromVertexValuesMapper<K> - Class in org.apache.flink.graph.library
 
CommunityDetection.VertexLabelUpdater<K> - Class in org.apache.flink.graph.library
 
CommunityDetectionData - Class in org.apache.flink.graph.examples.data
Provides the default data set used for the Simple Community Detection test program.
CompactingHashTable<T> - Class in org.apache.flink.runtime.operators.hash
A hash table that uses Flink's managed memory and supports replacement of records or updates to records.
CompactingHashTable(TypeSerializer<T>, TypeComparator<T>, List<MemorySegment>) - Constructor for class org.apache.flink.runtime.operators.hash.CompactingHashTable
 
CompactingHashTable(TypeSerializer<T>, TypeComparator<T>, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.operators.hash.CompactingHashTable
 
CompactingHashTable.EntryIterator - Class in org.apache.flink.runtime.operators.hash
Iterator that traverses the whole hash table once If entries are inserted during iteration they may be overlooked by the iterator
CompactingHashTable.HashTableProber<PT> - Class in org.apache.flink.runtime.operators.hash
 
ComparableAggregator<T> - Class in org.apache.flink.streaming.api.functions.aggregation
An AggregationFunction that computes values based on comparisons of Comparables.
ComparableAggregator(int, TypeInformation<T>, AggregationFunction.AggregationType, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.aggregation.ComparableAggregator
 
ComparableAggregator(int, TypeInformation<T>, AggregationFunction.AggregationType, boolean, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.aggregation.ComparableAggregator
 
ComparableAggregator(String, TypeInformation<T>, AggregationFunction.AggregationType, boolean, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.aggregation.ComparableAggregator
 
comparator - Variable in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
comparator - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 
Comparator - Class in org.apache.flink.streaming.api.functions.aggregation
Internal comparator implementation, for use with ComparableAggregator.
Comparator() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.Comparator
 
comparatorClass() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
 
comparators - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
comparators for the key fields, in the same order as the key fields
compare(boolean[], boolean[]) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArrayComparator
 
compare(byte[], byte[]) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArrayComparator
 
compare(char[], char[]) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArrayComparator
 
compare(double[], double[]) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArrayComparator
 
compare(float[], float[]) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArrayComparator
 
compare(int[], int[]) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArrayComparator
 
compare(long[], long[]) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArrayComparator
 
compare(short[], short[]) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArrayComparator
 
compare(T, T) - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
compare(BooleanValue, BooleanValue) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
compare(ByteValue, ByteValue) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
compare(CharValue, CharValue) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
compare(DoubleValue, DoubleValue) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
compare(FloatValue, FloatValue) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
compare(IntValue, IntValue) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
compare(LongValue, LongValue) - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
compare(NullValue, NullValue) - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
compare(ShortValue, ShortValue) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
compare(StringValue, StringValue) - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
compare(T, T) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Compares two records in object form.
compare(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
compare(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
compare(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
compare(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
compare(Row, Row) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
 
compare(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
 
compare(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
compare(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
 
compare(T, T) - Method in class org.apache.flink.api.scala.typeutils.CaseClassComparator
 
compare(Enumeration.Value, Enumeration.Value) - Method in class org.apache.flink.api.scala.typeutils.EnumValueComparator
 
compare(Option<A>, Option<A>) - Method in class org.apache.flink.api.scala.typeutils.OptionTypeComparator
 
compare(StreamRecord<IN>, StreamRecord<IN>) - Method in class org.apache.flink.cep.operator.StreamRecordComparator
 
compare(MemorySegment, int, int, int) - Method in class org.apache.flink.core.memory.MemorySegment
Compares two memory segment regions.
compare(IntValueArray, IntValueArray) - Method in class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
 
compare(LongValueArray, LongValueArray) - Method in class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
 
compare(NullValueArray, NullValueArray) - Method in class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
 
compare(StringValueArray, StringValueArray) - Method in class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
 
compare(IndexedRow) - Method in class org.apache.flink.ml.math.distributed.IndexedRow
 
compare(int, int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
compare(int, int, int, int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
compare(int, int) - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
Compare items at the given addresses consistent with the semantics of Comparator.compare(Object, Object).
compare(int, int, int, int) - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
Compare records at the given addresses consistent with the semantics of Comparator.compare(Object, Object).
compare(int, int) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
compare(int, int, int, int) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
compare(CRow, CRow) - Method in class org.apache.flink.table.runtime.types.CRowComparator
 
compare(T, T) - Method in class org.apache.flink.test.util.JavaProgramTestBase.TupleComparator
 
compare(T, T) - Method in class org.apache.flink.test.util.TestBaseUtils.TupleComparator
 
compareAccumulatorTypes(Object, Class<? extends Accumulator>, Class<? extends Accumulator>) - Static method in class org.apache.flink.api.common.accumulators.AccumulatorHelper
Compare both classes and throw UnsupportedOperationException if they differ
compareAgainstReference(Comparable[]) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
 
compareAgainstReference(Comparable<?>[]) - Static method in class org.apache.flink.api.scala.typeutils.OptionTypeComparator
 
compareEnum(String, Enum<?>) - Method in class org.apache.flink.table.codegen.CodeGenUtils$
 
compareEnum(String, Enum<?>) - Static method in class org.apache.flink.table.codegen.CodeGenUtils
 
compareKeyValuePairsWithDelta(String, String, String, double) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
compareKeyValuePairsWithDelta(String, String, String[], String, double) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
compareOrderedResultAsText(List<T>, String) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
compareOrderedResultAsText(List<T>, String, boolean) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
compareResultAsText(List<T>, String) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
compareResultAsTuples(List<T>, String) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
compareResultCollections(List<X>, List<X>, Comparator<X>) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
compareResultsByLinesInMemory(String, String) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
compareResultsByLinesInMemory(String, String, String[]) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
compareResultsByLinesInMemoryWithStrictOrder(String, String) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
compareResultsByLinesInMemoryWithStrictOrder(String, String, String[]) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BigDecComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BigIntComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.CharComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DateComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.EnumComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.IntComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LongComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Compares two records in serialized form.
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.scala.typeutils.EnumValueComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.api.scala.typeutils.OptionTypeComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
 
compareSerialized(DataInputView, DataInputView) - Method in class org.apache.flink.table.runtime.types.CRowComparator
 
compareSerializedDate(DataInputView, DataInputView, boolean) - Static method in class org.apache.flink.api.common.typeutils.base.DateComparator
 
compareTo(IntermediateSampleData<T>) - Method in class org.apache.flink.api.java.sampling.IntermediateSampleData
 
compareTo(BlockLocation) - Method in class org.apache.flink.core.fs.local.LocalBlockLocation
 
compareTo(Object) - Method in class org.apache.flink.core.fs.Path
 
compareTo(CirculantGraph.OffsetRange) - Method in class org.apache.flink.graph.generator.CirculantGraph.OffsetRange
 
compareTo(AdamicAdar.Result<T>) - Method in class org.apache.flink.graph.library.similarity.AdamicAdar.Result
 
compareTo(JaccardIndex.Result<T>) - Method in class org.apache.flink.graph.library.similarity.JaccardIndex.Result
 
compareTo(ValueArray<IntValue>) - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
 
compareTo(ValueArray<LongValue>) - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
 
compareTo(ValueArray<NullValue>) - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
 
compareTo(ValueArray<StringValue>) - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
 
compareTo(A) - Static method in class org.apache.flink.ml.math.distributed.IndexedRow
 
compareTo(Costs) - Method in class org.apache.flink.optimizer.costs.Costs
The order of comparison is: network first, then disk, then CPU.
compareTo(BlobKey) - Method in class org.apache.flink.runtime.blob.BlobKey
 
compareTo(ResourceProfile) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
 
compareTo(BlockLocation) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopBlockLocation
 
compareTo(TaskManagerLocation) - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
 
compareTo(TimestampedFileInputSplit) - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
 
compareTo(InternalTimer<K, N>) - Method in class org.apache.flink.streaming.api.operators.InternalTimer
 
compareTo(WindowOperator.Timer<K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
 
compareTo(BooleanValue) - Method in class org.apache.flink.types.BooleanValue
 
compareTo(ByteValue) - Method in class org.apache.flink.types.ByteValue
 
compareTo(CharValue) - Method in class org.apache.flink.types.CharValue
 
compareTo(DoubleValue) - Method in class org.apache.flink.types.DoubleValue
 
compareTo(FloatValue) - Method in class org.apache.flink.types.FloatValue
 
compareTo(IntValue) - Method in class org.apache.flink.types.IntValue
 
compareTo(LongValue) - Method in class org.apache.flink.types.LongValue
 
compareTo(NullValue) - Method in class org.apache.flink.types.NullValue
 
compareTo(ShortValue) - Method in class org.apache.flink.types.ShortValue
 
compareTo(StringValue) - Method in class org.apache.flink.types.StringValue
 
compareTo(AbstractID) - Method in class org.apache.flink.util.AbstractID
 
compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
compareToReference(TypeComparator<BooleanValue>) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
compareToReference(TypeComparator<ByteValue>) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
compareToReference(TypeComparator<CharValue>) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
compareToReference(TypeComparator<DoubleValue>) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
compareToReference(TypeComparator<FloatValue>) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
compareToReference(TypeComparator<IntValue>) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
compareToReference(TypeComparator<LongValue>) - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
compareToReference(TypeComparator<NullValue>) - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
compareToReference(TypeComparator<ShortValue>) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
compareToReference(TypeComparator<StringValue>) - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
compareToReference(T2) - Method in class org.apache.flink.api.common.typeutils.GenericPairComparator
 
compareToReference(T) - Method in class org.apache.flink.api.common.typeutils.SameTypePairComparator
 
compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
This method compares the element that has been set as reference in this type accessor, to the element set as reference in the given type accessor.
compareToReference(T2) - Method in class org.apache.flink.api.common.typeutils.TypePairComparator
 
compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
compareToReference(TypeComparator<Row>) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
 
compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
compareToReference(TypeComparator<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
 
compareToReference(TypeComparator<Enumeration.Value>) - Method in class org.apache.flink.api.scala.typeutils.EnumValueComparator
 
compareToReference(TypeComparator<Option<A>>) - Method in class org.apache.flink.api.scala.typeutils.OptionTypeComparator
 
compareToReference(TypeComparator<IntValueArray>) - Method in class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
 
compareToReference(TypeComparator<LongValueArray>) - Method in class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
 
compareToReference(TypeComparator<NullValueArray>) - Method in class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
 
compareToReference(TypeComparator<StringValueArray>) - Method in class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
 
compareToReference(TypeComparator<CRow>) - Method in class org.apache.flink.table.runtime.types.CRowComparator
 
comparison() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
comparison() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
CompatibilityResult<T> - Class in org.apache.flink.api.common.typeutils
A CompatibilityResult contains information about whether or not data migration is required in order to continue using new serializers for previously serialized data.
CompatibilityUtil - Class in org.apache.flink.api.common.typeutils
Utilities related to serializer compatibility.
CompatibilityUtil() - Constructor for class org.apache.flink.api.common.typeutils.CompatibilityUtil
 
compatible() - Static method in class org.apache.flink.api.common.typeutils.CompatibilityResult
Returns a result that signals that the new serializer is compatible and no migration is required.
CompensatedSum - Class in org.apache.flink.api.java.summarize.aggregation
Used to calculate sums using the Kahan summation algorithm The Kahan summation algorithm (also known as compensated summation) reduces the numerical errors that occur when adding a sequence of finite precision floating point numbers.
CompensatedSum(double, double) - Constructor for class org.apache.flink.api.java.summarize.aggregation.CompensatedSum
Used to calculate sums using the Kahan summation algorithm
compile(Pattern<T, ?>, TypeSerializer<T>, boolean) - Static method in class org.apache.flink.cep.nfa.compiler.NFACompiler
Compiles the given pattern into a NFA.
compile(Plan) - Method in class org.apache.flink.optimizer.Optimizer
Translates the given program to an OptimizedPlan, where all nodes have their local strategy assigned and all channels have a shipping strategy assigned.
compile(ClassLoader, String, String) - Method in interface org.apache.flink.table.codegen.Compiler
 
compileFactory(Pattern<T, ?>, TypeSerializer<T>, boolean) - Static method in class org.apache.flink.cep.nfa.compiler.NFACompiler
Compiles the given pattern into a NFACompiler.NFAFactory.
compileJobGraph(OptimizedPlan) - Method in class org.apache.flink.optimizer.plantranslate.JobGraphGenerator
Translates a OptimizedPlan into a JobGraph.
compileJobGraph(OptimizedPlan, JobID) - Method in class org.apache.flink.optimizer.plantranslate.JobGraphGenerator
 
Compiler<T> - Interface in org.apache.flink.table.codegen
 
CompilerException - Exception in org.apache.flink.optimizer
An exception that is thrown by the Optimizer when encountering an illegal condition.
CompilerException() - Constructor for exception org.apache.flink.optimizer.CompilerException
Creates a compiler exception with no message and no cause.
CompilerException(String) - Constructor for exception org.apache.flink.optimizer.CompilerException
Creates a compiler exception with the given message and no cause.
CompilerException(Throwable) - Constructor for exception org.apache.flink.optimizer.CompilerException
Creates a compiler exception with the given cause and no message.
CompilerException(String, Throwable) - Constructor for exception org.apache.flink.optimizer.CompilerException
Creates a compiler exception with the given message and cause.
CompilerHints - Class in org.apache.flink.api.common.operators
A class encapsulating compiler hints describing the behavior of the user function.
CompilerHints() - Constructor for class org.apache.flink.api.common.operators.CompilerHints
 
compilerHints - Variable in class org.apache.flink.api.common.operators.Operator
 
CompilerPostPassException - Exception in org.apache.flink.optimizer
An exception that is thrown by the Optimizer when encountering a problem during the optimizer post pass.
CompilerPostPassException() - Constructor for exception org.apache.flink.optimizer.CompilerPostPassException
Creates a post pass exception with no message and no cause.
CompilerPostPassException(String) - Constructor for exception org.apache.flink.optimizer.CompilerPostPassException
Creates a post pass exception with the given message and no cause.
CompilerPostPassException(Throwable) - Constructor for exception org.apache.flink.optimizer.CompilerPostPassException
Creates a post pass exception with the given cause and no message.
CompilerPostPassException(String, Throwable) - Constructor for exception org.apache.flink.optimizer.CompilerPostPassException
Creates a post pass exception with the given message and cause.
complementBlockInfo(BlockInfo) - Method in class org.apache.flink.api.common.io.BinaryOutputFormat
 
CompletableFuture<T> - Interface in org.apache.flink.runtime.concurrent
Flink's completable future abstraction.
complete(T) - Method in interface org.apache.flink.runtime.concurrent.CompletableFuture
Completes the future with the given value.
complete(T) - Method in class org.apache.flink.runtime.concurrent.impl.FlinkCompletableFuture
 
completed(T) - Static method in class org.apache.flink.runtime.concurrent.impl.FlinkCompletableFuture
 
CompletedCheckpoint - Class in org.apache.flink.runtime.checkpoint
A CompletedCheckpoint describes a checkpoint after all required tasks acknowledged it (with their state) and that is considered successful.
CompletedCheckpoint(JobID, long, long, long, Map<OperatorID, OperatorState>, Collection<MasterState>, CheckpointProperties, StreamStateHandle, String) - Constructor for class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
CompletedCheckpointStats - Class in org.apache.flink.runtime.checkpoint
Statistics for a successfully completed checkpoint.
CompletedCheckpointStatsSummary - Class in org.apache.flink.runtime.checkpoint
Summary over all completed checkpoints.
CompletedCheckpointStore - Interface in org.apache.flink.runtime.checkpoint
A bounded LIFO-queue of CompletedCheckpoint instances.
completedExceptionally(Throwable) - Static method in class org.apache.flink.runtime.concurrent.impl.FlinkCompletableFuture
 
completeExceptionally(Throwable) - Method in interface org.apache.flink.runtime.concurrent.CompletableFuture
Completes the future with the given exception.
completeExceptionally(Throwable) - Method in class org.apache.flink.runtime.concurrent.impl.FlinkCompletableFuture
 
CompleteGraph - Class in org.apache.flink.graph.drivers.input
Generate a CompleteGraph.
CompleteGraph() - Constructor for class org.apache.flink.graph.drivers.input.CompleteGraph
 
CompleteGraph - Class in org.apache.flink.graph.generator
 
CompleteGraph(ExecutionEnvironment, long) - Constructor for class org.apache.flink.graph.generator.CompleteGraph
An undirected Graph connecting every distinct pair of vertices.
ComponentIdFilter() - Constructor for class org.apache.flink.examples.java.graph.ConnectedComponents.ComponentIdFilter
 
ComponentMetricGroup<P extends AbstractMetricGroup<?>> - Class in org.apache.flink.runtime.metrics.groups
Abstract MetricGroup for system components (e.g., TaskManager, Job, Task, Operator).
ComponentMetricGroup(MetricRegistry, String[], P) - Constructor for class org.apache.flink.runtime.metrics.groups.ComponentMetricGroup
Creates a new ComponentMetricGroup.
composite() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
composite() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
compositeBuffer() - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
 
compositeBuffer(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
 
CompositeContainerOverlay - Class in org.apache.flink.runtime.clusterframework.overlays
A composite overlay that delegates to a set of inner overlays.
CompositeContainerOverlay(ContainerOverlay...) - Constructor for class org.apache.flink.runtime.clusterframework.overlays.CompositeContainerOverlay
 
CompositeContainerOverlay(List<ContainerOverlay>) - Constructor for class org.apache.flink.runtime.clusterframework.overlays.CompositeContainerOverlay
 
compositeDirectBuffer() - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
 
compositeDirectBuffer(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
 
compositeHeapBuffer() - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
 
compositeHeapBuffer(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
 
CompositeRelDataType - Class in org.apache.flink.table.plan.schema
Composite type for encapsulating Flink's CompositeType.
CompositeRelDataType(CompositeType<?>, boolean, FlinkTypeFactory) - Constructor for class org.apache.flink.table.plan.schema.CompositeRelDataType
 
CompositeRelDataType$ - Class in org.apache.flink.table.plan.schema
 
CompositeRelDataType$() - Constructor for class org.apache.flink.table.plan.schema.CompositeRelDataType$
 
CompositeStateHandle - Interface in org.apache.flink.runtime.state
Base of all snapshots that are taken by StateBackends and some other components in tasks.
CompositeType<T> - Class in org.apache.flink.api.common.typeutils
Base type information class for Tuple and Pojo types The class is taking care of serialization and comparators for Tuples as well.
CompositeType(Class<T>) - Constructor for class org.apache.flink.api.common.typeutils.CompositeType
 
compositeType() - Method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
CompositeType.FlatFieldDescriptor - Class in org.apache.flink.api.common.typeutils
 
CompositeType.InvalidFieldReferenceException - Exception in org.apache.flink.api.common.typeutils
 
CompositeType.TypeComparatorBuilder<T> - Interface in org.apache.flink.api.common.typeutils
 
CompositeTypeComparator<T> - Class in org.apache.flink.api.common.typeutils
 
CompositeTypeComparator() - Constructor for class org.apache.flink.api.common.typeutils.CompositeTypeComparator
 
CompositeTypeSerializerConfigSnapshot - Class in org.apache.flink.api.common.typeutils
A TypeSerializerConfigSnapshot for serializers that has multiple nested serializers.
CompositeTypeSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
CompositeTypeSerializerConfigSnapshot(TypeSerializer<?>...) - Constructor for class org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
 
ComputationState<T> - Class in org.apache.flink.cep.nfa
Helper class which encapsulates the state of the NFA computation.
ComputationState.ConditionContext - Class in org.apache.flink.cep.nfa
The context used when evaluating this computation state.
compute(Vertex<Long, Double>, MessageIterator<Double>) - Method in class org.apache.flink.graph.examples.PregelSSSP.SSSPComputeFunction
 
compute(Vertex<K, VV>, MessageIterator<Message>) - Method in class org.apache.flink.graph.pregel.ComputeFunction
This method is invoked once per superstep, for each active vertex.
computeAffinity(DataSet<StochasticOutlierSelection.BreezeLabeledVector>, ParameterMap) - Method in class org.apache.flink.ml.outlier.StochasticOutlierSelection$
Approximate the affinity by fitting a Gaussian-like function
computeAffinity(DataSet<StochasticOutlierSelection.BreezeLabeledVector>, ParameterMap) - Static method in class org.apache.flink.ml.outlier.StochasticOutlierSelection
Approximate the affinity by fitting a Gaussian-like function
computeBindingProbabilities(DataSet<StochasticOutlierSelection.BreezeLabeledVector>) - Method in class org.apache.flink.ml.outlier.StochasticOutlierSelection$
Normalizes the input vectors so each row sums up to one.
computeBindingProbabilities(DataSet<StochasticOutlierSelection.BreezeLabeledVector>) - Static method in class org.apache.flink.ml.outlier.StochasticOutlierSelection
Normalizes the input vectors so each row sums up to one.
computeDefaultMaxParallelism(int) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
Computes a default maximum parallelism from the operator parallelism.
computeDigest() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
computeDigest() - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
computeDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
computeDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
computeDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
computeDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
computeDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
computeDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
computeDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
computeDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
computeDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
computeDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
computeDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
computeDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
computeDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
computeDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
computeDigest() - Static method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
computeDissimilarityVectors(DataSet<StochasticOutlierSelection.BreezeLabeledVector>) - Method in class org.apache.flink.ml.outlier.StochasticOutlierSelection$
Compute pair-wise distance from each vector, to all other vectors.
computeDissimilarityVectors(DataSet<StochasticOutlierSelection.BreezeLabeledVector>) - Static method in class org.apache.flink.ml.outlier.StochasticOutlierSelection
Compute pair-wise distance from each vector, to all other vectors.
ComputeFunction<K,VV,EV,Message> - Class in org.apache.flink.graph.pregel
The base class for the message-passing functions between vertices as a part of a VertexCentricIteration.
ComputeFunction() - Constructor for class org.apache.flink.graph.pregel.ComputeFunction
 
computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.dag.PartitionNode.PartitionDescriptor
 
computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.dag.SortPartitionNode.SortPartitionDescriptor
 
computeGlobalProperties(GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.AbstractJoinDescriptor
 
computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.AllGroupCombineProperties
 
computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.AllGroupReduceProperties
 
computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.AllGroupWithPartialPreGroupProperties
 
computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.AllReduceProperties
 
computeGlobalProperties(GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.BinaryUnionOpDescriptor
 
computeGlobalProperties(GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.CartesianProductDescriptor
 
computeGlobalProperties(GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupDescriptor
 
computeGlobalProperties(GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupRawDescriptor
 
computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.FilterDescriptor
 
computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.FlatMapDescriptor
 
computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.GroupCombineProperties
 
computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.GroupReduceProperties
 
computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.GroupReduceWithCombineProperties
 
computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.MapDescriptor
 
computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.MapPartitionDescriptor
 
computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.NoOpDescriptor
 
computeGlobalProperties(GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
 
computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorSingle
Returns the global properties which are present after the operator was applied on the provided global properties.
computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.PartialGroupProperties
 
computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.ReduceProperties
 
computeGlobalProperties(GlobalProperties) - Method in class org.apache.flink.optimizer.operators.SolutionSetDeltaOperator
 
computeGlobalProperties(GlobalProperties, GlobalProperties) - Method in class org.apache.flink.optimizer.operators.UtilSinkJoinOpDescriptor
 
computeInterestingPropertiesForInputs(CostEstimator) - Method in class org.apache.flink.optimizer.dag.AbstractPartialSolutionNode
 
computeInterestingPropertiesForInputs(CostEstimator) - Method in class org.apache.flink.optimizer.dag.BinaryUnionNode
 
computeInterestingPropertiesForInputs(CostEstimator) - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
 
computeInterestingPropertiesForInputs(CostEstimator) - Method in class org.apache.flink.optimizer.dag.DataSinkNode
 
computeInterestingPropertiesForInputs(CostEstimator) - Method in class org.apache.flink.optimizer.dag.DataSourceNode
 
computeInterestingPropertiesForInputs(CostEstimator) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
Tells the node to compute the interesting properties for its inputs.
computeInterestingPropertiesForInputs(CostEstimator) - Method in class org.apache.flink.optimizer.dag.SingleInputNode
 
computeInterestingPropertiesForInputs(CostEstimator) - Method in class org.apache.flink.optimizer.dag.TwoInputNode
 
computeInterestingPropertiesForInputs(CostEstimator) - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
 
computeKeyGroupForKeyHash(int, int) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
Assigns the given key to a key-group index.
computeKeyGroupRangeForOperatorIndex(int, int, int) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
Computes the range of key-groups that are assigned to a given operator under the given parallelism and maximum parallelism.
computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.dag.PartitionNode.PartitionDescriptor
 
computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.dag.SortPartitionNode.SortPartitionDescriptor
 
computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.AbstractSortMergeJoinDescriptor
 
computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.AllGroupCombineProperties
 
computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.AllGroupReduceProperties
 
computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.AllGroupWithPartialPreGroupProperties
 
computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.AllReduceProperties
 
computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.BinaryUnionOpDescriptor
 
computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupDescriptor
 
computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupRawDescriptor
 
computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupWithSolutionSetFirstDescriptor
 
computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CoGroupWithSolutionSetSecondDescriptor
 
computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CrossBlockOuterFirstDescriptor
 
computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CrossBlockOuterSecondDescriptor
 
computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CrossStreamOuterFirstDescriptor
 
computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.CrossStreamOuterSecondDescriptor
 
computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.FilterDescriptor
 
computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.FlatMapDescriptor
 
computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.GroupCombineProperties
 
computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.GroupReduceProperties
 
computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.GroupReduceWithCombineProperties
 
computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashFullOuterJoinBuildFirstDescriptor
 
computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashFullOuterJoinBuildSecondDescriptor
 
computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashJoinBuildFirstProperties
 
computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashJoinBuildSecondProperties
 
computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashLeftOuterJoinBuildFirstDescriptor
 
computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashLeftOuterJoinBuildSecondDescriptor
 
computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashRightOuterJoinBuildFirstDescriptor
 
computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.HashRightOuterJoinBuildSecondDescriptor
 
computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.MapDescriptor
 
computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.MapPartitionDescriptor
 
computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.NoOpDescriptor
 
computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
 
computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorSingle
Returns the local properties which are present after the operator was applied on the provided local properties.
computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.PartialGroupProperties
 
computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.ReduceProperties
 
computeLocalProperties(LocalProperties) - Method in class org.apache.flink.optimizer.operators.SolutionSetDeltaOperator
 
computeLocalProperties(LocalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.operators.UtilSinkJoinOpDescriptor
 
computeLogicalKeyPositions() - Method in class org.apache.flink.api.common.operators.Keys
 
computeLogicalKeyPositions() - Method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
computeLogicalKeyPositions() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
computeMemorySize(double) - Method in class org.apache.flink.runtime.memory.MemoryManager
Computes the memory size of the fraction per slot.
computeNumberOfPages(double) - Method in class org.apache.flink.runtime.memory.MemoryManager
Computes to how many pages the given number of bytes corresponds.
computeOperatorIndexForKeyGroup(int, int, int) - Static method in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
Computes the index of the operator to which a key-group belongs under the given parallelism and maximum parallelism.
computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.AbstractPartialSolutionNode
 
computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.BinaryUnionNode
 
computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
 
computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.CoGroupNode
 
computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.CoGroupRawNode
 
computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.CrossNode
We assume that the cardinality is the product of the input cardinalities and that the result width is the sum of the input widths.
computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.DataSinkNode
Computes the estimated outputs for the data sink.
computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.DataSourceNode
 
computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.FilterNode
Computes the estimates for the Filter operator.
computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.FlatMapNode
Computes the estimates for the FlatMap operator.
computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.GroupCombineNode
 
computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.GroupReduceNode
 
computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.JoinNode
The default estimates build on the principle of inclusion: The smaller input key domain is included in the larger input key domain.
computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.MapNode
Computes the estimates for the Map operator.
computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.MapPartitionNode
Computes the estimates for the MapPartition operator.
computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.NoOpNode
 
computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.OuterJoinNode
 
computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.PartitionNode
 
computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.ReduceNode
 
computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.SinkJoiner
 
computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.SortPartitionNode
 
computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.UnaryOperatorNode
 
computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
 
computeOperatorSpecificDefaultEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode.SingleRootJoiner
 
computeOutlierProbability(DataSet<StochasticOutlierSelection.BreezeLabeledVector>) - Method in class org.apache.flink.ml.outlier.StochasticOutlierSelection$
Compute the final outlier probability by taking the product of the column.
computeOutlierProbability(DataSet<StochasticOutlierSelection.BreezeLabeledVector>) - Static method in class org.apache.flink.ml.outlier.StochasticOutlierSelection
Compute the final outlier probability by taking the product of the column.
computeOutputEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.BinaryUnionNode
 
computeOutputEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.BulkPartialSolutionNode
 
computeOutputEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
Causes this node to compute its output estimates (such as number of rows, size in bytes) based on the inputs and the compiler hints.
computeOutputEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.SinkJoiner
 
computeOutputEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.SolutionSetNode
 
computeOutputEstimates(DataStatistics) - Method in class org.apache.flink.optimizer.dag.WorksetNode
 
computeSelfCost(RelOptPlanner) - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
computeSelfCost(RexProgram, RelOptPlanner, double) - Method in interface org.apache.flink.table.plan.nodes.CommonCalc
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.dataset.BatchTableSourceScan
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetAggregate
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetCalc
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetCorrelate
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetDistinct
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetIntersect
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetJoin
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetMinus
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetScan
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetSingleRowJoin
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetUnion
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetWindowAggregate
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamCalc
 
computeSelfCost(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.datastream.StreamTableSourceScan
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
computeSelfCost(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
computeSelfCost(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
computeSelfCost(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
computeSelfCost(RelOptPlanner, RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
computeUnclosedBranchStack() - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
 
computeUnclosedBranchStack() - Method in class org.apache.flink.optimizer.dag.BulkPartialSolutionNode
 
computeUnclosedBranchStack() - Method in class org.apache.flink.optimizer.dag.DataSinkNode
 
computeUnclosedBranchStack() - Method in class org.apache.flink.optimizer.dag.DataSourceNode
 
computeUnclosedBranchStack() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
This method causes the node to compute the description of open branches in its sub-plan.
computeUnclosedBranchStack() - Method in class org.apache.flink.optimizer.dag.SingleInputNode
 
computeUnclosedBranchStack() - Method in class org.apache.flink.optimizer.dag.SinkJoiner
 
computeUnclosedBranchStack() - Method in class org.apache.flink.optimizer.dag.SolutionSetNode
 
computeUnclosedBranchStack() - Method in class org.apache.flink.optimizer.dag.TwoInputNode
 
computeUnclosedBranchStack() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
 
computeUnclosedBranchStack() - Method in class org.apache.flink.optimizer.dag.WorksetNode
 
computeUnclosedBranchStackForBroadcastInputs(List<OptimizerNode.UnclosedBranchDescriptor>) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
computeUnionOfInterestingPropertiesFromSuccessors() - Method in class org.apache.flink.optimizer.dag.BinaryUnionNode
 
computeUnionOfInterestingPropertiesFromSuccessors() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
Computes all the interesting properties that are relevant to this node.
computeWindowStartEndPropertyPos(Seq<FlinkRelBuilder.NamedWindowProperty>) - Method in class org.apache.flink.table.runtime.aggregate.AggregateUtil$
 
computeWindowStartEndPropertyPos(Seq<FlinkRelBuilder.NamedWindowProperty>) - Static method in class org.apache.flink.table.runtime.aggregate.AggregateUtil
 
CONCAT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
String concatenation operator, '||'.
concat(String...) - Static method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
 
concat(CharacterFilter, String...) - Static method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
 
concat(Character, String...) - Static method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
 
concat(CharacterFilter, Character, String...) - Static method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
Concatenates the given component names separated by the delimiter character.
concatenate(Record) - Method in class org.apache.flink.types.Record
 
ConcatenatedExtract<FROM,OVER,TO> - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
Combines two extractors which will be executed one after each other.
ConcatenatedExtract(Extractor<FROM, OVER>, Extractor<OVER, TO>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ConcatenatedExtract
Combines two extractors which will be executed one after each other.
concatenateWithAnd(String, String) - Static method in class org.apache.flink.util.StringUtils
If both string arguments are non-null, this method concatenates them with ' and '.
concatScopes(String) - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
 
condition() - Method in class org.apache.flink.table.expressions.If
 
condition() - Method in class org.apache.flink.table.plan.logical.Filter
 
condition() - Method in class org.apache.flink.table.plan.logical.Join
 
ConditionContext(NFA<T>, ComputationState<T>) - Constructor for class org.apache.flink.cep.nfa.ComputationState.ConditionContext
 
conditionToString(RexProgram, Function3<RexNode, List<String>, Option<List<RexNode>>, String>) - Method in interface org.apache.flink.table.plan.nodes.CommonCalc
 
conditionToString(RexProgram, Function3<RexNode, List<String>, Option<List<RexNode>>, String>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
CONF_COMPRESS - Static variable in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter
 
CONF_COMPRESS_CODEC - Static variable in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter
 
CONF_DEFLATE_LEVEL - Static variable in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter
 
CONF_OUTPUT_KEY_SCHEMA - Static variable in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter
 
CONF_OUTPUT_VALUE_SCHEMA - Static variable in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter
 
CONF_XZ_LEVEL - Static variable in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter
 
confData - Variable in class org.apache.flink.configuration.Configuration
Stores the concrete key/value pairs of this configuration object.
config - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
 
Config(Option<String>, Option<Object>, Option<String[]>, Enumeration.Value, Option<FlinkShell.YarnConfig>, Option<String>) - Constructor for class org.apache.flink.api.scala.FlinkShell.Config
 
config() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
config - Variable in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
The Flink configuration object
config - Variable in class org.apache.flink.runtime.operators.BatchTask
The task configuration with the setup parameters.
config - Variable in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
config - Variable in class org.apache.flink.runtime.operators.util.TaskConfig
 
config() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
 
config - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
config() - Method in class org.apache.flink.table.api.TableEnvironment
 
config - Variable in class org.apache.flink.test.util.AbstractTestBase
Configuration to start the testing cluster with
config() - Method in class org.apache.flink.yarn.YarnMessages.StartYarnSession
 
config() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
Config$() - Constructor for class org.apache.flink.api.scala.FlinkShell.Config$
 
CONFIG_FILE_LOG4J_NAME - Static variable in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
 
CONFIG_FILE_LOGBACK_NAME - Static variable in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
 
CONFIG_KEY_BULK_FLUSH_BACKOFF_DELAY - Static variable in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase
 
CONFIG_KEY_BULK_FLUSH_BACKOFF_ENABLE - Static variable in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase
 
CONFIG_KEY_BULK_FLUSH_BACKOFF_RETRIES - Static variable in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase
 
CONFIG_KEY_BULK_FLUSH_BACKOFF_TYPE - Static variable in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase
 
CONFIG_KEY_BULK_FLUSH_INTERVAL_MS - Static variable in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase
 
CONFIG_KEY_BULK_FLUSH_MAX_ACTIONS - Static variable in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase
 
CONFIG_KEY_BULK_FLUSH_MAX_SIZE_MB - Static variable in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase
 
configBuilder() - Static method in class org.apache.calcite.sql2rel.SqlToRelConverter
Creates a builder for a SqlToRelConverter.Config.
ConfigConstants - Class in org.apache.flink.configuration
This class contains all constants for the configuration.
configDir() - Method in class org.apache.flink.api.scala.FlinkShell.Config
 
ConfigOption<T> - Class in org.apache.flink.configuration
A ConfigOption describes a configuration parameter.
ConfigOptions - Class in org.apache.flink.configuration
ConfigOptions are used to build a ConfigOption.
ConfigOptions.OptionBuilder - Class in org.apache.flink.configuration
The option builder is used to create a ConfigOption.
ConfigurableStreamPartitioner - Interface in org.apache.flink.streaming.runtime.partitioner
Interface for StreamPartitioner which have to be configured with the maximum parallelism of the stream transformation.
configuration - Variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
 
Configuration - Class in org.apache.flink.configuration
Lightweight configuration object which stores key/value pairs.
Configuration() - Constructor for class org.apache.flink.configuration.Configuration
Creates a new empty configuration.
Configuration(Configuration) - Constructor for class org.apache.flink.configuration.Configuration
Creates a new configuration with the copy of the given configuration.
configuration() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
ConfigurationException - Exception in org.apache.flink.util
Exception which occurs when creating a configuration object fails.
ConfigurationException(String) - Constructor for exception org.apache.flink.util.ConfigurationException
 
ConfigurationException(String, Throwable) - Constructor for exception org.apache.flink.util.ConfigurationException
 
ConfigurationException(Throwable) - Constructor for exception org.apache.flink.util.ConfigurationException
 
ConfigurationUtil - Class in org.apache.flink.util
Utility for accessing deprecated Configuration values.
ConfigurationUtil() - Constructor for class org.apache.flink.util.ConfigurationUtil
 
configure(Configuration) - Method in class org.apache.flink.addons.hbase.AbstractTableInputFormat
Creates a Scan object and opens the HTable connection.
configure(Configuration) - Method in class org.apache.flink.addons.hbase.HBaseRowInputFormat
 
configure(Configuration) - Method in class org.apache.flink.addons.hbase.TableInputFormat
Creates a Scan object and opens the HTable connection.
configure(Configuration) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
 
configure(Configuration) - Method in class org.apache.flink.api.common.io.BinaryOutputFormat
 
configure(Configuration) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
Configures this input format by reading the path to the file from the configuration and the string that defines the record delimiter.
configure(Configuration) - Method in class org.apache.flink.api.common.io.FileInputFormat
Configures the file input format by reading the file path from the configuration.
configure(Configuration) - Method in class org.apache.flink.api.common.io.FileOutputFormat
 
configure(Configuration) - Method in class org.apache.flink.api.common.io.GenericInputFormat
 
configure(Configuration) - Method in interface org.apache.flink.api.common.io.InputFormat
Configures this input format.
configure(Configuration) - Method in interface org.apache.flink.api.common.io.OutputFormat
Configures this output format.
configure(Configuration) - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
 
configure(Configuration) - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
configure(Configuration) - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
 
configure(Configuration) - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
configure(Configuration) - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
 
configure(Configuration) - Method in class org.apache.flink.api.java.io.DiscardingOutputFormat
 
configure(Configuration) - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat
 
configure(Configuration) - Method in class org.apache.flink.api.java.io.jdbc.JDBCOutputFormat
 
configure(Configuration) - Method in class org.apache.flink.api.java.io.LocalCollectionOutputFormat
 
configure(Configuration) - Method in class org.apache.flink.api.java.io.PrintingOutputFormat
 
configure(Configuration) - Method in class org.apache.flink.api.java.io.TextInputFormat
 
configure(Configuration) - Method in class org.apache.flink.api.java.io.TextValueInputFormat
 
configure(Configuration) - Method in class org.apache.flink.api.java.Utils.ChecksumHashCodeHelper
 
configure(Configuration) - Method in class org.apache.flink.api.java.Utils.CollectHelper
 
configure(Configuration) - Method in class org.apache.flink.api.java.Utils.CountHelper
 
configure(Configuration) - Method in class org.apache.flink.batch.connectors.cassandra.CassandraInputFormat
 
configure(Configuration) - Method in class org.apache.flink.batch.connectors.cassandra.CassandraOutputFormat
 
configure(Configuration) - Method in class org.apache.flink.examples.java.distcp.FileCopyTaskInputFormat
 
configure(Configuration) - Method in class org.apache.flink.graph.AnalyticHelper
 
configure(ParameterTool) - Method in class org.apache.flink.graph.drivers.input.CirculantGraph
 
configure(ParameterTool) - Method in class org.apache.flink.graph.drivers.input.GridGraph
 
configure(ParameterTool) - Method in class org.apache.flink.graph.drivers.parameter.BooleanParameter
 
configure(ParameterTool) - Method in class org.apache.flink.graph.drivers.parameter.ChoiceParameter
 
configure(ParameterTool) - Method in class org.apache.flink.graph.drivers.parameter.DoubleParameter
 
configure(ParameterTool) - Method in class org.apache.flink.graph.drivers.parameter.IterationConvergence
 
configure(ParameterTool) - Method in class org.apache.flink.graph.drivers.parameter.LongParameter
 
configure(ParameterTool) - Method in interface org.apache.flink.graph.drivers.parameter.Parameter
Read and parse the parameter value from command-line arguments.
configure(ParameterTool) - Method in interface org.apache.flink.graph.drivers.parameter.Parameterized
Read parameter values from the command-line arguments.
configure(ParameterTool) - Method in class org.apache.flink.graph.drivers.parameter.ParameterizedBase
 
configure(ParameterTool) - Method in class org.apache.flink.graph.drivers.parameter.Simplify
 
configure(ParameterTool) - Method in class org.apache.flink.graph.drivers.parameter.StringParameter
 
configure(GSAConfiguration) - Method in class org.apache.flink.graph.gsa.GatherSumApplyIteration
Configures this gather-sum-apply iteration with the provided parameters.
configure(VertexCentricConfiguration) - Method in class org.apache.flink.graph.pregel.VertexCentricIteration
Configures this vertex-centric iteration with the provided parameters.
configure(ScatterGatherConfiguration) - Method in class org.apache.flink.graph.spargel.ScatterGatherIteration
Configures this scatter-gather iteration with the provided parameters.
configure(Configuration) - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
 
configure(Configuration) - Method in class org.apache.flink.hcatalog.scala.HCatInputFormat
 
configure(ContainerSpecification) - Method in class org.apache.flink.runtime.clusterframework.overlays.CompositeContainerOverlay
 
configure(ContainerSpecification) - Method in interface org.apache.flink.runtime.clusterframework.overlays.ContainerOverlay
Configure the given container specification.
configure(ContainerSpecification) - Method in class org.apache.flink.runtime.clusterframework.overlays.FlinkDistributionOverlay
 
configure(ContainerSpecification) - Method in class org.apache.flink.runtime.clusterframework.overlays.HadoopConfOverlay
 
configure(ContainerSpecification) - Method in class org.apache.flink.runtime.clusterframework.overlays.HadoopUserOverlay
 
configure(ContainerSpecification) - Method in class org.apache.flink.runtime.clusterframework.overlays.KeytabOverlay
 
configure(ContainerSpecification) - Method in class org.apache.flink.runtime.clusterframework.overlays.Krb5ConfOverlay
 
configure(ContainerSpecification) - Method in class org.apache.flink.runtime.clusterframework.overlays.SSLStoreOverlay
 
configure(String[], TypeInformation<?>[]) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSink
 
configure(int) - Method in interface org.apache.flink.streaming.runtime.partitioner.ConfigurableStreamPartitioner
Configure the StreamPartitioner with the maximum parallelism of the down stream operator.
configure(int) - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
 
configure(String[], TypeInformation<?>[]) - Static method in class org.apache.flink.table.sinks.CsvTableSink
 
configure(String[], TypeInformation<?>[]) - Method in interface org.apache.flink.table.sinks.TableSink
Return a copy of this TableSink configured with the field names and types of the Table to emit.
configure(String[], TypeInformation<?>[]) - Method in interface org.apache.flink.table.sinks.TableSinkBase
Return a copy of this TableSink configured with the field names and types of the Table to emit.
CONFIGURE_MUTEX - Static variable in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
 
CONFIGURE_MUTEX - Static variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
 
configureBulkProcessorBackoff(BulkProcessor.Builder, ElasticsearchSinkBase.BulkFlushBackoffPolicy) - Method in class org.apache.flink.streaming.connectors.elasticsearch.Elasticsearch1ApiCallBridge
 
configureBulkProcessorBackoff(BulkProcessor.Builder, ElasticsearchSinkBase.BulkFlushBackoffPolicy) - Method in interface org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchApiCallBridge
Set backoff-related configurations on the provided BulkProcessor.Builder.
configureBulkProcessorBackoff(BulkProcessor.Builder, ElasticsearchSinkBase.BulkFlushBackoffPolicy) - Method in class org.apache.flink.streaming.connectors.elasticsearch2.Elasticsearch2ApiCallBridge
 
configureBulkProcessorBackoff(BulkProcessor.Builder, ElasticsearchSinkBase.BulkFlushBackoffPolicy) - Method in class org.apache.flink.streaming.connectors.elasticsearch5.Elasticsearch5ApiCallBridge
 
confirmCheckpoint(ExecutionAttemptID, long, long) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
confirmCheckpoint(ExecutionAttemptID, long, long) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Confirm a checkpoint for the given task.
confirmLeaderSessionID(UUID) - Method in class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
 
confirmLeaderSessionID(UUID) - Method in interface org.apache.flink.runtime.leaderelection.LeaderElectionService
Confirms that the new leader session ID has been successfully received by the new leader.
confirmLeaderSessionID(UUID) - Method in class org.apache.flink.runtime.leaderelection.StandaloneLeaderElectionService
 
confirmLeaderSessionID(UUID) - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
 
ConflictingFieldTypeInfoException - Exception in org.apache.flink.optimizer.postpass
 
ConflictingFieldTypeInfoException(int, Object, Object) - Constructor for exception org.apache.flink.optimizer.postpass.ConflictingFieldTypeInfoException
 
conflictsWith(OptionalBoolean) - Method in class org.apache.flink.graph.utils.proxy.OptionalBoolean
The conflicting states are true with false and false with true.
connecDataSet(IntermediateDataSet) - Method in class org.apache.flink.runtime.jobgraph.JobEdge
 
connect(String, Class<C>) - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
connect(String, Class<C>) - Method in interface org.apache.flink.runtime.rpc.RpcService
Connect to a remote rpc server under the provided address.
connect(DataStream<R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Creates a new ConnectedStreams by connecting DataStream outputs of (possible) different types with each other.
connect(DataStream<T2>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Creates a new ConnectedStreams by connecting DataStream outputs of different type with each other.
CONNECT_BACKLOG - Static variable in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
CONNECT_RETRY_RATE() - Method in class org.apache.flink.mesos.scheduler.ConnectionMonitor$
 
CONNECT_RETRY_RATE() - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
connectDataSetAsInput(IntermediateDataSet, DistributionPattern) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
Connected - Class in org.apache.flink.mesos.scheduler.messages
Message sent by the callback handler to the scheduler actor when the scheduler becomes "connected" to the master.
Connected() - Constructor for class org.apache.flink.mesos.scheduler.messages.Connected
 
ConnectedComponents - Class in org.apache.flink.examples.java.graph
An implementation of the connected components algorithm, using a delta iteration.
ConnectedComponents() - Constructor for class org.apache.flink.examples.java.graph.ConnectedComponents
 
ConnectedComponents - Class in org.apache.flink.examples.scala.graph
An implementation of the connected components algorithm, using a delta iteration.
ConnectedComponents() - Constructor for class org.apache.flink.examples.scala.graph.ConnectedComponents
 
ConnectedComponents<K extends Comparable<K>,VV,EV> - Class in org.apache.flink.graph.drivers
ConnectedComponents() - Constructor for class org.apache.flink.graph.drivers.ConnectedComponents
 
ConnectedComponents<K,VV extends Comparable<VV>,EV> - Class in org.apache.flink.graph.library
A scatter-gather implementation of the Weakly Connected Components algorithm.
ConnectedComponents(Integer) - Constructor for class org.apache.flink.graph.library.ConnectedComponents
Creates an instance of the Connected Components algorithm.
ConnectedComponents - Class in org.apache.flink.graph.scala.examples
This example shows how to use Gelly's library methods.
ConnectedComponents() - Constructor for class org.apache.flink.graph.scala.examples.ConnectedComponents
 
ConnectedComponents$ - Class in org.apache.flink.examples.scala.graph
An implementation of the connected components algorithm, using a delta iteration.
ConnectedComponents$() - Constructor for class org.apache.flink.examples.scala.graph.ConnectedComponents$
 
ConnectedComponents$ - Class in org.apache.flink.graph.scala.examples
This example shows how to use Gelly's library methods.
ConnectedComponents$() - Constructor for class org.apache.flink.graph.scala.examples.ConnectedComponents$
 
ConnectedComponents.CCMessenger<K,VV extends Comparable<VV>> - Class in org.apache.flink.graph.library
Sends the current vertex value to all adjacent vertices.
ConnectedComponents.CCUpdater<K,VV extends Comparable<VV>> - Class in org.apache.flink.graph.library
Updates the value of a vertex by picking the minimum neighbor value out of all the incoming messages.
ConnectedComponents.ComponentIdFilter - Class in org.apache.flink.examples.java.graph
 
ConnectedComponents.DuplicateValue<T> - Class in org.apache.flink.examples.java.graph
Function that turns a value into a 2-tuple where both fields are that value.
ConnectedComponents.NeighborWithComponentIDJoin - Class in org.apache.flink.examples.java.graph
UDF that joins a (Vertex-ID, Component-ID) pair that represents the current component that a vertex is associated with, with a (Source-Vertex-ID, Target-VertexID) edge.
ConnectedComponents.UndirectEdge - Class in org.apache.flink.examples.java.graph
Undirected edges by emitting for each input edge the input edges itself and an inverted version.
ConnectedComponentsData - Class in org.apache.flink.examples.java.graph.util
Provides the default data sets used for the Connected Components example program.
ConnectedComponentsData() - Constructor for class org.apache.flink.examples.java.graph.util.ConnectedComponentsData
 
ConnectedComponentsData - Class in org.apache.flink.test.testdata
 
ConnectedComponentsDefaultData - Class in org.apache.flink.graph.examples.data
Provides the default data sets used for the connected components example program.
ConnectedIterativeStreams(DataStream<I>, TypeInformation<F>, long) - Constructor for class org.apache.flink.streaming.api.datastream.IterativeStream.ConnectedIterativeStreams
 
ConnectedState$() - Constructor for class org.apache.flink.mesos.scheduler.ConnectionMonitor.ConnectedState$
 
ConnectedStreams<IN1,IN2> - Class in org.apache.flink.streaming.api.datastream
ConnectedStreams represent two connected streams of (possibly) different data types.
ConnectedStreams(StreamExecutionEnvironment, DataStream<IN1>, DataStream<IN2>) - Constructor for class org.apache.flink.streaming.api.datastream.ConnectedStreams
 
ConnectedStreams<IN1,IN2> - Class in org.apache.flink.streaming.api.scala
ConnectedStreams represents two connected streams of (possibly) different data types.
ConnectedStreams(ConnectedStreams<IN1, IN2>) - Constructor for class org.apache.flink.streaming.api.scala.ConnectedStreams
 
connectedToJobManager() - Method in class org.apache.flink.runtime.client.JobAttachmentClientActor
 
connectedToJobManager() - Method in class org.apache.flink.runtime.client.JobClientActor
Hook to be called once a connection has been established with the JobManager.
connectedToJobManager() - Method in class org.apache.flink.runtime.client.JobSubmissionClientActor
 
connectIdInput(IntermediateDataSetID, DistributionPattern) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
ConnectingState$() - Constructor for class org.apache.flink.mesos.scheduler.ConnectionMonitor.ConnectingState$
 
connection - Variable in class org.apache.flink.streaming.connectors.rabbitmq.RMQSink
 
connection - Variable in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
 
ConnectionID - Class in org.apache.flink.runtime.io.network
A ConnectionID identifies a connection to a remote task manager by the socket address and a connection index.
ConnectionID(TaskManagerLocation, int) - Constructor for class org.apache.flink.runtime.io.network.ConnectionID
 
ConnectionID(InetSocketAddress, int) - Constructor for class org.apache.flink.runtime.io.network.ConnectionID
 
connectionInfo() - Method in class org.apache.flink.runtime.messages.RegistrationMessages.RegisterTaskManager
 
ConnectionManager - Interface in org.apache.flink.runtime.io.network
The connection manager manages physical connections for the (logical) remote input channels at runtime.
ConnectionMonitor - Class in org.apache.flink.mesos.scheduler
Actively monitors the Mesos connection.
ConnectionMonitor() - Constructor for class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
ConnectionMonitor$ - Class in org.apache.flink.mesos.scheduler
 
ConnectionMonitor$() - Constructor for class org.apache.flink.mesos.scheduler.ConnectionMonitor$
 
ConnectionMonitor.ConnectedState$ - Class in org.apache.flink.mesos.scheduler
 
ConnectionMonitor.ConnectingState$ - Class in org.apache.flink.mesos.scheduler
 
ConnectionMonitor.FsmState - Interface in org.apache.flink.mesos.scheduler
An FSM state of the connection monitor.
ConnectionMonitor.Start - Class in org.apache.flink.mesos.scheduler
Starts the connection monitor.
ConnectionMonitor.Start$ - Class in org.apache.flink.mesos.scheduler
 
ConnectionMonitor.Stop - Class in org.apache.flink.mesos.scheduler
Stops the connection monitor.
ConnectionMonitor.Stop$ - Class in org.apache.flink.mesos.scheduler
 
ConnectionMonitor.StoppedState$ - Class in org.apache.flink.mesos.scheduler
 
ConnectionTimeout(UUID) - Constructor for class org.apache.flink.runtime.messages.JobClientMessages.ConnectionTimeout
 
ConnectionTimeout$() - Constructor for class org.apache.flink.runtime.messages.JobClientMessages.ConnectionTimeout$
 
ConnectionUtils - Class in org.apache.flink.runtime.net
Utilities to determine the network interface and address that should be used to bind the TaskManager communication to.
ConnectionUtils() - Constructor for class org.apache.flink.runtime.net.ConnectionUtils
 
ConnectionUtils.LeaderConnectingAddressListener - Class in org.apache.flink.runtime.net
 
connectNewDataSetAsInput(JobVertex, DistributionPattern, ResultPartitionType) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
connectSource(int, IntermediateResult, JobEdge, int) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
connectToJob(JobID) - Method in class org.apache.flink.client.program.ClusterClient
Reattaches to a running job with the given job id.
connectToPredecessors(Map<IntermediateDataSetID, IntermediateResult>) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
connectToResourceManager(UUID, ResourceManagerGateway) - Method in class org.apache.flink.runtime.instance.SlotPool
 
connectToResourceManager(UUID, ResourceManagerGateway) - Method in interface org.apache.flink.runtime.instance.SlotPoolGateway
Connects the SlotPool to the given ResourceManager.
consecutive() - Method in class org.apache.flink.cep.pattern.Pattern
Works in conjunction with Pattern.oneOrMore() or Pattern.times(int).
consecutive() - Method in class org.apache.flink.cep.pattern.Quantifier
 
consecutive() - Method in class org.apache.flink.cep.scala.pattern.Pattern
Works in conjunction with Pattern.oneOrMore() or Pattern.times(int).
Constant$() - Constructor for class org.apache.flink.ml.optimization.LearningRateMethod.Constant$
 
ConstantCallGen - Class in org.apache.flink.table.codegen.calls
Generates a function call which returns a constant.
ConstantCallGen(TypeInformation<?>, String) - Constructor for class org.apache.flink.table.codegen.calls.ConstantCallGen
 
ConstantTextHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Responder that returns a constant String.
ConstantTextHandler(String) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.ConstantTextHandler
 
constraints() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
Get the placement constraints
construct(RelBuilder) - Method in class org.apache.flink.table.plan.logical.Aggregate
 
construct(RelBuilder) - Method in class org.apache.flink.table.plan.logical.AliasNode
 
construct(RelBuilder) - Method in class org.apache.flink.table.plan.logical.CatalogNode
 
construct(RelBuilder) - Method in class org.apache.flink.table.plan.logical.Distinct
 
construct(RelBuilder) - Method in class org.apache.flink.table.plan.logical.Filter
 
construct(RelBuilder) - Method in class org.apache.flink.table.plan.logical.Intersect
 
construct(RelBuilder) - Method in class org.apache.flink.table.plan.logical.Join
 
construct(RelBuilder) - Method in class org.apache.flink.table.plan.logical.Limit
 
construct(RelBuilder) - Method in class org.apache.flink.table.plan.logical.LogicalNode
 
construct(RelBuilder) - Method in class org.apache.flink.table.plan.logical.LogicalRelNode
 
construct(RelBuilder) - Method in class org.apache.flink.table.plan.logical.LogicalTableFunctionCall
 
construct(RelBuilder) - Method in class org.apache.flink.table.plan.logical.Minus
 
construct(RelBuilder) - Method in class org.apache.flink.table.plan.logical.Project
 
construct(RelBuilder) - Method in class org.apache.flink.table.plan.logical.Sort
 
construct(RelBuilder) - Method in class org.apache.flink.table.plan.logical.Union
 
construct(RelBuilder) - Method in class org.apache.flink.table.plan.logical.WindowAggregate
 
constructArgNameList(SqlCall) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
constructArgNameList(SqlCall) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
constructArgNameList(SqlCall) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
constructArgNameList(SqlCall) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
constructArgTypeList(SqlValidator, SqlValidatorScope, SqlCall, List<SqlNode>, boolean) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
constructArgTypeList(SqlValidator, SqlValidatorScope, SqlCall, List<SqlNode>, boolean) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
constructArgTypeList(SqlValidator, SqlValidatorScope, SqlCall, List<SqlNode>, boolean) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
constructArgTypeList(SqlValidator, SqlValidatorScope, SqlCall, List<SqlNode>, boolean) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
constructLogString(String, String, AbstractInvokable) - Static method in class org.apache.flink.runtime.operators.BatchTask
Utility function that composes a string for logging purposes.
constructOperandList(SqlValidator, SqlCall, List<String>) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
constructOperandList(SqlValidator, SqlCall, List<String>) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
constructOperandList(SqlValidator, SqlCall, List<String>) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
constructOperandList(SqlValidator, SqlCall, List<String>) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
constructTestPath(Class<?>, String) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
constructTestURI(Class<?>, String) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
consumeAndCacheRemainingData() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
consumer - Variable in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
 
CONSUMER_KEY - Static variable in class org.apache.flink.streaming.connectors.twitter.TwitterSource
 
CONSUMER_SECRET - Static variable in class org.apache.flink.streaming.connectors.twitter.TwitterSource
 
consumesRetractions() - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupAggregate
 
consumesRetractions() - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
consumesRetractions() - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamOverAggregate
 
consumesRetractions() - Method in interface org.apache.flink.table.plan.nodes.datastream.DataStreamRel
Whether the DataStreamRel consumes retraction messages instead of forwarding them.
consumesRetractions(RelNode) - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamRetractionRules.SetAccModeRule
Checks if a RelNode consumes retraction messages instead of forwarding them.
container() - Method in class org.apache.flink.yarn.YarnContainerInLaunch
 
containerContains(String) - Method in class org.apache.flink.api.java.sca.TaggedValue
 
ContaineredJobManager - Class in org.apache.flink.runtime.clusterframework
JobManager actor for execution on Yarn or Mesos.
ContaineredJobManager(Configuration, ScheduledExecutorService, Executor, InstanceManager, Scheduler, BlobLibraryCacheManager, ActorRef, RestartStrategyFactory, FiniteDuration, LeaderElectionService, SubmittedJobGraphStore, CheckpointRecoveryFactory, FiniteDuration, Option<MetricRegistry>) - Constructor for class org.apache.flink.runtime.clusterframework.ContaineredJobManager
 
containeredParameters() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
Get the common containered parameters.
ContaineredTaskManagerParameters - Class in org.apache.flink.runtime.clusterframework
This class describes the basic parameters for launching a TaskManager process.
ContaineredTaskManagerParameters(long, long, long, int, HashMap<String, String>) - Constructor for class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
 
containerHasReferences() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
containerImageName() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
Get the container image name.
CONTAINERIZED_HEAP_CUTOFF_MIN - Static variable in class org.apache.flink.configuration.ConfigConstants
Minimum amount of heap memory to remove in containers, as a safety margin.
CONTAINERIZED_HEAP_CUTOFF_RATIO - Static variable in class org.apache.flink.configuration.ConfigConstants
Percentage of heap space to remove from containers (YARN / Mesos), to compensate for other JVM memory usage.
CONTAINERIZED_MASTER_ENV_PREFIX - Static variable in class org.apache.flink.configuration.ConfigConstants
Prefix for passing custom environment variables to Flink's master process.
CONTAINERIZED_TASK_MANAGER_ENV_PREFIX - Static variable in class org.apache.flink.configuration.ConfigConstants
Similar to the CONTAINERIZED_MASTER_ENV_PREFIX, this configuration prefix allows setting custom environment variables for the workers (TaskManagers)
ContainerOverlay - Interface in org.apache.flink.runtime.clusterframework.overlays
A container overlay to produce a container specification.
containers() - Method in class org.apache.flink.api.scala.FlinkShell.YarnConfig
 
containers() - Method in class org.apache.flink.yarn.messages.ContainersAllocated
 
containers() - Method in class org.apache.flink.yarn.messages.ContainersComplete
 
containers() - Method in class org.apache.flink.yarn.YarnMessages.YarnContainersAllocated
 
ContainersAllocated - Class in org.apache.flink.yarn.messages
Message sent by the callback handler to the YarnFlinkResourceManager to notify it that a set of new containers is available.
ContainersAllocated(List<Container>) - Constructor for class org.apache.flink.yarn.messages.ContainersAllocated
 
ContainersComplete - Class in org.apache.flink.yarn.messages
Message sent by the callback handler to the YarnFlinkResourceManager to notify it that a set of new containers is complete.
ContainersComplete(List<ContainerStatus>) - Constructor for class org.apache.flink.yarn.messages.ContainersComplete
 
ContainerSpecification - Class in org.apache.flink.runtime.clusterframework
Encapsulates a container specification, including artifacts, environment variables, system properties, and Flink configuration settings.
ContainerSpecification() - Constructor for class org.apache.flink.runtime.clusterframework.ContainerSpecification
 
ContainerSpecification.Artifact - Class in org.apache.flink.runtime.clusterframework
An artifact to be copied into the container.
ContainerSpecification.Artifact.Builder - Class in org.apache.flink.runtime.clusterframework
 
containerType() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
Get the container type (Mesos or Docker).
containerVolumes() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
Get the container volumes string
containingIteration - Variable in class org.apache.flink.api.common.operators.base.DeltaIterationBase.SolutionSetPlaceHolder
 
contains(Integer) - Method in class org.apache.flink.api.common.operators.util.FieldSet
 
contains(UK) - Method in interface org.apache.flink.api.common.state.MapState
Returns whether there exists the given mapping.
contains(ConfigOption<?>) - Method in class org.apache.flink.configuration.Configuration
Checks whether there is an entry for the given config option
contains(ConfigOption<?>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
contains(UK) - Method in class org.apache.flink.contrib.streaming.state.RocksDBMapState
 
contains(Vector) - Method in class org.apache.flink.ml.nn.QuadTree.Node
Tests whether the queryPoint is in the node, or a child of that node
contains(Object) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
contains(UK) - Method in class org.apache.flink.runtime.state.heap.HeapMapState
 
contains(int) - Method in class org.apache.flink.runtime.state.KeyGroupRange
Checks whether or not a single key-group is contained in the range.
contains(int) - Method in interface org.apache.flink.runtime.state.KeyGroupsList
Returns true, if the given key group id is contained in the list, otherwise false.
contains(JobID) - Method in class org.apache.flink.runtime.taskexecutor.JobManagerTable
 
contains(String) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
contains(Object) - Method in class org.apache.flink.types.ListValue
 
containsAll(Collection<?>) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
containsAll(Collection<?>) - Method in class org.apache.flink.types.ListValue
 
containsCause(Throwable, Class<? extends Throwable>) - Static method in class org.apache.flink.core.testutils.CommonTestUtils
Checks whether the given throwable contains the given cause as a cause.
containsDistinctCall() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
containsDistinctCall() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
containsDistinctCall() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
containsJob(JobID) - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
Check whether the given job is being monitored or not.
containsJob(JobID) - Method in class org.apache.flink.runtime.taskexecutor.JobLeaderService
Check whether the service monitors the given job.
containsKey(String) - Method in class org.apache.flink.configuration.Configuration
Checks whether there is an entry with the specified key
containsKey(String) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
containsKey(N) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
containsKey(N) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
containsKey(N) - Method in class org.apache.flink.runtime.state.heap.StateTable
Returns whether this table contains a mapping for the composite of active key and given namespace.
containsKey(K) - Method in class org.apache.flink.runtime.util.LRUCacheMap
 
containsKey(Object) - Method in class org.apache.flink.storm.util.StormConfig
 
containsKey(Object) - Method in class org.apache.flink.types.MapValue
 
containsNonNull() - Method in class org.apache.flink.api.java.summarize.ColumnSummary
True if this column contains any non-null values
containsNull() - Method in class org.apache.flink.api.java.summarize.ColumnSummary
True if this column contains any null values
containsResultAsText(List<T>, String) - Static method in class org.apache.flink.test.util.TestBaseUtils
The expected string contains all expected results separate with line break, check whether all elements in result are contained in the expected string.
containsSlot(SlotID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
containsThrowable(Throwable, Class<?>) - Static method in class org.apache.flink.util.ExceptionUtils
Checks whether a throwable chain contains a specific type of exception.
containsValue(Object) - Method in class org.apache.flink.storm.util.StormConfig
 
containsValue(Object) - Method in class org.apache.flink.types.MapValue
 
CONTENTS - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
 
contentsHaveChangedSince(long, long) - Method in class org.apache.flink.table.catalog.ExternalCatalogSchema
 
context - Variable in class org.apache.flink.api.java.DataSet
 
context - Variable in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
 
context - Variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
 
Context<T> - Interface in org.apache.flink.cep.scala.conditions
The context used when evaluating the condition.
context() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
context() - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
context() - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
context() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
context() - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
context() - Static method in class org.apache.flink.mesos.scheduler.Tasks
 
context() - Static method in class org.apache.flink.runtime.jobmanager.JobManager
 
context() - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
 
Context() - Constructor for class org.apache.flink.streaming.api.functions.co.CoProcessFunction.Context
 
Context() - Constructor for class org.apache.flink.streaming.api.functions.ProcessFunction.Context
 
Context() - Constructor for class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction.Context
 
Context() - Constructor for class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
 
Context() - Constructor for class org.apache.flink.streaming.api.scala.function.ProcessAllWindowFunction.Context
 
Context() - Constructor for class org.apache.flink.streaming.api.scala.function.ProcessWindowFunction.Context
 
Context(K, W) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
context() - Static method in class org.apache.flink.yarn.ApplicationClient
 
context() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
ContextEnvironment - Class in org.apache.flink.client.program
Execution Environment for remote execution with the Client.
ContextEnvironment(ClusterClient, List<URL>, List<URL>, ClassLoader, SavepointRestoreSettings) - Constructor for class org.apache.flink.client.program.ContextEnvironment
 
ContextEnvironmentFactory - Class in org.apache.flink.client.program
The factory that instantiates the environment to be used when running jobs that are submitted through a pre-configured client connection.
ContextEnvironmentFactory(ClusterClient, List<URL>, List<URL>, ClassLoader, int, boolean, SavepointRestoreSettings) - Constructor for class org.apache.flink.client.program.ContextEnvironmentFactory
 
contextTerm() - Method in class org.apache.flink.table.codegen.CodeGenerator
 
ContinuousEventTimeTrigger<W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
A Trigger that continuously fires based on a given time interval.
ContinuousFileMonitoringFunction<OUT> - Class in org.apache.flink.streaming.api.functions.source
This is the single (non-parallel) monitoring task which takes a FileInputFormat and, depending on the FileProcessingMode and the FilePathFilter, it is responsible for: Monitoring a user-provided path. Deciding which files should be further read and processed. Creating the splits corresponding to those files. Assigning them to downstream tasks for further processing.
ContinuousFileMonitoringFunction(FileInputFormat<OUT>, FileProcessingMode, int, long) - Constructor for class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
 
ContinuousFileReaderOperator<OUT> - Class in org.apache.flink.streaming.api.functions.source
The operator that reads the splits received from the preceding ContinuousFileMonitoringFunction.
ContinuousFileReaderOperator(FileInputFormat<OUT>) - Constructor for class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
 
ContinuousProcessingTimeTrigger<W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
A Trigger that continuously fires based on a given time interval as measured by the clock of the machine on which the job is running.
Contributors - Class in org.apache.flink.contrib.tweetinputformat.model.tweet
Nullable.
Contributors() - Constructor for class org.apache.flink.contrib.tweetinputformat.model.tweet.Contributors
 
Contributors(long, String, String) - Constructor for class org.apache.flink.contrib.tweetinputformat.model.tweet.Contributors
 
contributorsObjectStatePrimitiveHandler(Object) - Method in class org.apache.flink.contrib.tweetinputformat.io.TweetHandler
 
ConvergenceCriterion<T extends Value> - Interface in org.apache.flink.api.common.aggregators
Used to check for convergence.
convergenceThreshold - Variable in class org.apache.flink.graph.drivers.parameter.IterationConvergence.Value
 
ConvergenceThreshold$() - Constructor for class org.apache.flink.ml.optimization.IterativeSolver.ConvergenceThreshold$
 
ConvergenceThreshold$() - Constructor for class org.apache.flink.ml.regression.MultipleLinearRegression.ConvergenceThreshold$
 
CONVERT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
convert(RexBuilder, RexNode, RexNode) - Method in interface org.apache.calcite.sql2rel.AuxiliaryConverter
Converts an expression.
convert(RexBuilder, RexNode, RexNode) - Method in class org.apache.calcite.sql2rel.AuxiliaryConverter.Impl
 
convert(Vector<Object>) - Method in interface org.apache.flink.ml.math.BreezeVectorConverter
Converts a Breeze vector into a Flink vector of type T
convert(RelDataType, boolean) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
convert(RelNode, RexBuilder) - Method in class org.apache.flink.table.calcite.RelTimeIndicatorConverter$
 
convert(RelNode, RexBuilder) - Static method in class org.apache.flink.table.calcite.RelTimeIndicatorConverter
 
convert(RelOptPlanner, RelNode, AccModeTrait, boolean) - Method in class org.apache.flink.table.plan.nodes.datastream.AccModeTraitDef
 
convert(RelOptPlanner, RelNode, UpdateAsRetractionTrait, boolean) - Method in class org.apache.flink.table.plan.nodes.datastream.UpdateAsRetractionTraitDef
 
convert(RelNode) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregateConverter
 
convert(RelNode) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalcConverter
 
convert(RelNode) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelateConverter
 
convert(RelNode) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersectConverter
 
convert(RelNode) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoinConverter
 
convert(RelNode) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinusConverter
 
convert(RelNode) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScanConverter
 
convert(RelNode) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindowConverter
 
convert(RelNode) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSortConverter
 
convert(RelNode) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScanConverter
 
convert(RelNode) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScanConverter
 
convert(RelNode) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnionConverter
 
convert(RelNode) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValuesConverter
 
convert(RelNode) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregateConverter
 
convert(RelNode) - Method in class org.apache.flink.table.plan.rules.dataSet.BatchTableSourceScanRule
 
convert(RelNode) - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateRule
 
convert(RelNode) - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateWithNullValuesRule
 
convert(RelNode) - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetCalcRule
 
convert(RelNode) - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetCorrelateRule
 
convert(RelNode) - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetDistinctRule
 
convert(RelNode) - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetIntersectRule
 
convert(RelNode) - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetJoinRule
 
convert(RelNode) - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetMinusRule
 
convert(RelNode) - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetScanRule
 
convert(RelNode) - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetSingleRowJoinRule
 
convert(RelNode) - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetSortRule
 
convert(RelNode) - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetUnionRule
 
convert(RelNode) - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetValuesRule
 
convert(RelNode) - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetWindowAggregateRule
 
convert(RelNode) - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamCalcRule
 
convert(RelNode) - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamCorrelateRule
 
convert(RelNode) - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupAggregateRule
 
convert(RelNode) - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupWindowAggregateRule
 
convert(RelNode) - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamOverAggregateRule
 
convert(RelNode) - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamScanRule
 
convert(RelNode) - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamUnionRule
 
convert(RelNode) - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamValuesRule
 
convert(RelNode) - Method in class org.apache.flink.table.plan.rules.datastream.StreamTableSourceScanRule
 
convertAgg(SqlToRelConverter.Blackboard, SqlSelect, List<SqlNode>) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Converts the SELECT, GROUP BY and HAVING clauses of an aggregate query.
convertArray(Object) - Method in class org.apache.flink.table.expressions.ExpressionUtils$
 
convertArray(Object) - Static method in class org.apache.flink.table.expressions.ExpressionUtils
 
convertAuxiliaryToGroupCall(SqlCall) - Static method in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Converts a call to a grouped auxiliary function to a call to the grouped window function.
convertBoxedJavaType(Object) - Static method in class org.apache.flink.types.JavaToValueConverter
 
convertCollectionTable(SqlToRelConverter.Blackboard, SqlCall) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
 
convertColumnList(SqlInsert, RelNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Creates a source for an INSERT statement.
convertDynamicParam(SqlDynamicParam) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
 
CONVERTER() - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate$
 
CONVERTER() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
CONVERTER() - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc$
 
CONVERTER() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
CONVERTER() - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate$
 
CONVERTER() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
CONVERTER() - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect$
 
CONVERTER() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
CONVERTER() - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin$
 
CONVERTER() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
CONVERTER() - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus$
 
CONVERTER() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
CONVERTER() - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan$
 
CONVERTER() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
CONVERTER() - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow$
 
CONVERTER() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
CONVERTER() - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort$
 
CONVERTER() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
CONVERTER() - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan$
 
CONVERTER() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
CONVERTER() - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan$
 
CONVERTER() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
CONVERTER() - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion$
 
CONVERTER() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
CONVERTER() - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues$
 
CONVERTER() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
CONVERTER() - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate$
 
CONVERTER() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
convertExpression(SqlNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
 
convertExpression(SqlNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Converts an expression from SqlNode to RexNode format.
convertExpression(SqlNode, Map<String, RexNode>) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Converts an expression from SqlNode to RexNode format, mapping identifier references to predefined expressions.
convertExtendedExpression(SqlNode, SqlToRelConverter.Blackboard) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Converts a non-standard expression.
convertFrom(SqlToRelConverter.Blackboard, SqlNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Converts a FROM clause into a relational expression.
convertGroupToAuxiliaryCalls(SqlCall) - Static method in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Converts a call to a grouped window function to a call to its auxiliary window function(s).
convertInetSocketAddresses(List<InetSocketAddress>) - Static method in class org.apache.flink.streaming.connectors.elasticsearch.util.ElasticsearchUtils
Utility method to convert a List of InetSocketAddress to Elasticsearch TransportAddress.
convertInsert(SqlInsert) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
 
convertInterval(SqlIntervalQualifier) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
 
convertKeyedBackendState(HashMap<String, KvStateSnapshot<?, ?, ?, ?>>, int, long) - Static method in class org.apache.flink.migration.runtime.checkpoint.savepoint.SavepointV0Serializer
This is public so that we can use it when restoring a legacy snapshot in AbstractStreamOperatorTestHarness.
convertletTable() - Method in class org.apache.flink.table.calcite.FlinkPlannerImpl
 
convertLiteral(SqlLiteral) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
 
convertMatchRecognize(SqlToRelConverter.Blackboard, SqlCall) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
 
convertOperatorAndFunctionState(StreamTaskState) - Static method in class org.apache.flink.migration.runtime.checkpoint.savepoint.SavepointV0Serializer
This is public so that we can use it when restoring a legacy snapshot in AbstractStreamOperatorTestHarness.
convertOrder(SqlSelect, SqlToRelConverter.Blackboard, RelCollation, List<SqlNode>, SqlNode, SqlNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Converts a query's ORDER BY clause, if any.
convertOrderItem(SqlSelect, SqlNode, List<SqlNode>, RelFieldCollation.Direction, RelFieldCollation.NullDirection) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
 
convertOutputType(RelNode) - Method in class org.apache.flink.table.calcite.RelTimeIndicatorConverter$
 
convertOutputType(RelNode) - Static method in class org.apache.flink.table.calcite.RelTimeIndicatorConverter
 
convertQuery(SqlNode, boolean, boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Converts an unvalidated query's parse tree into a relational expression.
convertQueryRecursive(SqlNode, boolean, RelDataType) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Recursively converts a query to a relational expression.
convertSelect(SqlSelect, boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Converts a SELECT statement's parse tree into a relational expression.
convertSelectImpl(SqlToRelConverter.Blackboard, SqlSelect) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Implementation of SqlToRelConverter.convertSelect(SqlSelect, boolean); derived class may override.
convertSetOp(SqlCall) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Converts a set operation (UNION, INTERSECT, MINUS) into relational expressions.
convertSortExpression(SqlNode, Set<SqlKind>) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
Converts an item in an ORDER BY clause, extracting DESC, NULLS LAST and NULLS FIRST flags first.
convertStateHandle(StateHandle<?>) - Static method in class org.apache.flink.migration.runtime.checkpoint.savepoint.SavepointV0Serializer
This is public so that we can use it when restoring a legacy snapshot in AbstractStreamOperatorTestHarness.
convertToInternalRow(DataSet<Object>, FlinkTable<?>, TableConfig) - Method in interface org.apache.flink.table.plan.nodes.dataset.BatchScan
 
convertToInternalRow(RowSchema, DataStream<Object>, FlinkTable<?>, TableConfig) - Method in interface org.apache.flink.table.plan.nodes.datastream.StreamScan
 
convertToOperatorStateSavepointV2(Map<JobVertexID, ExecutionJobVertex>, Savepoint) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
Deprecated.
Only kept for backwards-compatibility with versions < 1.3. Will be removed in the future.
convertToSingleValueSubq(SqlNode, RelNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Converts the RelNode tree for a select statement to a select that produces a single value.
convertTypeInfoToTaggedValue(TaggedValue.Input, TypeInformation<?>, String, List<CompositeType.FlatFieldDescriptor>, int[]) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
 
convertValues(SqlCall, RelDataType) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Converts a SELECT statement's parse tree into a relational expression.
convertValueType(Value) - Static method in class org.apache.flink.types.JavaToValueConverter
 
convertWith(SqlWith, boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Converts a WITH sub-query into a relational expression.
Coordinates - Class in org.apache.flink.contrib.tweetinputformat.model.tweet
Nullable.
Coordinates() - Constructor for class org.apache.flink.contrib.tweetinputformat.model.tweet.Coordinates
 
coordinatesObjectStatePrimitiveHandler(Object) - Method in class org.apache.flink.contrib.tweetinputformat.io.TweetHandler
 
CoProcessFunction<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.functions.co
A function that processes elements of two streams and produces a single output one.
CoProcessFunction() - Constructor for class org.apache.flink.streaming.api.functions.co.CoProcessFunction
 
CoProcessFunction.Context - Class in org.apache.flink.streaming.api.functions.co
CoProcessFunction.OnTimerContext - Class in org.apache.flink.streaming.api.functions.co
Information available in an invocation of CoProcessFunction.onTimer(long, OnTimerContext, Collector).
CoProcessOperator<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
CoProcessOperator(CoProcessFunction<IN1, IN2, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.co.CoProcessOperator
 
copy(Map<String, Accumulator<?, ?>>) - Static method in class org.apache.flink.api.common.accumulators.AccumulatorHelper
 
copy(boolean[]) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
copy(boolean[], boolean[]) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
copy(byte[]) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
copy(byte[], byte[]) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
copy(char[]) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
copy(char[], char[]) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
copy(double[]) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
copy(double[], double[]) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
copy(float[]) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
copy(float[], float[]) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
copy(int[]) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
copy(int[], int[]) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
copy(long[]) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
copy(long[], long[]) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
copy(short[]) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
copy(short[], short[]) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
copy(String[]) - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
copy(String[], String[]) - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
copy(BigDecimal) - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
copy(BigDecimal, BigDecimal) - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
copy(BigInteger) - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
copy(BigInteger, BigInteger) - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
copy(Boolean) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
copy(Boolean, Boolean) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
copy(BooleanValue) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
copy(BooleanValue, BooleanValue) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
copy(Byte) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
 
copy(Byte, Byte) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
 
copy(ByteValue) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
copy(ByteValue, ByteValue) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
copy(Character) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
 
copy(Character, Character) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
 
copy(CharValue) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
copy(CharValue, CharValue) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
copy(Date) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
 
copy(Date, Date) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
 
copy(Double) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
copy(Double, Double) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
copy(DoubleValue) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
copy(DoubleValue, DoubleValue) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
copy(T) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
copy(T, T) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
copy(Float) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
 
copy(Float, Float) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
 
copy(FloatValue) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
copy(FloatValue, FloatValue) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
copy(C[]) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
copy(C[], C[]) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
copy(Integer) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
 
copy(Integer, Integer) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
 
copy(IntValue) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
copy(IntValue, IntValue) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
copy(List<T>) - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
 
copy(List<T>, List<T>) - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
 
copy(Long) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
 
copy(Long, Long) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
 
copy(LongValue) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
copy(LongValue, LongValue) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
copy(Map<K, V>) - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
copy(Map<K, V>, Map<K, V>) - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
copy(NullValue) - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
copy(NullValue, NullValue) - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
copy(Short) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
 
copy(Short, Short) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
 
copy(ShortValue) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
copy(ShortValue, ShortValue) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
copy(Date) - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
copy(Date, Date) - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
copy(Time) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
copy(Time, Time) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
copy(Timestamp) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
copy(Timestamp, Timestamp) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
copy(String) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
 
copy(String, String) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
 
copy(StringValue) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
copy(StringValue, StringValue) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
copy(Void) - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
 
copy(Void, Void) - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
 
copy(T) - Method in class org.apache.flink.api.common.typeutils.TypeDeserializerAdapter
 
copy(T, T) - Method in class org.apache.flink.api.common.typeutils.TypeDeserializerAdapter
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.TypeDeserializerAdapter
 
copy(T) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
Creates a deep copy of the given element in a new element.
copy(T, T) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
Creates a copy from the given element.
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
Copies exactly one record from the source input view to the target output view.
copy(T) - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
copy(T, T) - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
copy() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
copy(Type) - Method in class org.apache.flink.api.java.sca.TaggedValue
 
copy() - Method in class org.apache.flink.api.java.tuple.Tuple
Shallow tuple copy.
copy() - Method in class org.apache.flink.api.java.tuple.Tuple0
Shallow tuple copy.
copy() - Method in class org.apache.flink.api.java.tuple.Tuple1
Shallow tuple copy.
copy() - Method in class org.apache.flink.api.java.tuple.Tuple10
Shallow tuple copy.
copy() - Method in class org.apache.flink.api.java.tuple.Tuple11
Shallow tuple copy.
copy() - Method in class org.apache.flink.api.java.tuple.Tuple12
Shallow tuple copy.
copy() - Method in class org.apache.flink.api.java.tuple.Tuple13
Shallow tuple copy.
copy() - Method in class org.apache.flink.api.java.tuple.Tuple14
Shallow tuple copy.
copy() - Method in class org.apache.flink.api.java.tuple.Tuple15
Shallow tuple copy.
copy() - Method in class org.apache.flink.api.java.tuple.Tuple16
Shallow tuple copy.
copy() - Method in class org.apache.flink.api.java.tuple.Tuple17
Shallow tuple copy.
copy() - Method in class org.apache.flink.api.java.tuple.Tuple18
Shallow tuple copy.
copy() - Method in class org.apache.flink.api.java.tuple.Tuple19
Shallow tuple copy.
copy() - Method in class org.apache.flink.api.java.tuple.Tuple2
Shallow tuple copy.
copy() - Method in class org.apache.flink.api.java.tuple.Tuple20
Shallow tuple copy.
copy() - Method in class org.apache.flink.api.java.tuple.Tuple21
Shallow tuple copy.
copy() - Method in class org.apache.flink.api.java.tuple.Tuple22
Shallow tuple copy.
copy() - Method in class org.apache.flink.api.java.tuple.Tuple23
Shallow tuple copy.
copy() - Method in class org.apache.flink.api.java.tuple.Tuple24
Shallow tuple copy.
copy() - Method in class org.apache.flink.api.java.tuple.Tuple25
Shallow tuple copy.
copy() - Method in class org.apache.flink.api.java.tuple.Tuple3
Shallow tuple copy.
copy() - Method in class org.apache.flink.api.java.tuple.Tuple4
Shallow tuple copy.
copy() - Method in class org.apache.flink.api.java.tuple.Tuple5
Shallow tuple copy.
copy() - Method in class org.apache.flink.api.java.tuple.Tuple6
Shallow tuple copy.
copy() - Method in class org.apache.flink.api.java.tuple.Tuple7
Shallow tuple copy.
copy() - Method in class org.apache.flink.api.java.tuple.Tuple8
Shallow tuple copy.
copy() - Method in class org.apache.flink.api.java.tuple.Tuple9
Shallow tuple copy.
copy(T) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
 
copy(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
 
copy(T) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
copy(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
copy(Either<L, R>) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
copy(Either<L, R>, Either<L, R>) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
copy(T) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
copy(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
copy(T, Kryo, TypeSerializer<T>) - Static method in class org.apache.flink.api.java.typeutils.runtime.KryoUtils
Tries to copy the given record from using the provided Kryo instance.
copy(T, T, Kryo, TypeSerializer<T>) - Static method in class org.apache.flink.api.java.typeutils.runtime.KryoUtils
Tries to copy the given record from using the provided Kryo instance.
copy(T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
copy(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
copy(Row) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
copy(Row, Row) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
copy(Tuple0) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
copy(Tuple0, Tuple0) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
copy(T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
copy(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
copy(T) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
copy(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
copy(T) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
 
copy(T, T) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
 
copy(T, T) - Method in class org.apache.flink.api.scala.typeutils.CaseClassSerializer
 
copy(T) - Method in class org.apache.flink.api.scala.typeutils.CaseClassSerializer
 
copy(T) - Method in class org.apache.flink.api.scala.typeutils.EitherSerializer
 
copy(T, T) - Method in class org.apache.flink.api.scala.typeutils.EitherSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.scala.typeutils.EitherSerializer
 
copy(Enumeration.Value) - Method in class org.apache.flink.api.scala.typeutils.EnumValueSerializer
 
copy(Enumeration.Value, Enumeration.Value) - Method in class org.apache.flink.api.scala.typeutils.EnumValueSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.scala.typeutils.EnumValueSerializer
 
copy(Object) - Method in class org.apache.flink.api.scala.typeutils.NothingSerializer
 
copy(Object, Object) - Method in class org.apache.flink.api.scala.typeutils.NothingSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.scala.typeutils.NothingSerializer
 
copy(Option<A>) - Method in class org.apache.flink.api.scala.typeutils.OptionSerializer
 
copy(Option<A>, Option<A>) - Method in class org.apache.flink.api.scala.typeutils.OptionSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.scala.typeutils.OptionSerializer
 
copy(T) - Method in class org.apache.flink.api.scala.typeutils.TraversableSerializer
 
copy(T, T) - Method in class org.apache.flink.api.scala.typeutils.TraversableSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.scala.typeutils.TraversableSerializer
 
copy(Try<A>) - Method in class org.apache.flink.api.scala.typeutils.TrySerializer
 
copy(Try<A>, Try<A>) - Method in class org.apache.flink.api.scala.typeutils.TrySerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.scala.typeutils.TrySerializer
 
copy(BoxedUnit) - Method in class org.apache.flink.api.scala.typeutils.UnitSerializer
 
copy(BoxedUnit, BoxedUnit) - Method in class org.apache.flink.api.scala.typeutils.UnitSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.api.scala.typeutils.UnitSerializer
 
copy(DeweyNumber) - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
 
copy(DeweyNumber, DeweyNumber) - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
 
copy(NFA<T>) - Method in class org.apache.flink.cep.nfa.NFA.NFASerializer
 
copy(NFA<T>, NFA<T>) - Method in class org.apache.flink.cep.nfa.NFA.NFASerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.cep.nfa.NFA.NFASerializer
 
copy(NFA<T>) - Method in class org.apache.flink.cep.nfa.NFA.Serializer
 
copy(NFA<T>, NFA<T>) - Method in class org.apache.flink.cep.nfa.NFA.Serializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.cep.nfa.NFA.Serializer
 
copy(SharedBuffer) - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
 
copy(SharedBuffer, SharedBuffer) - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
 
copy(T) - Method in class org.apache.flink.cep.NonDuplicatingTypeSerializer
 
copy(T, T) - Method in class org.apache.flink.cep.NonDuplicatingTypeSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.cep.NonDuplicatingTypeSerializer
 
copy() - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
 
copy(IntValueArray) - Method in class org.apache.flink.graph.types.valuearray.IntValueArraySerializer
 
copy(IntValueArray, IntValueArray) - Method in class org.apache.flink.graph.types.valuearray.IntValueArraySerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.IntValueArraySerializer
 
copy() - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
 
copy(LongValueArray) - Method in class org.apache.flink.graph.types.valuearray.LongValueArraySerializer
 
copy(LongValueArray, LongValueArray) - Method in class org.apache.flink.graph.types.valuearray.LongValueArraySerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.LongValueArraySerializer
 
copy() - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
 
copy(NullValueArray) - Method in class org.apache.flink.graph.types.valuearray.NullValueArraySerializer
 
copy(NullValueArray, NullValueArray) - Method in class org.apache.flink.graph.types.valuearray.NullValueArraySerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.NullValueArraySerializer
 
copy() - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
 
copy(StringValueArray) - Method in class org.apache.flink.graph.types.valuearray.StringValueArraySerializer
 
copy(StringValueArray, StringValueArray) - Method in class org.apache.flink.graph.types.valuearray.StringValueArraySerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.StringValueArraySerializer
 
copy(Serializable) - Method in class org.apache.flink.migration.MigrationNamespaceSerializerProxy
Deprecated.
 
copy(Serializable, Serializable) - Method in class org.apache.flink.migration.MigrationNamespaceSerializerProxy
Deprecated.
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.migration.MigrationNamespaceSerializerProxy
Deprecated.
 
copy(StreamElement) - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer
 
copy(StreamElement, StreamElement) - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer
 
copy(StreamRecord<T>) - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.StreamRecordSerializer
 
copy(StreamRecord<T>, StreamRecord<T>) - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.StreamRecordSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.StreamRecordSerializer
 
copy(Vector, Vector) - Method in class org.apache.flink.ml.math.BLAS$
y = x
copy(Vector, Vector) - Static method in class org.apache.flink.ml.math.BLAS
y = x
copy() - Method in class org.apache.flink.ml.math.DenseMatrix
Copies the matrix instance
copy() - Method in class org.apache.flink.ml.math.DenseVector
Copies the vector instance
copy() - Method in interface org.apache.flink.ml.math.Matrix
Copies the matrix instance
copy() - Method in class org.apache.flink.ml.math.SparseMatrix
Copies the matrix instance
copy() - Method in class org.apache.flink.ml.math.SparseVector
Copies the vector instance
copy() - Method in interface org.apache.flink.ml.math.Vector
Copies the vector instance
copy(Path, Path, boolean) - Static method in class org.apache.flink.runtime.filecache.FileCache
 
copy(String) - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
Create a copy of this QueryScopeInfo and append the given scope.
copy(String) - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobManagerQueryScopeInfo
 
copy(String) - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobQueryScopeInfo
 
copy(String) - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
 
copy(String) - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskManagerQueryScopeInfo
 
copy(String) - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
 
copy(ArrayList<T>) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
copy(ArrayList<T>, ArrayList<T>) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
copy(HashMap<K, V>) - Method in class org.apache.flink.runtime.state.HashMapSerializer
 
copy(HashMap<K, V>, HashMap<K, V>) - Method in class org.apache.flink.runtime.state.HashMapSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.runtime.state.HashMapSerializer
 
copy(VoidNamespace) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
 
copy(VoidNamespace, VoidNamespace) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
 
copy(InternalTimer<K, N>) - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
 
copy(InternalTimer<K, N>, InternalTimer<K, N>) - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
 
copy(GlobalWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
 
copy(GlobalWindow, GlobalWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
 
copy(TimeWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
copy(TimeWindow, TimeWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
copy() - Method in class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
 
copy() - Method in class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
 
copy() - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
 
copy() - Method in class org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
 
copy() - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
 
copy() - Method in class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
 
copy() - Method in class org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
 
copy() - Method in class org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
 
copy() - Method in class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
 
copy(StreamElement) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
copy(StreamElement, StreamElement) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
copy(T) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
Creates a copy of this stream record.
copy(RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.flink.table.plan.nodes.dataset.BatchTableSourceScan
 
copy(RelTraitSet, TableSource<?>) - Method in class org.apache.flink.table.plan.nodes.dataset.BatchTableSourceScan
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetAggregate
 
copy(RelTraitSet, RelNode, RexProgram) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetCalc
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetCorrelate
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetDistinct
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetIntersect
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetJoin
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetMinus
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetScan
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetSingleRowJoin
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetSort
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetUnion
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetValues
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetWindowAggregate
 
copy(RelTraitSet, RelNode, RexProgram) - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamCalc
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamCorrelate
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupAggregate
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamOverAggregate
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamScan
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamUnion
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamValues
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.flink.table.plan.nodes.datastream.StreamTableSourceScan
 
copy(RelTraitSet, TableSource<?>) - Method in class org.apache.flink.table.plan.nodes.datastream.StreamTableSourceScan
 
copy(RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
copy(RelTraitSet, RelNode, RexProgram) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
copy(RelTraitSet, RelNode, RelNode, CorrelationId, ImmutableBitSet, SemiJoinType) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
copy(RelTraitSet, List<RelNode>, boolean) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
copy(RelTraitSet, RexNode, RelNode, RelNode, JoinRelType, boolean) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
copy(RelTraitSet, List<RelNode>, boolean) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
copy(RelTraitSet, List<RelNode>) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
copy(RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
copy(RelTraitSet, List<RelNode>, RexNode, Type, RelDataType, Set<RelColumnMapping>) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
copy(RelTraitSet, TableSource<?>) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
copy(RelTraitSet, List<RelNode>, boolean) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
copy(RelTraitSet, List<RelNode>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
copy(RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
copy(RelTraitSet, TableSource<?>) - Method in class org.apache.flink.table.plan.nodes.PhysicalTableSourceScan
 
copy(CRow) - Method in class org.apache.flink.table.runtime.types.CRowSerializer
 
copy(CRow, CRow) - Method in class org.apache.flink.table.runtime.types.CRowSerializer
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.table.runtime.types.CRowSerializer
 
copy() - Method in class org.apache.flink.table.sinks.CsvTableSink
 
copy() - Method in interface org.apache.flink.table.sinks.TableSinkBase
Return a deep copy of the TableSink.
copy() - Method in class org.apache.flink.types.BooleanValue
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.BooleanValue
 
copy() - Method in class org.apache.flink.types.ByteValue
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.ByteValue
 
copy() - Method in class org.apache.flink.types.CharValue
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.CharValue
 
copy() - Method in interface org.apache.flink.types.CopyableValue
Performs a deep copy of this object into a new instance.
copy(DataInputView, DataOutputView) - Method in interface org.apache.flink.types.CopyableValue
Copies the next serialized instance from source to target.
copy() - Method in class org.apache.flink.types.DoubleValue
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.DoubleValue
 
copy() - Method in class org.apache.flink.types.FloatValue
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.FloatValue
 
copy() - Method in class org.apache.flink.types.IntValue
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.IntValue
 
copy() - Method in class org.apache.flink.types.LongValue
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.LongValue
 
copy() - Method in class org.apache.flink.types.NullValue
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.NullValue
 
copy() - Method in class org.apache.flink.types.Record
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.Record
 
copy(Row) - Static method in class org.apache.flink.types.Row
Creates a new Row which copied from another row.
copy() - Method in class org.apache.flink.types.ShortValue
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.ShortValue
 
copy() - Method in class org.apache.flink.types.StringValue
 
copy(DataInputView, DataOutputView) - Method in class org.apache.flink.types.StringValue
 
copy1 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
copy2 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
CopyableValue<T> - Interface in org.apache.flink.types
Interface to be implemented by basic types that support to be copied efficiently.
CopyableValueComparator<T extends CopyableValue<T> & Comparable<T>> - Class in org.apache.flink.api.java.typeutils.runtime
Comparator for all Value types that extend Key
CopyableValueComparator(boolean, Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
CopyableValueSerializer<T extends CopyableValue<T>> - Class in org.apache.flink.api.java.typeutils.runtime
 
CopyableValueSerializer(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
CopyableValueSerializer.CopyableValueSerializerConfigSnapshot<T extends CopyableValue<T>> - Class in org.apache.flink.api.java.typeutils.runtime
 
CopyableValueSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer.CopyableValueSerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
CopyableValueSerializerConfigSnapshot(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer.CopyableValueSerializerConfigSnapshot
 
copyBigInteger(DataInputView, DataOutputView) - Static method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
copyBytes(InputStream, OutputStream, int, boolean) - Static method in class org.apache.flink.util.IOUtils
Copies from one stream to another.
copyBytes(InputStream, OutputStream) - Static method in class org.apache.flink.util.IOUtils
Copies from one stream to another.
copyBytes(InputStream, OutputStream, boolean) - Static method in class org.apache.flink.util.IOUtils
Copies from one stream to another.
copyEstimates(OptimizerNode) - Method in class org.apache.flink.optimizer.dag.AbstractPartialSolutionNode
 
copyFrom(CompilerHints) - Method in class org.apache.flink.api.common.operators.CompilerHints
 
copyFrom(EnumTrianglesDataTypes.EdgeWithDegrees) - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.EdgeWithDegrees
 
copyFrom(TriangleEnumerator.EdgeWithDegrees<K>) - Method in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
 
copyFrom(Record, int[], int[]) - Method in class org.apache.flink.types.Record
Bin-copies fields from a source record to this record.
copyFromLocal(File, URI) - Static method in class org.apache.flink.streaming.util.HDFSCopyFromLocal
 
CopyingDirectedOutput<OUT> - Class in org.apache.flink.streaming.api.collector.selector
Special version of DirectedOutput that performs a shallow copy of the StreamRecord to ensure that multi-chaining works correctly.
CopyingDirectedOutput(List<OutputSelector<OUT>>, List<Tuple2<Output<StreamRecord<OUT>>, StreamEdge>>) - Constructor for class org.apache.flink.streaming.api.collector.selector.CopyingDirectedOutput
 
CopyingIterator<E> - Class in org.apache.flink.api.common.functions.util
 
CopyingIterator(Iterator<E>, TypeSerializer<E>) - Constructor for class org.apache.flink.api.common.functions.util.CopyingIterator
 
CopyingListCollector<T> - Class in org.apache.flink.api.common.functions.util
 
CopyingListCollector(List<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.api.common.functions.util.CopyingListCollector
 
copyInternal(DataInputView, DataOutputView) - Static method in class org.apache.flink.graph.types.valuearray.IntValueArray
 
copyInternal(DataInputView, DataOutputView) - Static method in class org.apache.flink.graph.types.valuearray.LongValueArray
 
copyInternal(DataInputView, DataOutputView) - Static method in class org.apache.flink.graph.types.valuearray.StringValueArray
 
copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
 
copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
 
copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
 
copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
 
copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.BooleanValue
 
copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.ByteValue
 
copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.CharValue
 
copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.IntValue
 
copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.LongValue
 
copyNormalizedKey(MemorySegment, int, int) - Method in interface org.apache.flink.types.NormalizableKey
Writes a normalized key for the given record into the target byte array, starting at the specified position an writing exactly the given number of bytes.
copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.NullValue
 
copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.ShortValue
 
copyNormalizedKey(MemorySegment, int, int) - Method in class org.apache.flink.types.StringValue
 
CopyOnWriteStateTable<K,N,S> - Class in org.apache.flink.runtime.state.heap
Implementation of Flink's in-memory state tables with copy-on-write support.
CopyOnWriteStateTableSnapshot<K,N,S> - Class in org.apache.flink.runtime.state.heap
This class represents the snapshot of a CopyOnWriteStateTable and has a role in operator state checkpointing.
copyOperation(AbstractInsnNode, BasicValue) - Method in class org.apache.flink.api.java.sca.NestedMethodAnalyzer
 
copyStream(InputStream, OutputStream, boolean) - Method in class org.apache.flink.api.scala.ClosureCleaner$
Copy all data from an InputStream to an OutputStream
copyStream(InputStream, OutputStream, boolean) - Static method in class org.apache.flink.api.scala.ClosureCleaner
Copy all data from an InputStream to an OutputStream
copyString(DataInput, DataOutput) - Static method in class org.apache.flink.types.StringValue
 
copyTemplate() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
 
copyTo(int, MemorySegment, int, int) - Method in class org.apache.flink.core.memory.MemorySegment
Bulk copy method.
copyTo(ValueArray<IntValue>) - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
 
copyTo(ValueArray<LongValue>) - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
 
copyTo(ValueArray<NullValue>) - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
 
copyTo(ValueArray<StringValue>) - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
 
copyTo(T, StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
Copies this record into the new stream record.
copyTo(BooleanValue) - Method in class org.apache.flink.types.BooleanValue
 
copyTo(ByteValue) - Method in class org.apache.flink.types.ByteValue
 
copyTo(CharValue) - Method in class org.apache.flink.types.CharValue
 
copyTo(T) - Method in interface org.apache.flink.types.CopyableValue
Performs a deep copy of this object into the target instance.
copyTo(DoubleValue) - Method in class org.apache.flink.types.DoubleValue
 
copyTo(FloatValue) - Method in class org.apache.flink.types.FloatValue
 
copyTo(IntValue) - Method in class org.apache.flink.types.IntValue
 
copyTo(LongValue) - Method in class org.apache.flink.types.LongValue
 
copyTo(NullValue) - Method in class org.apache.flink.types.NullValue
 
copyTo(Record) - Method in class org.apache.flink.types.Record
 
copyTo(ShortValue) - Method in class org.apache.flink.types.ShortValue
 
copyTo(StringValue) - Method in class org.apache.flink.types.StringValue
 
copyToLocal(URI, File) - Static method in class org.apache.flink.streaming.util.HDFSCopyToLocal
 
copyType(RelDataType) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
copyVerticesFromEdgeWithDegrees(EnumTrianglesDataTypes.EdgeWithDegrees) - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Edge
 
copyVerticesFromTuple2(Tuple2<Integer, Integer>) - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Edge
 
CoreOptions - Class in org.apache.flink.configuration
 
CoreOptions() - Constructor for class org.apache.flink.configuration.CoreOptions
 
correlated() - Method in class org.apache.flink.table.plan.logical.Join
 
CorrelateFlatMapRunner<IN,OUT> - Class in org.apache.flink.table.runtime
 
CorrelateFlatMapRunner(String, String, String, String, TypeInformation<OUT>) - Constructor for class org.apache.flink.table.runtime.CorrelateFlatMapRunner
 
correlateOpName(RexCall, TableSqlFunction, RelDataType) - Method in interface org.apache.flink.table.plan.nodes.CommonCorrelate
 
correlateToString(RexCall, TableSqlFunction) - Method in interface org.apache.flink.table.plan.nodes.CommonCorrelate
 
CorruptConfigurationException - Exception in org.apache.flink.runtime.operators.util
Exception indicating that the parsed configuration was corrupt.
CorruptConfigurationException(String) - Constructor for exception org.apache.flink.runtime.operators.util.CorruptConfigurationException
Creates a new exception with the given error message.
CorruptConfigurationException(String, Throwable) - Constructor for exception org.apache.flink.runtime.operators.util.CorruptConfigurationException
 
COS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
cos() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Calculates the cosine of a given number.
COS() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
COS() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
Cos - Class in org.apache.flink.table.expressions
 
Cos(Expression) - Constructor for class org.apache.flink.table.expressions.Cos
 
Cos$ - Class in org.apache.flink.table.expressions
 
Cos$() - Constructor for class org.apache.flink.table.expressions.Cos$
 
COS_DEC() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
COS_DEC() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
CosineDistance<DATA> - Class in org.apache.flink.streaming.api.functions.windowing.delta
This delta function calculates the cosine distance between two given vectors.
CosineDistance() - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.CosineDistance
 
CosineDistance(Extractor<DATA, double[]>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.CosineDistance
 
CosineDistanceMetric - Class in org.apache.flink.ml.metrics.distances
This class implements a cosine distance metric.
CosineDistanceMetric() - Constructor for class org.apache.flink.ml.metrics.distances.CosineDistanceMetric
 
CosineDistanceMetric$ - Class in org.apache.flink.ml.metrics.distances
 
CosineDistanceMetric$() - Constructor for class org.apache.flink.ml.metrics.distances.CosineDistanceMetric$
 
CostEstimator - Class in org.apache.flink.optimizer.costs
Abstract base class for a cost estimator.
CostEstimator() - Constructor for class org.apache.flink.optimizer.costs.CostEstimator
 
costOperator(PlanNode) - Method in class org.apache.flink.optimizer.costs.CostEstimator
This method computes the cost of an operator.
CoStreamFlatMap<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
CoStreamFlatMap(CoFlatMapFunction<IN1, IN2, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
 
CoStreamMap<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
CoStreamMap(CoMapFunction<IN1, IN2, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.co.CoStreamMap
 
Costs - Class in org.apache.flink.optimizer.costs
Simple class to represent the costs of an operation.
Costs() - Constructor for class org.apache.flink.optimizer.costs.Costs
Default constructor.
Costs(double, double) - Constructor for class org.apache.flink.optimizer.costs.Costs
Creates a new costs object using the given values for the network and storage cost.
Costs(double, double, double) - Constructor for class org.apache.flink.optimizer.costs.Costs
Creates a new costs object using the given values for the network and storage cost.
costWeight - Variable in class org.apache.flink.optimizer.dag.OptimizerNode
 
COT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
cot() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Calculates the cotangent of a given number.
COT() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
COT() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
Cot - Class in org.apache.flink.table.expressions
 
Cot(Expression) - Constructor for class org.apache.flink.table.expressions.Cot
 
Cot$ - Class in org.apache.flink.table.expressions
 
Cot$() - Constructor for class org.apache.flink.table.expressions.Cot$
 
COT_DEC() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
COT_DEC() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
COUNT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
COUNT aggregate function.
count() - Method in class org.apache.flink.api.java.DataSet
Convenience method to get the count (number of elements) of a DataSet.
count() - Static method in class org.apache.flink.api.scala.CrossDataSet
 
count() - Method in class org.apache.flink.api.scala.DataSet
Convenience method to get the count (number of elements) of a DataSet
count - Variable in class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
 
count - Variable in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
Count<T> - Class in org.apache.flink.graph.asm.dataset
Count the number of elements in a DataSet.
Count() - Constructor for class org.apache.flink.graph.asm.dataset.Count
 
count(DataSet<T>) - Static method in class org.apache.flink.graph.utils.GraphUtils
Count the number of elements in a DataSet.
count - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
count - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.CounterDump
 
count - Variable in class org.apache.flink.streaming.examples.socket.SocketWindowWordCount.WordWithCount
 
count() - Method in class org.apache.flink.streaming.scala.examples.socket.SocketWindowWordCount.WordWithCount
 
count() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Returns the number of input rows for which the field is not null.
count(boolean, String, RexNode[]) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
Count - Class in org.apache.flink.table.expressions
 
Count(Expression) - Constructor for class org.apache.flink.table.expressions.Count
 
Count$ - Class in org.apache.flink.table.expressions
 
Count$() - Constructor for class org.apache.flink.table.expressions.Count$
 
CountAccumulator - Class in org.apache.flink.table.functions.aggfunctions
The initial accumulator for count aggregate function
CountAccumulator() - Constructor for class org.apache.flink.table.functions.aggfunctions.CountAccumulator
 
CountAggFunction - Class in org.apache.flink.table.functions.aggfunctions
built-in count aggregate function
CountAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.CountAggFunction
 
CountAppender() - Constructor for class org.apache.flink.examples.java.clustering.KMeans.CountAppender
 
countBuffers() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
countElementsPerPartition(DataSet<T>) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Method that goes over all the elements in each partition in order to retrieve the total number of elements.
Counter - Class in org.apache.flink.api.scala.codegen
 
Counter() - Constructor for class org.apache.flink.api.scala.codegen.Counter
 
Counter - Interface in org.apache.flink.metrics
A Counter is a Metric that measures a count.
counter(int) - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
 
counter(String) - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
 
counter(int, C) - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
 
counter(String, C) - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
 
counter(int) - Method in interface org.apache.flink.metrics.MetricGroup
Creates and registers a new Counter with Flink.
counter(String) - Method in interface org.apache.flink.metrics.MetricGroup
Creates and registers a new Counter with Flink.
counter(int, C) - Method in interface org.apache.flink.metrics.MetricGroup
Registers a Counter with Flink.
counter(String, C) - Method in interface org.apache.flink.metrics.MetricGroup
Registers a Counter with Flink.
counter(int) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
counter(String) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
counter(int, C) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
counter(String, C) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
counter(int) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
counter(String) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
counter(int, C) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
counter(String, C) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
counter - Variable in class org.apache.flink.storm.util.InMemorySpout
 
counter() - Method in class org.apache.flink.streaming.scala.examples.async.SimpleSource
 
CounterDump(QueryScopeInfo, String, long) - Constructor for class org.apache.flink.runtime.metrics.dump.MetricDump.CounterDump
 
counterId - Static variable in class org.apache.flink.storm.wordcount.WordCountTopology
 
counters - Variable in class org.apache.flink.metrics.reporter.AbstractReporter
 
CountEvictor<W extends Window> - Class in org.apache.flink.streaming.api.windowing.evictors
An Evictor that keeps up to a certain amount of elements.
CountHelper(String) - Constructor for class org.apache.flink.api.java.Utils.CountHelper
 
CountingCollector<OUT> - Class in org.apache.flink.runtime.operators.util.metrics
 
CountingCollector(Collector<OUT>, Counter) - Constructor for class org.apache.flink.runtime.operators.util.metrics.CountingCollector
 
CountingIterable<IN> - Class in org.apache.flink.runtime.operators.util.metrics
 
CountingIterable(Iterable<IN>, Counter) - Constructor for class org.apache.flink.runtime.operators.util.metrics.CountingIterable
 
CountingIterator<IN> - Class in org.apache.flink.runtime.operators.util.metrics
 
CountingIterator(Iterator<IN>, Counter) - Constructor for class org.apache.flink.runtime.operators.util.metrics.CountingIterator
 
CountingMutableObjectIterator<IN> - Class in org.apache.flink.runtime.operators.util.metrics
 
CountingMutableObjectIterator(MutableObjectIterator<IN>, Counter) - Constructor for class org.apache.flink.runtime.operators.util.metrics.CountingMutableObjectIterator
 
CountingOutput(Output<StreamRecord<OUT>>, Counter) - Constructor for class org.apache.flink.streaming.api.operators.AbstractStreamOperator.CountingOutput
 
countList() - Method in class org.apache.flink.table.runtime.LimitFilterFunction
 
CountPartitionFunction<IN> - Class in org.apache.flink.table.runtime
 
CountPartitionFunction() - Constructor for class org.apache.flink.table.runtime.CountPartitionFunction
 
COUNTS - Static variable in class org.apache.flink.test.testdata.WordCountData
 
COUNTS_AS_TUPLES - Static variable in class org.apache.flink.test.testdata.WordCountData
 
countStar(String) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
CountTrigger<W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
A Trigger that fires once the count of elements in a pane reaches the given count.
countWindow(long) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Windows this KeyedStream into tumbling count windows.
countWindow(long, long) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Windows this KeyedStream into sliding count windows.
countWindow(long, long) - Method in class org.apache.flink.streaming.api.scala.KeyedStream
Windows this KeyedStream into sliding count windows.
countWindow(long) - Method in class org.apache.flink.streaming.api.scala.KeyedStream
Windows this KeyedStream into tumbling count windows.
countWindowAll(long) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Windows this DataStream into tumbling count windows.
countWindowAll(long, long) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Windows this DataStream into sliding count windows.
countWindowAll(long, long) - Method in class org.apache.flink.streaming.api.scala.DataStream
Windows this DataStream into sliding count windows.
countWindowAll(long) - Method in class org.apache.flink.streaming.api.scala.DataStream
Windows this DataStream into tumbling count windows.
COVAR_POP - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
COVAR_POP aggregate function.
COVAR_SAMP - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
COVAR_SAMP aggregate function.
cover(TimeWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
Returns the minimal window covers both this window and the given window.
cpu() - Method in class org.apache.flink.table.plan.cost.DataSetCost
 
cpus() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
Get the CPU units to use for the TaskManager process.
create(InputStream) - Method in class org.apache.flink.api.common.io.compression.Bzip2InputStreamFactory
 
create(InputStream) - Method in class org.apache.flink.api.common.io.compression.DeflateInflaterInputStreamFactory
 
create(InputStream) - Method in class org.apache.flink.api.common.io.compression.GzipInflaterInputStreamFactory
 
create(InputStream) - Method in interface org.apache.flink.api.common.io.compression.InflaterInputStreamFactory
Creates a InflaterInputStream that wraps the given input stream.
create(InputStream) - Method in class org.apache.flink.api.common.io.compression.XZInputStreamFactory
 
create(TupleTypeInfoBase<?>) - Static method in class org.apache.flink.api.java.summarize.aggregation.SummaryAggregatorFactory
 
create(Class<T>) - Static method in class org.apache.flink.api.java.summarize.aggregation.SummaryAggregatorFactory
Create an SummaryAggregator for the supplied type
create(Kryo, Input, Class<Collection>) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.SpecificInstanceCollectionSerializer
 
create(Path, boolean, int, short, long) - Method in class org.apache.flink.core.fs.FileSystem
Deprecated.
Deprecated because not well supported across types of file systems. Control the behavior of specific file systems via configurations instead.
create(Path, boolean) - Method in class org.apache.flink.core.fs.FileSystem
Deprecated.
create(Path, FileSystem.WriteMode) - Method in class org.apache.flink.core.fs.FileSystem
Opens an FSDataOutputStream to a new file at the given path.
create(Path, FileSystem.WriteMode) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
create(Path, boolean, int, short, long) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
create(Path, boolean, int, short, long) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
create(Path, FileSystem.WriteMode) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
create(ExecutionEnvironment) - Method in class org.apache.flink.graph.drivers.input.CSV
Generate the graph as configured.
create(ExecutionEnvironment) - Method in class org.apache.flink.graph.drivers.input.GeneratedGraph
 
create(ExecutionEnvironment) - Method in class org.apache.flink.graph.drivers.input.GeneratedMultiGraph
Generate the graph as configured.
create(ExecutionEnvironment) - Method in interface org.apache.flink.graph.drivers.input.Input
Create the input Graph.
create(Configuration) - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
Create the Mesos TaskManager parameters.
create() - Method in interface org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook.Factory
Instantiates the MasterTriggerRestoreHook.
create(Configuration, long, int) - Static method in class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
Computes the parameters to be used to start a TaskManager Java process.
create(ExecutionGraph) - Method in interface org.apache.flink.runtime.executiongraph.failover.FailoverStrategy.Factory
Instantiates the FailoverStrategy.
create(ExecutionGraph) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartAllStrategy.Factory
 
create(ExecutionGraph) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy.Factory
 
create(ExecutionGraph) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy.Factory
 
create(Path, boolean, int, short, long) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
 
create(Path, FileSystem.WriteMode) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
 
create(Path, boolean, int, short, long) - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
 
create(Path, FileSystem.WriteMode) - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
 
create(String, JobID, ExecutionAttemptID, InputGateDeploymentDescriptor, NetworkEnvironment, TaskActions, TaskIOMetricGroup) - Static method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
Creates an input gate and all of its input channels.
create(Executor) - Method in interface org.apache.flink.runtime.state.SharedStateRegistryFactory
Factory method for SharedStateRegistry.
create() - Static method in class org.apache.flink.runtime.util.LRUCache
 
create() - Static method in class org.apache.flink.runtime.util.LRUCacheMap
 
create() - Static method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
Creates a new GlobalWindows WindowAssigner that assigns all elements to the same GlobalWindow.
create() - Static method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
Creates an event-time trigger that fires once the watermark passes the end of the window.
create() - Static method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
Creates a new trigger that fires once system time passes the end of the window.
create() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.KeyMap.LazyFactory
The factory method; creates the value.
create(FrameworkConfig) - Method in class org.apache.flink.table.calcite.FlinkRelBuilder$
 
create(FrameworkConfig) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
create(RelOptPlanner, RexBuilder) - Method in class org.apache.flink.table.calcite.FlinkRelOptClusterFactory$
 
create(RelOptPlanner, RexBuilder) - Static method in class org.apache.flink.table.calcite.FlinkRelOptClusterFactory
 
create(LogicalWindow, Seq<FlinkRelBuilder.NamedWindowProperty>, Aggregate) - Method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate$
 
create(LogicalWindow, Seq<FlinkRelBuilder.NamedWindowProperty>, Aggregate) - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
create(List<RelNode>, boolean) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion$
 
create(List<RelNode>, boolean) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
create(RelOptCluster, RelDataType, ImmutableList<ImmutableList<RexLiteral>>) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues$
 
create(RelOptCluster, RelDataType, ImmutableList<ImmutableList<RexLiteral>>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
createAccumulator() - Method in interface org.apache.flink.api.common.functions.AggregateFunction
Creates a new accumulator, starting a new aggregate.
createAccumulator() - Method in class org.apache.flink.api.common.functions.RichAggregateFunction
 
createAccumulator() - Method in class org.apache.flink.table.functions.aggfunctions.BigIntegralAvgAggFunction
 
createAccumulator() - Method in class org.apache.flink.table.functions.aggfunctions.CountAggFunction
 
createAccumulator() - Method in class org.apache.flink.table.functions.aggfunctions.DecimalAvgAggFunction
 
createAccumulator() - Method in class org.apache.flink.table.functions.aggfunctions.DecimalSumAggFunction
 
createAccumulator() - Method in class org.apache.flink.table.functions.aggfunctions.DecimalSumWithRetractAggFunction
 
createAccumulator() - Method in class org.apache.flink.table.functions.aggfunctions.FloatingAvgAggFunction
 
createAccumulator() - Method in class org.apache.flink.table.functions.aggfunctions.IntegralAvgAggFunction
 
createAccumulator() - Method in class org.apache.flink.table.functions.aggfunctions.MaxAggFunction
 
createAccumulator() - Method in class org.apache.flink.table.functions.aggfunctions.MaxWithRetractAggFunction
 
createAccumulator() - Method in class org.apache.flink.table.functions.aggfunctions.MinAggFunction
 
createAccumulator() - Method in class org.apache.flink.table.functions.aggfunctions.MinWithRetractAggFunction
 
createAccumulator() - Method in class org.apache.flink.table.functions.aggfunctions.SumAggFunction
 
createAccumulator() - Method in class org.apache.flink.table.functions.aggfunctions.SumWithRetractAggFunction
 
createAccumulator() - Method in class org.apache.flink.table.functions.AggregateFunction
Creates and init the Accumulator for this AggregateFunction.
createAccumulator() - Method in class org.apache.flink.table.runtime.aggregate.AggregateAggFunction
 
createAccumulatorRowType(AggregateFunction<?, ?>[]) - Method in class org.apache.flink.table.runtime.aggregate.AggregateUtil$
 
createAccumulatorRowType(AggregateFunction<?, ?>[]) - Static method in class org.apache.flink.table.runtime.aggregate.AggregateUtil
 
createAccumulators() - Method in class org.apache.flink.table.runtime.aggregate.GeneratedAggregations
Initializes the accumulators and save them to a accumulators row.
createActivatorDeactivator() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
createActorProps(Class<? extends MesosFlinkResourceManager>, Configuration, MesosConfiguration, MesosWorkerStore, LeaderRetrievalService, MesosTaskManagerParameters, ContainerSpecification, MesosArtifactResolver, Logger) - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
Creates the props needed to instantiate this actor.
createActorProps(Class<T>, Configuration) - Method in class org.apache.flink.mesos.scheduler.ConnectionMonitor$
Creates the properties for the ConnectionMonitor actor.
createActorProps(Class<T>, Configuration) - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
Creates the properties for the ConnectionMonitor actor.
createActorProps(Class<T>, ActorRef, Configuration, SchedulerDriver, TaskSchedulerBuilder) - Method in class org.apache.flink.mesos.scheduler.LaunchCoordinator$
Get the configuration properties for the launch coordinator.
createActorProps(Class<T>, ActorRef, Configuration, SchedulerDriver, TaskSchedulerBuilder) - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
Get the configuration properties for the launch coordinator.
createActorProps(Class<T>, Configuration, SchedulerDriver) - Method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator$
Create the properties for a reconciliation coordinator.
createActorProps(Class<T>, Configuration, SchedulerDriver) - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
Create the properties for a reconciliation coordinator.
createActorProps(Class<T>, Configuration, SchedulerDriver, TaskMonitor.TaskGoalState) - Method in class org.apache.flink.mesos.scheduler.TaskMonitor$
Creates the properties for the TaskMonitor actor.
createActorProps(Class<T>, Configuration, SchedulerDriver, TaskMonitor.TaskGoalState) - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
Creates the properties for the TaskMonitor actor.
createActorProps(Class<T>, Configuration, SchedulerDriver, Class<M>) - Method in class org.apache.flink.mesos.scheduler.Tasks$
Create a tasks actor.
createActorProps(Class<T>, Configuration, SchedulerDriver, Class<M>) - Static method in class org.apache.flink.mesos.scheduler.Tasks
Create a tasks actor.
createActorProps(LeaderRetrievalService, FiniteDuration, boolean) - Static method in class org.apache.flink.runtime.client.JobAttachmentClientActor
 
createActorProps(LeaderRetrievalService, FiniteDuration, boolean, Configuration) - Static method in class org.apache.flink.runtime.client.JobSubmissionClientActor
 
createActorProps(Class<? extends YarnFlinkResourceManager>, Configuration, YarnConfiguration, LeaderRetrievalService, String, String, ContaineredTaskManagerParameters, ContainerLaunchContext, int, Logger) - Static method in class org.apache.flink.yarn.YarnFlinkResourceManager
Creates the props needed to instantiate this actor.
createActorSystem(Configuration, String, int) - Method in class org.apache.flink.runtime.akka.AkkaUtils$
Creates an actor system bound to the given hostname and port.
createActorSystem(Configuration, Option<Tuple2<String, Object>>) - Method in class org.apache.flink.runtime.akka.AkkaUtils$
Creates an actor system.
createActorSystem(Config) - Method in class org.apache.flink.runtime.akka.AkkaUtils$
Creates an actor system with the given akka config.
createActorSystem(Configuration, String, int) - Static method in class org.apache.flink.runtime.akka.AkkaUtils
Creates an actor system bound to the given hostname and port.
createActorSystem(Configuration, Option<Tuple2<String, Object>>) - Static method in class org.apache.flink.runtime.akka.AkkaUtils
Creates an actor system.
createActorSystem(Config) - Static method in class org.apache.flink.runtime.akka.AkkaUtils
Creates an actor system with the given akka config.
createAggImpl(SqlToRelConverter.Blackboard, SqlToRelConverter.AggConverter, SqlNodeList, SqlNodeList, SqlNode, List<SqlNode>) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
 
createAggregate(SqlToRelConverter.Blackboard, boolean, ImmutableBitSet, ImmutableList<ImmutableBitSet>, List<AggregateCall>) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Creates an Aggregate.
createAggregateSqlFunction(String, AggregateFunction<?, ?>, TypeInformation<?>, FlinkTypeFactory) - Method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils$
Create SqlFunction for an AggregateFunction
createAggregateSqlFunction(String, AggregateFunction<?, ?>, TypeInformation<?>, FlinkTypeFactory) - Static method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils
Create SqlFunction for an AggregateFunction
createAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>) - Method in interface org.apache.flink.api.common.state.StateBinder
Creates and returns a new AggregatingState.
createAggregatingState(TypeSerializer<N>, AggregatingStateDescriptor<T, ACC, R>) - Method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
 
createAggregatingState(TypeSerializer<N>, AggregatingStateDescriptor<T, ACC, R>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
Creates and returns a new AggregatingState.
createAggregatingState(TypeSerializer<N>, AggregatingStateDescriptor<T, ACC, R>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
createAggregationAllWindowFunction(LogicalWindow, int, Seq<FlinkRelBuilder.NamedWindowProperty>) - Method in class org.apache.flink.table.runtime.aggregate.AggregateUtil$
Create an AllWindowFunction for non-partitioned window aggregates.
createAggregationAllWindowFunction(LogicalWindow, int, Seq<FlinkRelBuilder.NamedWindowProperty>) - Static method in class org.apache.flink.table.runtime.aggregate.AggregateUtil
Create an AllWindowFunction for non-partitioned window aggregates.
createAggregationFunction(Class<T>) - Method in interface org.apache.flink.api.java.aggregation.AggregationFunctionFactory
 
createAggregationFunction(Class<T>) - Method in class org.apache.flink.api.java.aggregation.MaxAggregationFunction.MaxAggregationFunctionFactory
 
createAggregationFunction(Class<T>) - Method in class org.apache.flink.api.java.aggregation.MinAggregationFunction.MinAggregationFunctionFactory
 
createAggregationFunction(Class<T>) - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.SumAggregationFunctionFactory
 
createAggregationGroupWindowFunction(LogicalWindow, int, int, int, Seq<FlinkRelBuilder.NamedWindowProperty>) - Method in class org.apache.flink.table.runtime.aggregate.AggregateUtil$
Create a WindowFunction for group window aggregates.
createAggregationGroupWindowFunction(LogicalWindow, int, int, int, Seq<FlinkRelBuilder.NamedWindowProperty>) - Static method in class org.apache.flink.table.runtime.aggregate.AggregateUtil
Create a WindowFunction for group window aggregates.
createAndAddResultDataSet(ResultPartitionType) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
createAndAddResultDataSet(IntermediateDataSetID, ResultPartitionType) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
createAndRegisterTempFile(String) - Method in class org.apache.flink.test.util.AbstractTestBase
 
createArrayType(RelDataType, long) - Method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
createAttemptAccumulatorsJson(AccessExecution) - Static method in class org.apache.flink.runtime.webmonitor.handlers.SubtaskExecutionAttemptAccumulatorsHandler
 
createAttemptDetailsJson(AccessExecution, String, String, MetricFetcher) - Static method in class org.apache.flink.runtime.webmonitor.handlers.SubtaskExecutionAttemptDetailsHandler
 
createAvailableOrEmbeddedServices(Configuration, Executor) - Static method in class org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils
 
createBasePath(FileSystem, Path, JobID) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory
 
createBasePath(FileSystem, Path, JobID) - Method in class org.apache.flink.runtime.state.filesystem.FsSavepointStreamFactory
 
createBlackboard(SqlValidatorScope, Map<String, RexNode>, boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Factory method for creating translation workspace.
createBlobStore() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
Creates the BLOB store in which BLOBs are stored in a highly-available fashion.
createBlobStore() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
 
createBlobStore() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
createBlobStore() - Method in class org.apache.flink.yarn.highavailability.YarnHighAvailabilityServices
 
createBlobStoreFromConfig(Configuration) - Static method in class org.apache.flink.runtime.blob.BlobUtils
Creates a BlobStore based on the parameters set in the configuration.
createBlockChannelReader(FileIOChannel.ID) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
Creates a block channel reader that reads blocks from the given channel.
createBlockChannelReader(FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
Creates a block channel reader that reads blocks from the given channel.
createBlockChannelReader(FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
Creates a block channel reader that reads blocks from the given channel.
createBlockChannelWriter(FileIOChannel.ID) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
Creates a block channel writer that writes to the given channel.
createBlockChannelWriter(FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
Creates a block channel writer that writes to the given channel.
createBlockChannelWriter(FileIOChannel.ID, RequestDoneCallback<MemorySegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
Creates a block channel writer that writes to the given channel.
createBlockChannelWriter(FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
 
createBlockChannelWriter(FileIOChannel.ID, RequestDoneCallback<MemorySegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
 
createBlockInfo() - Method in class org.apache.flink.api.common.io.BinaryInputFormat
 
createBlockInfo() - Method in class org.apache.flink.api.common.io.BinaryOutputFormat
 
createBlockInformation(int, int, DataSet<Tuple2<Object, ALS.Rating>>, ALS.BlockIDPartitioner) - Method in class org.apache.flink.ml.recommendation.ALS$
Creates the meta information needed to route the item and user vectors to the respective user and item blocks.
createBlockInformation(int, int, DataSet<Tuple2<Object, ALS.Rating>>, ALS.BlockIDPartitioner) - Static method in class org.apache.flink.ml.recommendation.ALS
Creates the meta information needed to route the item and user vectors to the respective user and item blocks.
createBoundedAndCurrentRowOverWindow(StreamQueryConfig, CodeGenerator, DataStream<CRow>, boolean, boolean) - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamOverAggregate
 
createBoundedOverProcessFunction(CodeGenerator, Seq<Pair<AggregateCall, String>>, RelDataType, TypeInformation<Row>, Seq<TypeInformation<?>>, long, StreamQueryConfig, boolean, boolean) - Method in class org.apache.flink.table.runtime.aggregate.AggregateUtil$
Create an ProcessFunction for ROWS clause bounded OVER window to evaluate final aggregate value.
createBoundedOverProcessFunction(CodeGenerator, Seq<Pair<AggregateCall, String>>, RelDataType, TypeInformation<Row>, Seq<TypeInformation<?>>, long, StreamQueryConfig, boolean, boolean) - Static method in class org.apache.flink.table.runtime.aggregate.AggregateUtil
Create an ProcessFunction for ROWS clause bounded OVER window to evaluate final aggregate value.
createBrokerIdString(JobID, String, int) - Static method in class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
Creates the identification string with which head and tail task find the shared blocking queue for the back channel.
createBufferFileReader(FileIOChannel.ID, RequestDoneCallback<Buffer>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
 
createBufferFileReader(FileIOChannel.ID, RequestDoneCallback<Buffer>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
 
createBufferFileSegmentReader(FileIOChannel.ID, RequestDoneCallback<FileSegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
 
createBufferFileSegmentReader(FileIOChannel.ID, RequestDoneCallback<FileSegment>) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
 
createBufferFileWriter(FileIOChannel.ID) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
 
createBufferFileWriter(FileIOChannel.ID) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
 
createBufferPool(int, int) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPoolFactory
Tries to create a buffer pool, which is guaranteed to provide at least the number of required buffers.
createBufferPool(int, int) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
createBuilder() - Method in class org.apache.flink.table.calcite.CalciteConfig$
Creates a new builder for constructing a CalciteConfig.
createBulkBlockChannelReader(FileIOChannel.ID, List<MemorySegment>, int) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
Creates a block channel reader that reads all blocks from the given channel directly in one bulk.
createBulkBlockChannelReader(FileIOChannel.ID, List<MemorySegment>, int) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
Creates a block channel reader that reads all blocks from the given channel directly in one bulk.
createCall(SqlLiteral, SqlParserPos, SqlNode[]) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
createCall(SqlParserPos, SqlNode[]) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
createCall(SqlNodeList) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
createCall(SqlParserPos, List<? extends SqlNode>) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
createCall(SqlLiteral, SqlParserPos, SqlNode[]) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
createCall(SqlParserPos, SqlNode[]) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
createCall(SqlNodeList) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
createCall(SqlParserPos, List<? extends SqlNode>) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
createCall(SqlLiteral, SqlParserPos, SqlNode[]) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
createCall(SqlParserPos, SqlNode[]) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
createCall(SqlNodeList) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
createCall(SqlParserPos, List<? extends SqlNode>) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
createCall(SqlLiteral, SqlParserPos, SqlNode[]) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
createCall(SqlParserPos, SqlNode[]) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
createCall(SqlNodeList) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
createCall(SqlParserPos, List<? extends SqlNode>) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
createCallBridge() - Method in class org.apache.flink.streaming.connectors.kafka.internal.Kafka010Fetcher
This method needs to be overridden because Kafka broke binary compatibility between 0.9 and 0.10, changing binary signatures
createCallBridge() - Method in class org.apache.flink.streaming.connectors.kafka.internal.Kafka09Fetcher
 
createChannel() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
Creates a new FileIOChannel.ID in one of the temp directories.
createChannelEnumerator() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
Creates a new FileIOChannel.Enumerator, spreading the channels in a round-robin fashion across the temporary file directories.
createCheckpointDataSerializer() - Method in interface org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook
Creates a the serializer to (de)serializes the data stored by this hook.
createCheckpointDetailsJson(AbstractCheckpointStats) - Static method in class org.apache.flink.runtime.webmonitor.handlers.checkpoints.CheckpointStatsDetailsHandler
 
createCheckpointDirPath(Path, long) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory
 
createCheckpointDirPath(Path, long) - Method in class org.apache.flink.runtime.state.filesystem.FsSavepointStreamFactory
 
createCheckpointIDCounter(JobID) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointRecoveryFactory
Creates a CheckpointIDCounter instance for a job.
createCheckpointIDCounter(JobID) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointRecoveryFactory
 
createCheckpointIDCounter(JobID) - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointRecoveryFactory
 
createCheckpointIDCounter(CuratorFramework, Configuration, JobID) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
Creates a ZooKeeperCheckpointIDCounter instance.
createCheckpointStateOutputStream(long, long) - Method in interface org.apache.flink.runtime.state.CheckpointStreamFactory
createCheckpointStateOutputStream(long, long) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory
 
createCheckpointStateOutputStream(long, long) - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory
 
createCheckpointStore(JobID, int, ClassLoader) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointRecoveryFactory
Creates a CompletedCheckpointStore instance for a job.
createCheckpointStore(JobID, int, ClassLoader) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointRecoveryFactory
 
createCheckpointStore(JobID, int, ClassLoader) - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointRecoveryFactory
 
createCheckpointStreamFactory(StreamOperator<?>) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
This is only visible because GenericWriteAheadSink uses the checkpoint stream factory to write write-ahead logs.
createClassNotInClassPath(ClassLoader) - Static method in class org.apache.flink.core.testutils.CommonTestUtils
Creates a new class that is not part of the classpath that the current JVM uses.
createClient(CommandLineOptions, PackagedProgram) - Method in class org.apache.flink.client.CliFrontend
Creates a ClusterClient object from the given command line options and other parameters.
createClient() - Method in class org.apache.flink.runtime.blob.BlobCache
 
createClient() - Method in class org.apache.flink.runtime.blob.BlobServer
 
createClient() - Method in interface org.apache.flink.runtime.blob.BlobService
 
createClient(Map<String, String>) - Method in class org.apache.flink.streaming.connectors.elasticsearch.Elasticsearch1ApiCallBridge
 
createClient(Map<String, String>) - Method in interface org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchApiCallBridge
Creates an Elasticsearch Client.
createClient(Map<String, String>) - Method in class org.apache.flink.streaming.connectors.elasticsearch2.Elasticsearch2ApiCallBridge
 
createClient(Map<String, String>) - Method in class org.apache.flink.streaming.connectors.elasticsearch5.Elasticsearch5ApiCallBridge
 
createClientSSLContext() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
createCluster(String, CommandLine, Configuration, List<URL>) - Method in interface org.apache.flink.client.cli.CustomCommandLine
Creates the client for the cluster
createCluster(String, CommandLine, Configuration, List<URL>) - Method in class org.apache.flink.client.cli.DefaultCLI
 
createCluster(String, CommandLine, Configuration, List<URL>) - Method in class org.apache.flink.yarn.cli.FlinkYarnCLI
 
createCluster(String, CommandLine, Configuration, List<URL>) - Method in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
 
createCollectionsEnvironment() - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a CollectionEnvironment that uses Java Collections underneath.
createCollectionsEnvironment() - Method in class org.apache.flink.api.scala.ExecutionEnvironment$
Creates an execution environment that uses Java Collections underneath.
createCollectionsEnvironment() - Static method in class org.apache.flink.api.scala.ExecutionEnvironment
Creates an execution environment that uses Java Collections underneath.
createColumnOptions(ColumnFamilyOptions) - Method in interface org.apache.flink.contrib.streaming.state.OptionsFactory
This method should set the additional options on top of the current options object.
createColumnOptions() - Method in enum org.apache.flink.contrib.streaming.state.PredefinedOptions
Creates the ColumnFamilyOptionsfor this pre-defined setting.
createComparator(boolean, ExecutionConfig) - Method in interface org.apache.flink.api.common.typeinfo.AtomicType
Creates a comparator for this type.
createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
createComparator(int[], boolean[], int, ExecutionConfig) - Method in class org.apache.flink.api.common.typeutils.CompositeType
Generic implementation of the comparator creation.
createComparator() - Method in interface org.apache.flink.api.common.typeutils.TypeComparatorFactory
 
createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
 
createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
 
createComparator(int[], boolean[], int, ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
 
createComparator() - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeComparatorFactory
 
createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
 
createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.scala.typeutils.EnumValueTypeInfo
 
createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.api.scala.typeutils.OptionTypeInfo
 
createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
 
createComparator(FieldList, boolean[], T) - Method in class org.apache.flink.optimizer.postpass.GenericFlatTypePostPass
 
createComparator(int[], boolean[], int, ExecutionConfig) - Method in class org.apache.flink.table.runtime.types.CRowTypeInfo
 
createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.table.typeutils.InternalTypeInfo
 
createComparator(boolean, ExecutionConfig) - Static method in class org.apache.flink.table.typeutils.RowIntervalTypeInfo
 
createComparator(boolean, ExecutionConfig) - Static method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
 
createComparator(boolean, ExecutionConfig) - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
 
createComparator12(TypeComparator<T1>, TypeComparator<T2>) - Method in interface org.apache.flink.api.common.typeutils.TypePairComparatorFactory
 
createComparator12(TypeComparator<T1>, TypeComparator<T2>) - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimePairComparatorFactory
 
createComparator21(TypeComparator<T1>, TypeComparator<T2>) - Method in interface org.apache.flink.api.common.typeutils.TypePairComparatorFactory
 
createComparator21(TypeComparator<T1>, TypeComparator<T2>) - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimePairComparatorFactory
 
createCompletedCheckpoints(CuratorFramework, Configuration, JobID, int, Executor) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
createConfigJson(long) - Static method in class org.apache.flink.runtime.webmonitor.handlers.DashboardConfigHandler
 
createConnectionMonitor() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
 
createCopy(Kryo, Collection) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.SpecificInstanceCollectionSerializer
 
createCopy(TypeSerializer<T>, T, T) - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
Copies an instance of the given type, potentially reusing the object passed as the reuse parameter, which may be null.
createCopy(TypeSerializer<T>, T, T) - Method in class org.apache.flink.runtime.operators.sort.NonReusingMergeInnerJoinIterator
 
createCopy(TypeSerializer<T>, T, T) - Method in class org.apache.flink.runtime.operators.sort.NonReusingMergeOuterJoinIterator
 
createCopy(TypeSerializer<T>, T, T) - Method in class org.apache.flink.runtime.operators.sort.ReusingMergeInnerJoinIterator
 
createCopy(TypeSerializer<T>, T, T) - Method in class org.apache.flink.runtime.operators.sort.ReusingMergeOuterJoinIterator
 
createCopy() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka08JsonTableSink
 
createCopy() - Method in class org.apache.flink.streaming.connectors.kafka.Kafka09JsonTableSink
 
createCopy() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSink
Create a deep copy of this sink.
createCopy() - Method in class org.apache.flink.types.Record
Creates an exact copy of this record.
createCopySerializable(T) - Static method in class org.apache.flink.core.testutils.CommonTestUtils
Creates a copy of an object via Java Serialization.
createCopyWritable(T) - Static method in class org.apache.flink.util.InstantiationUtil
Clones the given writable using the serialization.
createCrossOperator(DataSet<L>, DataSet<R>, CrossOperatorBase.CrossHint) - Method in class org.apache.flink.api.scala.CrossDataSet$
Creates a default cross operation with Tuple2 as result.
createCrossOperator(DataSet<L>, DataSet<R>, CrossOperatorBase.CrossHint) - Static method in class org.apache.flink.api.scala.CrossDataSet
Creates a default cross operation with Tuple2 as result.
createDataSetAggregateFunctions(CodeGenerator, Seq<Pair<AggregateCall, String>>, RelDataType, Seq<TypeInformation<?>>, RelDataType, int[], boolean) - Method in class org.apache.flink.table.runtime.aggregate.AggregateUtil$
Create functions to compute a DataSetAggregate.
createDataSetAggregateFunctions(CodeGenerator, Seq<Pair<AggregateCall, String>>, RelDataType, Seq<TypeInformation<?>>, RelDataType, int[], boolean) - Static method in class org.apache.flink.table.runtime.aggregate.AggregateUtil
Create functions to compute a DataSetAggregate.
createDataSetSlideWindowPrepareFlatMapFunction(LogicalWindow, Seq<Pair<AggregateCall, String>>, int[], TypeInformation<Row>, boolean) - Method in class org.apache.flink.table.runtime.aggregate.AggregateUtil$
Create a FlatMapFunction that prepares for non-incremental aggregates of sliding windows (time-windows).
createDataSetSlideWindowPrepareFlatMapFunction(LogicalWindow, Seq<Pair<AggregateCall, String>>, int[], TypeInformation<Row>, boolean) - Static method in class org.apache.flink.table.runtime.aggregate.AggregateUtil
Create a FlatMapFunction that prepares for non-incremental aggregates of sliding windows (time-windows).
createDataSetSlideWindowPrepareGroupReduceFunction(CodeGenerator, LogicalWindow, Seq<Pair<AggregateCall, String>>, int[], RelDataType, Seq<TypeInformation<?>>, boolean) - Method in class org.apache.flink.table.runtime.aggregate.AggregateUtil$
Create a GroupReduceFunction that prepares for partial aggregates of sliding windows (time and count-windows).
createDataSetSlideWindowPrepareGroupReduceFunction(CodeGenerator, LogicalWindow, Seq<Pair<AggregateCall, String>>, int[], RelDataType, Seq<TypeInformation<?>>, boolean) - Static method in class org.apache.flink.table.runtime.aggregate.AggregateUtil
Create a GroupReduceFunction that prepares for partial aggregates of sliding windows (time and count-windows).
createDataSetWindowAggregationCombineFunction(CodeGenerator, LogicalWindow, Seq<Pair<AggregateCall, String>>, RelDataType, Seq<TypeInformation<?>>, int[]) - Method in class org.apache.flink.table.runtime.aggregate.AggregateUtil$
Create a GroupCombineFunction that pre-aggregation for aggregates.
createDataSetWindowAggregationCombineFunction(CodeGenerator, LogicalWindow, Seq<Pair<AggregateCall, String>>, RelDataType, Seq<TypeInformation<?>>, int[]) - Static method in class org.apache.flink.table.runtime.aggregate.AggregateUtil
Create a GroupCombineFunction that pre-aggregation for aggregates.
createDataSetWindowAggregationGroupReduceFunction(CodeGenerator, LogicalWindow, Seq<Pair<AggregateCall, String>>, RelDataType, Seq<TypeInformation<?>>, RelDataType, int[], Seq<FlinkRelBuilder.NamedWindowProperty>, boolean) - Method in class org.apache.flink.table.runtime.aggregate.AggregateUtil$
Create a GroupReduceFunction to compute window aggregates on batch tables.
createDataSetWindowAggregationGroupReduceFunction(CodeGenerator, LogicalWindow, Seq<Pair<AggregateCall, String>>, RelDataType, Seq<TypeInformation<?>>, RelDataType, int[], Seq<FlinkRelBuilder.NamedWindowProperty>, boolean) - Static method in class org.apache.flink.table.runtime.aggregate.AggregateUtil
Create a GroupReduceFunction to compute window aggregates on batch tables.
createDataSetWindowAggregationMapPartitionFunction(CodeGenerator, LogicalWindow, Seq<Pair<AggregateCall, String>>, RelDataType, Seq<TypeInformation<?>>, int[]) - Method in class org.apache.flink.table.runtime.aggregate.AggregateUtil$
Create a MapPartitionFunction that aggregation for aggregates.
createDataSetWindowAggregationMapPartitionFunction(CodeGenerator, LogicalWindow, Seq<Pair<AggregateCall, String>>, RelDataType, Seq<TypeInformation<?>>, int[]) - Static method in class org.apache.flink.table.runtime.aggregate.AggregateUtil
Create a MapPartitionFunction that aggregation for aggregates.
createDataSetWindowPrepareMapFunction(CodeGenerator, LogicalWindow, Seq<Pair<AggregateCall, String>>, int[], RelDataType, Seq<TypeInformation<?>>, boolean) - Method in class org.apache.flink.table.runtime.aggregate.AggregateUtil$
Create a MapFunction that prepares for aggregates.
createDataSetWindowPrepareMapFunction(CodeGenerator, LogicalWindow, Seq<Pair<AggregateCall, String>>, int[], RelDataType, Seq<TypeInformation<?>>, boolean) - Static method in class org.apache.flink.table.runtime.aggregate.AggregateUtil
Create a MapFunction that prepares for aggregates.
createDataStreamAggregateFunction(CodeGenerator, Seq<Pair<AggregateCall, String>>, RelDataType, Seq<TypeInformation<?>>, RelDataType, int[], boolean) - Method in class org.apache.flink.table.runtime.aggregate.AggregateUtil$
 
createDataStreamAggregateFunction(CodeGenerator, Seq<Pair<AggregateCall, String>>, RelDataType, Seq<TypeInformation<?>>, RelDataType, int[], boolean) - Static method in class org.apache.flink.table.runtime.aggregate.AggregateUtil
 
createDBOptions(DBOptions) - Method in interface org.apache.flink.contrib.streaming.state.OptionsFactory
This method should set the additional options on top of the current options object.
createDBOptions() - Method in enum org.apache.flink.contrib.streaming.state.PredefinedOptions
Creates the DBOptionsfor this pre-defined setting.
createDecimalProduct(RelDataType, RelDataType) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
createDecimalQuotient(RelDataType, RelDataType) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
createDefaultActorSystem() - Method in class org.apache.flink.runtime.akka.AkkaUtils$
Creates an actor system with the default config and listening on a random port of the localhost.
createDefaultActorSystem() - Static method in class org.apache.flink.runtime.akka.AkkaUtils
Creates an actor system with the default config and listening on a random port of the localhost.
createDefaultFilter() - Static method in class org.apache.flink.api.common.io.FilePathFilter
Returns the default filter, which excludes the following files: Files starting with "_" Files starting with "." Files containing the string "_COPYING_"
createDefaultJoin(Keys<I2>) - Method in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
 
createDefaultJoin(Keys<L>, Keys<R>) - Method in class org.apache.flink.api.scala.UnfinishedJoinOperationBase
 
createDefaultMask(int) - Static method in class org.apache.flink.api.java.io.CsvInputFormat
 
createDescriptor(String, CommandLine) - Method in class org.apache.flink.yarn.cli.FlinkYarnCLI
 
createDescriptor(String, CommandLine) - Method in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
 
createDetailsForJob(AccessExecutionGraph) - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorUtils
 
createDriver(Scheduler, boolean) - Method in class org.apache.flink.mesos.util.MesosConfiguration
Create the Mesos scheduler driver based on this configuration.
createEmptySchema() - Method in class org.apache.flink.optimizer.postpass.GenericFlatTypePostPass
 
createEndpoint() - Method in interface org.apache.flink.streaming.connectors.twitter.TwitterSource.EndpointInitializer
 
createExecutionEnvironment() - Method in interface org.apache.flink.api.java.ExecutionEnvironmentFactory
Creates an ExecutionEnvironment from this factory.
createExecutionEnvironment() - Method in class org.apache.flink.client.program.ContextEnvironmentFactory
 
createExecutionEnvironment() - Method in interface org.apache.flink.streaming.api.environment.StreamExecutionEnvironmentFactory
Creates a StreamExecutionEnvironment from this factory.
createExtension(ExtendedActorSystem) - Static method in class org.apache.flink.runtime.akka.RemoteAddressExtension
 
createFactory(Configuration) - Static method in class org.apache.flink.runtime.executiongraph.restart.FailureRateRestartStrategy
 
createFactory(Configuration) - Static method in class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
Creates a FixedDelayRestartStrategy from the given Configuration.
createFactory(Configuration) - Static method in class org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy
Creates a NoRestartStrategy instance.
createFetcher(SourceFunction.SourceContext<T>, Map<KafkaTopicPartition, Long>, SerializedValue<AssignerWithPeriodicWatermarks<T>>, SerializedValue<AssignerWithPunctuatedWatermarks<T>>, StreamingRuntimeContext, OffsetCommitMode) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer010
 
createFetcher(SourceFunction.SourceContext<T>, Map<KafkaTopicPartition, Long>, SerializedValue<AssignerWithPeriodicWatermarks<T>>, SerializedValue<AssignerWithPunctuatedWatermarks<T>>, StreamingRuntimeContext, OffsetCommitMode) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer08
 
createFetcher(SourceFunction.SourceContext<T>, Map<KafkaTopicPartition, Long>, SerializedValue<AssignerWithPeriodicWatermarks<T>>, SerializedValue<AssignerWithPunctuatedWatermarks<T>>, StreamingRuntimeContext, OffsetCommitMode) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
 
createFetcher(SourceFunction.SourceContext<T>, Map<KafkaTopicPartition, Long>, SerializedValue<AssignerWithPeriodicWatermarks<T>>, SerializedValue<AssignerWithPunctuatedWatermarks<T>>, StreamingRuntimeContext, OffsetCommitMode) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
Creates the fetcher that connect to the Kafka brokers, pulls data, deserialized the data, and emits it into the data streams.
createFileSystemStateStorage(Configuration, String) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
Creates a FileSystemStateStorageHelper instance.
createFinalPlan(List<SinkPlanNode>, String, Plan) - Method in class org.apache.flink.optimizer.traversals.PlanFinalizer
 
createFoldingState(FoldingStateDescriptor<T, ACC>) - Method in interface org.apache.flink.api.common.state.StateBinder
Deprecated.
will be removed in a future version
createFoldingState(TypeSerializer<N>, FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
 
createFoldingState(TypeSerializer<N>, FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
Deprecated.
will be removed in a future version
createFoldingState(TypeSerializer<N>, FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
createFromConfig(Configuration) - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackendFactory
 
createFromConfig(Configuration) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackendFactory
 
createFromConfig(Configuration) - Method in interface org.apache.flink.runtime.state.StateBackendFactory
Creates the state backend, optionally using the given configuration.
createGroupAggregateFunction(CodeGenerator, Seq<Pair<AggregateCall, String>>, RelDataType, Seq<TypeInformation<?>>, int[], StreamQueryConfig, boolean, boolean) - Method in class org.apache.flink.table.runtime.aggregate.AggregateUtil$
Create an ProcessFunction for group (without window) aggregate to evaluate final aggregate value.
createGroupAggregateFunction(CodeGenerator, Seq<Pair<AggregateCall, String>>, RelDataType, Seq<TypeInformation<?>>, int[], StreamQueryConfig, boolean, boolean) - Static method in class org.apache.flink.table.runtime.aggregate.AggregateUtil
Create an ProcessFunction for group (without window) aggregate to evaluate final aggregate value.
createHadoopInput(InputFormat<K, V>, Class<K>, Class<V>, JobConf) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Please use org.apache.flink.hadoopcompatibility.HadoopInputs#createHadoopInput(org.apache.hadoop.mapred.InputFormat, Class, Class, JobConf) from the flink-hadoop-compatibility module.
createHadoopInput(InputFormat<K, V>, Class<K>, Class<V>, Job) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Please use org.apache.flink.hadoopcompatibility.HadoopInputs#createHadoopInput(org.apache.hadoop.mapreduce.InputFormat, Class, Class, Job) from the flink-hadoop-compatibility module.
createHadoopInput(InputFormat<K, V>, Class<K>, Class<V>, JobConf, TypeInformation<Tuple2<K, V>>) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
createHadoopInput(InputFormat<K, V>, Class<K>, Class<V>, Job, TypeInformation<Tuple2<K, V>>) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
createHadoopInput(InputFormat<K, V>, Class<K>, Class<V>, JobConf) - Static method in class org.apache.flink.hadoopcompatibility.HadoopInputs
Creates a Flink InputFormat that wraps the given Hadoop InputFormat.
createHadoopInput(InputFormat<K, V>, Class<K>, Class<V>, Job) - Static method in class org.apache.flink.hadoopcompatibility.HadoopInputs
Creates a Flink InputFormat that wraps the given Hadoop InputFormat.
createHadoopInput(InputFormat<K, V>, Class<K>, Class<V>, JobConf, TypeInformation<Tuple2<K, V>>) - Method in class org.apache.flink.hadoopcompatibility.scala.HadoopInputs$
Creates a Flink InputFormat that wraps the given Hadoop InputFormat.
createHadoopInput(InputFormat<K, V>, Class<K>, Class<V>, Job, TypeInformation<Tuple2<K, V>>) - Method in class org.apache.flink.hadoopcompatibility.scala.HadoopInputs$
Creates a Flink InputFormat that wraps the given Hadoop InputFormat.
createHadoopInput(InputFormat<K, V>, Class<K>, Class<V>, JobConf, TypeInformation<Tuple2<K, V>>) - Static method in class org.apache.flink.hadoopcompatibility.scala.HadoopInputs
Creates a Flink InputFormat that wraps the given Hadoop InputFormat.
createHadoopInput(InputFormat<K, V>, Class<K>, Class<V>, Job, TypeInformation<Tuple2<K, V>>) - Static method in class org.apache.flink.hadoopcompatibility.scala.HadoopInputs
Creates a Flink InputFormat that wraps the given Hadoop InputFormat.
createHadoopWritableTypeInfo(Class<T>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
createHeartbeatManager(ResourceID, HeartbeatListener<I, O>, ScheduledExecutor, Logger) - Method in class org.apache.flink.runtime.heartbeat.HeartbeatServices
Creates a heartbeat manager which does not actively send heartbeats.
createHeartbeatManagerSender(ResourceID, HeartbeatListener<I, O>, ScheduledExecutor, Logger) - Method in class org.apache.flink.runtime.heartbeat.HeartbeatServices
Creates a heartbeat manager which actively sends heartbeats to monitoring targets.
createHighAvailabilityServices(Configuration, Executor, HighAvailabilityServicesUtils.AddressResolution) - Static method in class org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils
 
createInBlockInformation(DataSet<Tuple2<Object, ALS.Rating>>, DataSet<Tuple2<Object, long[]>>, ALS.BlockIDGenerator) - Method in class org.apache.flink.ml.recommendation.ALS$
Creates the incoming block information
createInBlockInformation(DataSet<Tuple2<Object, ALS.Rating>>, DataSet<Tuple2<Object, long[]>>, ALS.BlockIDGenerator) - Static method in class org.apache.flink.ml.recommendation.ALS
Creates the incoming block information
createIndexRequest(T, RuntimeContext) - Method in interface org.apache.flink.streaming.connectors.elasticsearch.IndexRequestBuilder
Deprecated.
Creates an IndexRequest from an element.
createInitialWeightsDS(Option<DataSet<WeightVector>>, DataSet<LabeledVector>) - Static method in class org.apache.flink.ml.optimization.GradientDescent
 
createInitialWeightsDS(Option<DataSet<WeightVector>>, DataSet<LabeledVector>) - Static method in class org.apache.flink.ml.optimization.IterativeSolver
 
createInitialWeightsDS(Option<DataSet<WeightVector>>, DataSet<LabeledVector>) - Method in class org.apache.flink.ml.optimization.Solver
Creates initial weights vector, creating a DataSet with a WeightVector element
createInitialWeightVector(DataSet<Object>) - Static method in class org.apache.flink.ml.optimization.GradientDescent
 
createInitialWeightVector(DataSet<Object>) - Static method in class org.apache.flink.ml.optimization.IterativeSolver
 
createInitialWeightVector(DataSet<Object>) - Method in class org.apache.flink.ml.optimization.Solver
Creates a DataSet with one zero vector.
createInput(InputFormat<X, ?>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Generic method to create an input DataSet with in InputFormat.
createInput(InputFormat<X, ?>, TypeInformation<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Generic method to create an input DataSet with in InputFormat.
createInput(InputFormat<T, ?>, ClassTag<T>, TypeInformation<T>) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Generic method to create an input DataSet with an InputFormat.
createInput(InputFormat<OUT, ?>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Generic method to create an input data stream with InputFormat.
createInput(InputFormat<OUT, ?>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Generic method to create an input data stream with InputFormat.
createInput(InputFormat<T, ?>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Generic method to create an input data stream with a specific input format.
createInputChannelDeploymentDescriptor(Execution) - Method in class org.apache.flink.runtime.deployment.PartialInputChannelDeploymentDescriptor
Creates a channel deployment descriptor by completing the partition location.
createInputGate(Collection<InputGate>, Collection<InputGate>) - Static method in class org.apache.flink.streaming.runtime.io.InputGateUtil
 
createInputGate(InputGate[]) - Static method in class org.apache.flink.streaming.runtime.io.InputGateUtil
 
createInputIterator(MutableReader<?>, TypeSerializerFactory<?>) - Method in class org.apache.flink.runtime.operators.BatchTask
 
createInputSplits(int) - Method in class org.apache.flink.addons.hbase.AbstractTableInputFormat
 
createInputSplits(int) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
 
createInputSplits(int) - Method in class org.apache.flink.api.common.io.FileInputFormat
Computes the input splits for the file.
createInputSplits(int) - Method in class org.apache.flink.api.common.io.GenericInputFormat
 
createInputSplits(int) - Method in interface org.apache.flink.api.common.io.InputFormat
Creates the different splits of the input that can be processed in parallel.
createInputSplits(int) - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
 
createInputSplits(int) - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
createInputSplits(int) - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
createInputSplits(int) - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat
 
createInputSplits(int) - Method in class org.apache.flink.batch.connectors.cassandra.CassandraInputFormat
 
createInputSplits(int) - Method in interface org.apache.flink.core.io.InputSplitSource
Computes the input splits.
createInputSplits(int) - Method in class org.apache.flink.examples.java.distcp.FileCopyTaskInputFormat
 
createInputSplits(int) - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.TypeDeserializerAdapter
 
createInstance() - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
Creates a new instance of the data type.
createInstance() - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
 
createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
createInstance(Object[]) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
createInstance(Object[]) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
createInstance(Object[]) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
createInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
 
createInstance() - Method in class org.apache.flink.api.scala.typeutils.CaseClassSerializer
 
createInstance() - Method in class org.apache.flink.api.scala.typeutils.EitherSerializer
 
createInstance() - Method in class org.apache.flink.api.scala.typeutils.EnumValueSerializer
 
createInstance() - Method in class org.apache.flink.api.scala.typeutils.NothingSerializer
 
createInstance() - Method in class org.apache.flink.api.scala.typeutils.OptionSerializer
 
createInstance() - Method in class org.apache.flink.api.scala.typeutils.TraversableSerializer
 
createInstance() - Method in class org.apache.flink.api.scala.typeutils.TrySerializer
 
createInstance() - Method in class org.apache.flink.api.scala.typeutils.UnitSerializer
 
createInstance() - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
 
createInstance() - Method in class org.apache.flink.cep.nfa.NFA.NFASerializer
 
createInstance() - Method in class org.apache.flink.cep.nfa.NFA.Serializer
 
createInstance() - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
 
createInstance() - Method in class org.apache.flink.cep.NonDuplicatingTypeSerializer
 
createInstance() - Method in class org.apache.flink.graph.types.valuearray.IntValueArraySerializer
 
createInstance() - Method in class org.apache.flink.graph.types.valuearray.LongValueArraySerializer
 
createInstance() - Method in class org.apache.flink.graph.types.valuearray.NullValueArraySerializer
 
createInstance() - Method in class org.apache.flink.graph.types.valuearray.StringValueArraySerializer
 
createInstance() - Method in class org.apache.flink.migration.MigrationNamespaceSerializerProxy
Deprecated.
 
createInstance() - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer
 
createInstance() - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.StreamRecordSerializer
 
createInstance() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
createInstance() - Method in class org.apache.flink.runtime.state.HashMapSerializer
 
createInstance() - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
 
createInstance() - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
 
createInstance() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
 
createInstance() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
createInstance() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
createInstance() - Method in class org.apache.flink.table.runtime.types.CRowSerializer
 
createInterpreter() - Method in class org.apache.flink.api.scala.FlinkILoop
 
createIterationSourceAndSink(int, int, int, long, int, int, ResourceSpec, ResourceSpec) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
createJarFile() - Method in class org.apache.flink.runtime.util.JarFileCreator
Creates a jar file which contains the previously added class.
createJavaType(Class<?>) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
createJobAccumulatorsJson(AccessExecutionGraph) - Static method in class org.apache.flink.runtime.webmonitor.handlers.JobAccumulatorsHandler
 
createJobConfigJson(AccessExecutionGraph) - Static method in class org.apache.flink.runtime.webmonitor.handlers.JobConfigHandler
 
createJobDetailsJson(AccessExecutionGraph, MetricFetcher) - Static method in class org.apache.flink.runtime.webmonitor.handlers.JobDetailsHandler
 
createJobExceptionsJson(AccessExecutionGraph) - Static method in class org.apache.flink.runtime.webmonitor.handlers.JobExceptionsHandler
 
createJobGraph(StreamGraph) - Static method in class org.apache.flink.streaming.api.graph.StreamingJobGraphGenerator
 
createJobManagerComponents(Configuration, ScheduledExecutorService, Executor, BlobStore) - Method in class org.apache.flink.runtime.jobmanager.JobManager$
Create the job manager components as (instanceManager, scheduler, libraryCacheManager, archiverProps, defaultExecutionRetries, delayBetweenRetries, timeout)
createJobManagerComponents(Configuration, ScheduledExecutorService, Executor, BlobStore) - Static method in class org.apache.flink.runtime.jobmanager.JobManager
Create the job manager components as (instanceManager, scheduler, libraryCacheManager, archiverProps, defaultExecutionRetries, delayBetweenRetries, timeout)
createJoin(SqlToRelConverter.Blackboard, RelNode, RelNode, RexNode, JoinRelType) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
 
createJoinFunctionAssigner(Keys<I2>) - Method in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
 
createJoinFunctionAssigner(Keys<L>, Keys<R>) - Method in class org.apache.flink.api.scala.UnfinishedJoinOperation
 
createJoinFunctionAssigner(Keys<L>, Keys<R>) - Method in class org.apache.flink.api.scala.UnfinishedJoinOperationBase
 
createJoinFunctionAssigner(Keys<L>, Keys<R>) - Method in class org.apache.flink.api.scala.UnfinishedOuterJoinOperation
 
createJoinType(RelDataType[]) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
createKafkaPartitionHandle(KafkaTopicPartition) - Method in class org.apache.flink.streaming.connectors.kafka.internal.Kafka09Fetcher
 
createKafkaPartitionHandle(KafkaTopicPartition) - Method in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
Creates the Kafka version specific representation of the given topic partition.
createKafkaPartitionHandle(KafkaTopicPartition) - Method in class org.apache.flink.streaming.connectors.kafka.internals.Kafka08Fetcher
 
createKafkaProducer(String, Properties, SerializationSchema<Row>, FlinkKafkaPartitioner<Row>) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka08JsonTableSink
 
createKafkaProducer(String, Properties, SerializationSchema<Row>, FlinkKafkaPartitioner<Row>) - Method in class org.apache.flink.streaming.connectors.kafka.Kafka09JsonTableSink
 
createKafkaProducer(String, Properties, SerializationSchema<Row>, FlinkKafkaPartitioner<Row>) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSink
Returns the version-specifid Kafka producer.
createKeyedStateBackend(Environment, JobID, String, TypeSerializer<K>, int, KeyGroupRange, TaskKvStateRegistry) - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
 
createKeyedStateBackend(Environment, JobID, String, TypeSerializer<K>, int, KeyGroupRange, TaskKvStateRegistry) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
 
createKeyedStateBackend(Environment, JobID, String, TypeSerializer<K>, int, KeyGroupRange, TaskKvStateRegistry) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
 
createKeyedStateBackend(Environment, JobID, String, TypeSerializer<K>, int, KeyGroupRange, TaskKvStateRegistry) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
 
createKeyedStateBackend(Environment, JobID, String, TypeSerializer<K>, int, KeyGroupRange, TaskKvStateRegistry) - Method in interface org.apache.flink.runtime.state.StateBackend
Creates a new AbstractKeyedStateBackend that is responsible for holding keyed state and checkpointing it.
createKeyedStateBackend(TypeSerializer<K>, int, KeyGroupRange) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
createKeyGroupedIterator(MutableObjectIterator<T>, TypeSerializer<T>, TypeComparator<T>) - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
createKeyGroupedIterator(MutableObjectIterator<T>, TypeSerializer<T>, TypeComparator<T>) - Method in class org.apache.flink.runtime.operators.sort.NonReusingMergeInnerJoinIterator
 
createKeyGroupedIterator(MutableObjectIterator<T>, TypeSerializer<T>, TypeComparator<T>) - Method in class org.apache.flink.runtime.operators.sort.NonReusingMergeOuterJoinIterator
 
createKeyGroupedIterator(MutableObjectIterator<T>, TypeSerializer<T>, TypeComparator<T>) - Method in class org.apache.flink.runtime.operators.sort.ReusingMergeInnerJoinIterator
 
createKeyGroupedIterator(MutableObjectIterator<T>, TypeSerializer<T>, TypeComparator<T>) - Method in class org.apache.flink.runtime.operators.sort.ReusingMergeOuterJoinIterator
 
createKeyGroupPartitions(int, int) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
Groups the available set of key groups into key group partitions.
createKvStateTaskRegistry(JobID, JobVertexID) - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
createLaunchCoordinator() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
 
createLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
 
createLeaderElectionService(CuratorFramework, Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
Creates a ZooKeeperLeaderElectionService instance.
createLeaderElectionService(CuratorFramework, Configuration, String) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
Creates a ZooKeeperLeaderElectionService instance.
createLeaderRetrievalService() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
 
createLeaderRetrievalService() - Method in class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
 
createLeaderRetrievalService(Configuration) - Static method in class org.apache.flink.runtime.util.StandaloneUtils
Creates a StandaloneLeaderRetrievalService from the given configuration.
createLeaderRetrievalService(Configuration, boolean, String) - Static method in class org.apache.flink.runtime.util.StandaloneUtils
Creates a StandaloneLeaderRetrievalService form the given configuration and the JobManager name.
createLeaderRetrievalService(CuratorFramework, Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
createLeaderRetrievalService(CuratorFramework, Configuration, String) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
createListState(ListStateDescriptor<T>) - Method in interface org.apache.flink.api.common.state.StateBinder
Creates and returns a new ListState.
createListState(TypeSerializer<N>, ListStateDescriptor<T>) - Method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
 
createListState(TypeSerializer<N>, ListStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
Creates and returns a new ListState.
createListState(TypeSerializer<N>, ListStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
createLocal() - Static method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
 
createLocalActorSystem(Configuration) - Method in class org.apache.flink.runtime.akka.AkkaUtils$
Creates a local actor system without remoting.
createLocalActorSystem(Configuration) - Static method in class org.apache.flink.runtime.akka.AkkaUtils
Creates a local actor system without remoting.
createLocalCluster() - Method in class org.apache.flink.storm.api.FlinkLocalCluster.DefaultLocalClusterFactory
 
createLocalCluster() - Method in interface org.apache.flink.storm.api.FlinkLocalCluster.LocalClusterFactory
Creates a local Flink cluster.
createLocalEnvironment() - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a LocalEnvironment.
createLocalEnvironment(int) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a LocalEnvironment.
createLocalEnvironment(Configuration) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a LocalEnvironment.
createLocalEnvironment(int) - Method in class org.apache.flink.api.scala.ExecutionEnvironment$
Creates a local execution environment.
createLocalEnvironment(Configuration) - Method in class org.apache.flink.api.scala.ExecutionEnvironment$
Creates a local execution environment.
createLocalEnvironment(int) - Static method in class org.apache.flink.api.scala.ExecutionEnvironment
Creates a local execution environment.
createLocalEnvironment(Configuration) - Static method in class org.apache.flink.api.scala.ExecutionEnvironment
Creates a local execution environment.
createLocalEnvironment() - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
createLocalEnvironment(int) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
createLocalEnvironment(int, Configuration) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
createLocalEnvironment(int) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment$
Creates a local execution environment.
createLocalEnvironment(int) - Static method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Creates a local execution environment.
createLocalEnvironmentWithWebUI(Configuration) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a LocalEnvironment for local program execution that also starts the web monitoring UI.
createLocalEnvironmentWithWebUI(Configuration) - Method in class org.apache.flink.api.scala.ExecutionEnvironment$
Creates a ExecutionEnvironment for local program execution that also starts the web monitoring UI.
createLocalEnvironmentWithWebUI(Configuration) - Static method in class org.apache.flink.api.scala.ExecutionEnvironment
Creates a ExecutionEnvironment for local program execution that also starts the web monitoring UI.
createLocalEnvironmentWithWebUI(Configuration) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a LocalStreamEnvironment for local program execution that also starts the web monitoring UI.
createLocalEnvironmentWithWebUI(Configuration) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment$
Creates a StreamExecutionEnvironment for local program execution that also starts the web monitoring UI.
createLocalEnvironmentWithWebUI(Configuration) - Static method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Creates a StreamExecutionEnvironment for local program execution that also starts the web monitoring UI.
createLocalExecutor(Configuration) - Static method in class org.apache.flink.api.common.PlanExecutor
Creates an executor that runs the plan locally in a multi-threaded environment.
createLogicalFunctionCall(TableEnvironment, String) - Method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils$
Creates a LogicalTableFunctionCall by parsing a String expression.
createLogicalFunctionCall(TableEnvironment, String) - Static method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils
Creates a LogicalTableFunctionCall by parsing a String expression.
createMapState(MapStateDescriptor<MK, MV>) - Method in interface org.apache.flink.api.common.state.StateBinder
Creates and returns a new MapState.
createMapState(TypeSerializer<N>, MapStateDescriptor<UK, UV>) - Method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
 
createMapState(TypeSerializer<N>, MapStateDescriptor<UK, UV>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
Creates and returns a new MapState.
createMapState(TypeSerializer<N>, MapStateDescriptor<UK, UV>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
createMapType(RelDataType, RelDataType) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
createMasterTriggerRestoreHook() - Method in interface org.apache.flink.streaming.api.checkpoint.WithMasterCheckpointHook
Creates the hook that should be called by the checkpoint coordinator.
createMesosConfig(Configuration, String) - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosApplicationMasterRunner
Loads and validates the ResourceManager Mesos configuration from the given Flink configuration.
createMesosServices(Configuration) - Static method in class org.apache.flink.mesos.runtime.clusterframework.services.MesosServicesUtils
Creates a MesosServices instance depending on the high availability settings.
createMesosWorkerStore(Configuration, Executor) - Method in interface org.apache.flink.mesos.runtime.clusterframework.services.MesosServices
Creates a MesosWorkerStore which is used to persist mesos worker in high availability mode.
createMesosWorkerStore(Configuration, Executor) - Method in class org.apache.flink.mesos.runtime.clusterframework.services.StandaloneMesosServices
 
createMesosWorkerStore(Configuration, Executor) - Method in class org.apache.flink.mesos.runtime.clusterframework.services.ZooKeeperMesosServices
 
createMetricRegistry(Configuration) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
Factory method to create the metric registry for the mini cluster
createMultisetType(RelDataType, long) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
createNewOrderingUpToIndex(int) - Method in class org.apache.flink.api.common.operators.Ordering
Creates a new ordering the represents an ordering on a prefix of the fields.
createNFA() - Method in interface org.apache.flink.cep.nfa.compiler.NFACompiler.NFAFactory
 
createNiFiDataPacket(T, RuntimeContext) - Method in interface org.apache.flink.streaming.connectors.nifi.NiFiDataPacketBuilder
 
createObjectForClassNotInClassPath(ClassLoader) - Static method in class org.apache.flink.core.testutils.CommonTestUtils
Creates a new class that is not part of the classpath that the current JVM uses, and instantiates it.
createOperandTypeChecker(AggregateFunction<?, ?>) - Method in class org.apache.flink.table.functions.utils.AggSqlFunction$
 
createOperandTypeChecker(AggregateFunction<?, ?>) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
createOperandTypeChecker(String, ScalarFunction) - Method in class org.apache.flink.table.functions.utils.ScalarSqlFunction$
 
createOperandTypeChecker(String, ScalarFunction) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
createOperandTypeInference(AggregateFunction<?, ?>, FlinkTypeFactory) - Method in class org.apache.flink.table.functions.utils.AggSqlFunction$
 
createOperandTypeInference(AggregateFunction<?, ?>, FlinkTypeFactory) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
createOperandTypeInference(ScalarFunction, FlinkTypeFactory) - Method in class org.apache.flink.table.functions.utils.ScalarSqlFunction$
 
createOperandTypeInference(ScalarFunction, FlinkTypeFactory) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
createOperatorStateBackend(Environment, String) - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
 
createOperatorStateBackend(Environment, String) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
 
createOperatorStateBackend(Environment, String) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
 
createOperatorStateBackend(Environment, String) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
 
createOperatorStateBackend(Environment, String) - Method in interface org.apache.flink.runtime.state.StateBackend
Creates a new OperatorStateBackend that can be used for storing operator state.
createOperatorStateBackend(StreamOperator<?>, Collection<OperatorStateHandle>) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
createOrderedFromSet(FieldSet) - Static method in class org.apache.flink.optimizer.util.Utils
 
createOrdering(FieldList, boolean[]) - Static method in class org.apache.flink.optimizer.util.Utils
 
createOrdering(FieldList) - Static method in class org.apache.flink.optimizer.util.Utils
 
createOrReuseInstance(Object[], T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
createOrReuseInstance(Object[], T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
createOrReuseInstance(Object[], T) - Method in class org.apache.flink.api.scala.typeutils.CaseClassSerializer
 
createOutBlockInformation(DataSet<Tuple2<Object, ALS.Rating>>, DataSet<Tuple2<Object, long[]>>, int, ALS.BlockIDGenerator) - Method in class org.apache.flink.ml.recommendation.ALS$
Creates the outgoing block information
createOutBlockInformation(DataSet<Tuple2<Object, ALS.Rating>>, DataSet<Tuple2<Object, long[]>>, int, ALS.BlockIDGenerator) - Static method in class org.apache.flink.ml.recommendation.ALS
Creates the outgoing block information
createOutputRow() - Method in class org.apache.flink.table.runtime.aggregate.GeneratedAggregations
Creates an output row object with the correct arity.
createPairComparator(FieldList, FieldList, boolean[], T, T) - Method in class org.apache.flink.optimizer.postpass.GenericFlatTypePostPass
 
createPanes(KeySelector<IN, KEY>, Function) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
Deprecated.
 
createPanes(KeySelector<IN, KEY>, Function) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingProcessingTimeWindowOperator
Deprecated.
 
createPanes(KeySelector<IN, KEY>, Function) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AggregatingProcessingTimeWindowOperator
Deprecated.
 
createPartitionRequestClient(ConnectionID) - Method in interface org.apache.flink.runtime.io.network.ConnectionManager
Creates a PartitionRequestClient instance for the given ConnectionID.
createPartitionRequestClient(ConnectionID) - Method in class org.apache.flink.runtime.io.network.LocalConnectionManager
 
createPartitionRequestClient(ConnectionID) - Method in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager
 
createPartitions(int, int) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
createPatternStream(DataStream<T>, Pattern<T, ?>) - Static method in class org.apache.flink.cep.operator.CEPOperatorUtils
Creates a data stream containing the fully matching event patterns of the NFA computation.
createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.dag.PartitionNode.PartitionDescriptor
 
createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.dag.SortPartitionNode.SortPartitionDescriptor
 
createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.AbstractJoinDescriptor
 
createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.AllGroupCombineProperties
 
createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.AllGroupReduceProperties
 
createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.AllGroupWithPartialPreGroupProperties
 
createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.AllReduceProperties
 
createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.BinaryUnionOpDescriptor
 
createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.CartesianProductDescriptor
 
createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.CoGroupDescriptor
 
createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.CoGroupRawDescriptor
 
createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.FilterDescriptor
 
createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.FlatMapDescriptor
 
createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.GroupCombineProperties
 
createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.GroupReduceProperties
 
createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.GroupReduceWithCombineProperties
 
createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.MapDescriptor
 
createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.MapPartitionDescriptor
 
createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.NoOpDescriptor
 
createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
 
createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorSingle
Returns a list of global properties that are required by this operator descriptor.
createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.PartialGroupProperties
 
createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.ReduceProperties
 
createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.SolutionSetDeltaOperator
 
createPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.UtilSinkJoinOpDescriptor
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.dag.PartitionNode.PartitionDescriptor
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.dag.SortPartitionNode.SortPartitionDescriptor
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.AbstractSortMergeJoinDescriptor
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.AllGroupCombineProperties
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.AllGroupReduceProperties
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.AllGroupWithPartialPreGroupProperties
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.AllReduceProperties
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.BinaryUnionOpDescriptor
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.CartesianProductDescriptor
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.CoGroupDescriptor
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.CoGroupRawDescriptor
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.CoGroupWithSolutionSetFirstDescriptor
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.CoGroupWithSolutionSetSecondDescriptor
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.FilterDescriptor
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.FlatMapDescriptor
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.GroupCombineProperties
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.GroupReduceProperties
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.GroupReduceWithCombineProperties
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.HashFullOuterJoinBuildFirstDescriptor
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.HashFullOuterJoinBuildSecondDescriptor
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.HashJoinBuildFirstProperties
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.HashJoinBuildSecondProperties
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.HashLeftOuterJoinBuildFirstDescriptor
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.HashLeftOuterJoinBuildSecondDescriptor
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.HashRightOuterJoinBuildFirstDescriptor
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.HashRightOuterJoinBuildSecondDescriptor
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.MapDescriptor
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.MapPartitionDescriptor
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.NoOpDescriptor
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorSingle
Returns a list of local properties that are required by this operator descriptor.
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.PartialGroupProperties
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.ReduceProperties
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.SolutionSetDeltaOperator
 
createPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.UtilSinkJoinOpDescriptor
 
createPreOptimizedPlan(Plan) - Static method in class org.apache.flink.optimizer.Optimizer
This function performs only the first step to the compilation process - the creation of the optimizer representation of the plan.
createProber(TypeComparator<PT>, TypePairComparator<PT, BT>) - Method in class org.apache.flink.api.common.operators.util.JoinHashMap
 
createProctimeIndicatorType() - Method in class org.apache.flink.table.calcite.FlinkTypeFactory
Creates a indicator type for processing-time, but with similar properties as SQL timestamp.
createProgramPlan() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates the program's Plan.
createProgramPlan(String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates the program's Plan.
createProgramPlan(String, boolean) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates the program's Plan.
createProgramPlan(String) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Creates the program's Plan.
createProjectionPropertiesDual(int[], boolean[], TypeInformation<?>, TypeInformation<?>) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
 
createProjectionPropertiesSingle(int[], CompositeType<?>) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
 
createPropertiesFile(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
Create a properties file with all the known parameters (call after the last get*() call).
createPropertiesFile(String, boolean) - Method in class org.apache.flink.api.java.utils.ParameterTool
Create a properties file with all the known parameters (call after the last get*() call).
createQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
Creates the metric query service scope for this group.
createQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.GenericMetricGroup
 
createQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
 
createQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.JobMetricGroup
 
createQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.OperatorMetricGroup
 
createQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
 
createQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
createRandomName(String) - Static method in class org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils
Creates a random name of the form prefix_X, where X is an increasing number.
createReadView(BufferAvailabilityListener) - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
createReconciliationCoordinator() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
 
createReducingState(ReducingStateDescriptor<T>) - Method in interface org.apache.flink.api.common.state.StateBinder
Creates and returns a new ReducingState.
createReducingState(TypeSerializer<N>, ReducingStateDescriptor<T>) - Method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
 
createReducingState(TypeSerializer<N>, ReducingStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
Creates and returns a new ReducingState.
createReducingState(TypeSerializer<N>, ReducingStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
createRemote(ConnectionID) - Static method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
 
createRemoteEnvironment(String, int, String...) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
createRemoteEnvironment(String, int, Configuration, String...) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
createRemoteEnvironment(String, int, int, String...) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
createRemoteEnvironment(String, int, Seq<String>) - Method in class org.apache.flink.api.scala.ExecutionEnvironment$
Creates a remote execution environment.
createRemoteEnvironment(String, int, int, Seq<String>) - Method in class org.apache.flink.api.scala.ExecutionEnvironment$
Creates a remote execution environment.
createRemoteEnvironment(String, int, Configuration, Seq<String>) - Method in class org.apache.flink.api.scala.ExecutionEnvironment$
Creates a remote execution environment.
createRemoteEnvironment(String, int, Seq<String>) - Static method in class org.apache.flink.api.scala.ExecutionEnvironment
Creates a remote execution environment.
createRemoteEnvironment(String, int, int, Seq<String>) - Static method in class org.apache.flink.api.scala.ExecutionEnvironment
Creates a remote execution environment.
createRemoteEnvironment(String, int, Configuration, Seq<String>) - Static method in class org.apache.flink.api.scala.ExecutionEnvironment
Creates a remote execution environment.
createRemoteEnvironment(String, int, String...) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
createRemoteEnvironment(String, int, int, String...) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
createRemoteEnvironment(String, int, Configuration, String...) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
createRemoteEnvironment(String, int, Seq<String>) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment$
Creates a remote execution environment.
createRemoteEnvironment(String, int, int, Seq<String>) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment$
Creates a remote execution environment.
createRemoteEnvironment(String, int, Seq<String>) - Static method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Creates a remote execution environment.
createRemoteEnvironment(String, int, int, Seq<String>) - Static method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Creates a remote execution environment.
createRemoteExecutor(String, int, Configuration, List<URL>, List<URL>) - Static method in class org.apache.flink.api.common.PlanExecutor
Creates an executor that runs the plan on a remote environment.
createResource() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraCommitter
Generates the necessary tables to store information.
createResource() - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
Creates/opens/connects to the resource that is used to store information.
createRestartStrategy() - Method in class org.apache.flink.runtime.executiongraph.restart.FailureRateRestartStrategy.FailureRateRestartStrategyFactory
 
createRestartStrategy() - Method in class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy.FixedDelayRestartStrategyFactory
 
createRestartStrategy() - Method in class org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy.NoRestartStrategyFactory
 
createRestartStrategy() - Method in class org.apache.flink.runtime.executiongraph.restart.RestartStrategyFactory
Factory method to create a restart strategy
createRestartStrategy(RestartStrategies.RestartStrategyConfiguration) - Static method in class org.apache.flink.runtime.executiongraph.restart.RestartStrategyFactory
createRestartStrategyFactory(Configuration) - Static method in class org.apache.flink.runtime.executiongraph.restart.RestartStrategyFactory
Creates a RestartStrategy instance from the given Configuration.
createResult() - Method in interface org.apache.flink.api.java.operators.CustomUnaryOperation
 
createResult() - Method in class org.apache.flink.graph.gsa.GatherSumApplyIteration
Computes the results of the gather-sum-apply iteration
createResult() - Method in class org.apache.flink.graph.pregel.VertexCentricIteration
Creates the operator that represents this vertex-centric graph computation.
createResult() - Method in class org.apache.flink.graph.spargel.ScatterGatherIteration
Creates the operator that represents this scatter-gather graph computation.
createReturnTypeInference(TypeInformation<?>, FlinkTypeFactory) - Method in class org.apache.flink.table.functions.utils.AggSqlFunction$
 
createReturnTypeInference(TypeInformation<?>, FlinkTypeFactory) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
createReturnTypeInference(String, ScalarFunction, FlinkTypeFactory) - Method in class org.apache.flink.table.functions.utils.ScalarSqlFunction$
 
createReturnTypeInference(String, ScalarFunction, FlinkTypeFactory) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
createRowtimeIndicatorType() - Method in class org.apache.flink.table.calcite.FlinkTypeFactory
Creates a indicator type for event-time, but with similar properties as SQL timestamp.
createRpcService(Configuration, Time, boolean, String) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
Factory method to instantiate the RPC service.
createRpcService(String, int, Configuration) - Static method in class org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils
Utility method to create RPC service from configuration and hostname, port.
createRpcService(Configuration, HighAvailabilityServices) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
Create a RPC service for the task manager.
createRpcService(Configuration, String, String) - Method in class org.apache.flink.yarn.YarnFlinkApplicationMasterRunner
 
createRuntimeContext(MetricGroup) - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
createRuntimeContext(MetricGroup) - Method in class org.apache.flink.runtime.operators.BatchTask
 
createRuntimeContext() - Method in class org.apache.flink.runtime.operators.DataSinkTask
 
createRuntimeContext() - Method in class org.apache.flink.runtime.operators.DataSourceTask
 
createSavepointDirectory(String, JobID) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointStore
Creates a savepoint directory.
createSavepointStreamFactory(JobID, String, String) - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
 
createSavepointStreamFactory(JobID, String, String) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
 
createSavepointStreamFactory(JobID, String, String) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
 
createSavepointStreamFactory(JobID, String, String) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
 
createSavepointStreamFactory(JobID, String, String) - Method in interface org.apache.flink.runtime.state.StateBackend
Creates a CheckpointStreamFactory that can be used to create streams that should end up in a savepoint.
createSavepointStreamFactory(StreamOperator<?>, String) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
createScalarSqlFunction(String, ScalarFunction, FlinkTypeFactory) - Method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils$
Create SqlFunction for a ScalarFunction
createScalarSqlFunction(String, ScalarFunction, FlinkTypeFactory) - Static method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils
Create SqlFunction for a ScalarFunction
createSerializationSchema(String[]) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaJsonTableSink
 
createSerializationSchema(String[]) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSink
Create serialization schema for converting table rows into bytes.
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
Creates a serializer for the type.
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.ListTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.scala.typeutils.EitherTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.scala.typeutils.EnumValueTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.scala.typeutils.OptionTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.scala.typeutils.ScalaNothingTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.scala.typeutils.TraversableTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.scala.typeutils.TryTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.api.scala.typeutils.UnitTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
 
createSerializer(T) - Method in class org.apache.flink.optimizer.postpass.GenericFlatTypePostPass
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.table.runtime.types.CRowTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.table.typeutils.InternalTypeInfo
 
createSerializer(ExecutionConfig) - Static method in class org.apache.flink.table.typeutils.RowIntervalTypeInfo
 
createSerializer(ExecutionConfig) - Static method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
 
createSerializer(ExecutionConfig) - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
 
createSerializerInstance(Class<T>, TypeSerializer<?>[]) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
createSerializerInstance(Class<T>, TypeSerializer<?>[]) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
createSerializerInstance(Class<T>, TypeSerializer<?>[]) - Method in class org.apache.flink.api.scala.typeutils.CaseClassSerializer
 
createServerSSLContext() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
createSharedCount(String, int) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperUtilityFactory
Creates a ZooKeeperSharedCount to store a shared count between multiple instances.
createSharedStateRegistryKeyFromFileName(StateHandleID) - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
Create a unique key to register one of our shared state handles.
createSharedValue(String, byte[]) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperUtilityFactory
Creates a ZooKeeperSharedValue to store a shared value between multiple instances.
CreateSimilarUserEdges() - Constructor for class org.apache.flink.graph.examples.MusicProfiles.CreateSimilarUserEdges
 
createSlotReport(ResourceID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
 
createSnapshot() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsTracker
Creates a new snapshot of the available stats.
createSnapshot() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
createSnapshot() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
Creates a snapshot of this CopyOnWriteStateTable, to be written in checkpointing.
createSnapshot() - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
createSocket(int) - Method in interface org.apache.flink.util.NetUtils.SocketFactory
 
createSocketFromPorts(Iterator<Integer>, NetUtils.SocketFactory) - Static method in class org.apache.flink.util.NetUtils
Tries to allocate a socket from the given sets of ports.
createSolutionSetUpdateOutputCollector(Collector<OT>) - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
Creates a new solution set update output collector.
createSqlIntervalType(SqlIntervalQualifier) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
createSqlType(SqlTypeName, int) - Method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
createSSLClientContext(Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
Creates the SSL Context for the client if SSL is configured
createSSLServerContext(Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
Creates the SSL Context for the server if SSL is configured
createStartState(NFA<T>, State<T>) - Static method in class org.apache.flink.cep.nfa.ComputationState
 
createStartState(NFA<T>, State<T>, DeweyNumber) - Static method in class org.apache.flink.cep.nfa.ComputationState
 
createState(NFA<T>, State<T>, State<T>, T, int, long, DeweyNumber, long) - Static method in class org.apache.flink.cep.nfa.ComputationState
 
createStatistics(List<FileStatus>, FileInputFormat.FileBaseStatistics) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
Fill in the statistics.
createStreamFactory(JobID, String) - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
 
createStreamFactory(JobID, String) - Method in class org.apache.flink.runtime.state.AbstractStateBackend
 
createStreamFactory(JobID, String) - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
 
createStreamFactory(JobID, String) - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
 
createStreamFactory(JobID, String) - Method in interface org.apache.flink.runtime.state.StateBackend
Creates a CheckpointStreamFactory that can be used to create streams that should end up in a checkpoint.
createStructType(List<RelDataType>, List<String>) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
createStructType(StructKind, List<RelDataType>, List<String>) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
createStructType(RelDataTypeFactory.FieldInfo) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
createStructType(List<? extends Map.Entry<String, RelDataType>>) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
createStructType(Class<?>) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
createSubCatalog(String, ExternalCatalog, boolean) - Method in interface org.apache.flink.table.catalog.CrudExternalCatalog
Adds a subcatalog to this catalog.
createSubCatalog(String, ExternalCatalog, boolean) - Method in class org.apache.flink.table.catalog.InMemoryExternalCatalog
 
createSubmittedJobGraphs(CuratorFramework, Configuration, Executor) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
createSubpartitionView(int, BufferAvailabilityListener) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
Returns the requested subpartition.
createSubpartitionView(ResultPartitionID, int, BufferAvailabilityListener) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
 
createSubpartitionView(ResultPartitionID, int, BufferAvailabilityListener) - Method in interface org.apache.flink.runtime.io.network.partition.ResultPartitionProvider
Returns the requested intermediate result partition input view.
createSubtasksAccumulatorsJson(AccessExecutionJobVertex) - Static method in class org.apache.flink.runtime.webmonitor.handlers.SubtasksAllAccumulatorsHandler
 
createSubtaskTimesJson(AccessExecutionJobVertex) - Static method in class org.apache.flink.runtime.webmonitor.handlers.SubtasksTimesHandler
 
createSyntheticType(List<Type>) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
createTable(String, ExternalCatalogTable, boolean) - Method in interface org.apache.flink.table.catalog.CrudExternalCatalog
Adds a table to this catalog.
createTable(String, ExternalCatalogTable, boolean) - Method in class org.apache.flink.table.catalog.InMemoryExternalCatalog
 
createTableSqlFunctions(String, TableFunction<?>, TypeInformation<?>, FlinkTypeFactory) - Method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils$
Create SqlFunctions for a TableFunction's every eval method
createTableSqlFunctions(String, TableFunction<?>, TypeInformation<?>, FlinkTypeFactory) - Static method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils
Create SqlFunctions for a TableFunction's every eval method
createTaskRegistry(JobID, JobVertexID) - Method in class org.apache.flink.runtime.query.KvStateRegistry
Creates a TaskKvStateRegistry facade for the Task identified by the given JobID and JobVertexID instance.
createTaskRouter() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
 
createTempFile(String) - Static method in class org.apache.flink.core.testutils.CommonTestUtils
Creates a temporary file that contains the given string.
createTempFile(String, String) - Method in class org.apache.flink.test.util.AbstractTestBase
 
createTime() - Method in class org.apache.flink.table.catalog.ExternalCatalogTable
 
createTimeoutPatternStream(DataStream<T>, Pattern<T, ?>) - Static method in class org.apache.flink.cep.operator.CEPOperatorUtils
Creates a data stream containing fully matching event patterns or partially matching event patterns which have timed out.
createTmpFile(String, DistributedCache.DistributedCacheEntry, JobID) - Method in class org.apache.flink.runtime.filecache.FileCache
If the file doesn't exists locally, it will copy the file to the temp directory.
createTopology(TopologyBuilder) - Static method in class org.apache.flink.storm.api.FlinkTopology
Creates a Flink program that uses the specified spouts and bolts.
createTuple(int) - Static method in class org.apache.flink.python.api.streaming.data.PythonReceiver
 
createType(Type) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
createTypeComparator(ExecutionConfig) - Method in interface org.apache.flink.api.common.typeutils.CompositeType.TypeComparatorBuilder
 
createTypeComparatorBuilder() - Method in class org.apache.flink.api.common.typeutils.CompositeType
 
createTypeComparatorBuilder() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
createTypeComparatorBuilder() - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
 
createTypeComparatorBuilder() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
createTypeComparatorBuilder() - Method in class org.apache.flink.api.scala.typeutils.CaseClassTypeInfo
 
createTypeComparatorBuilder() - Method in class org.apache.flink.table.runtime.types.CRowTypeInfo
 
createTypeFromTypeInfo(TypeInformation<?>, boolean) - Method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
createTypeInfo(Type, Map<String, TypeInformation<?>>) - Method in class org.apache.flink.api.common.typeinfo.TypeInfoFactory
Creates type information for the type the factory is targeted for.
createTypeInfo(Type, Map<String, TypeInformation<?>>) - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfoFactory
 
createTypeInfo(Class<T>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
createTypeInfo(Type) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
createTypeInfo(Object, Class<?>, Class<?>, int) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
Creates a TypeInformation from the given parameters.
createTypeInfo(Class<?>, Class<?>, int, TypeInformation<IN1>, TypeInformation<IN2>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
createTypeInfo(Context, TypeTags.WeakTypeTag<T>) - Method in class org.apache.flink.api.scala.typeutils.TypeUtils$
 
createTypeInfo(Context, TypeTags.WeakTypeTag<T>) - Static method in class org.apache.flink.api.scala.typeutils.TypeUtils
 
createTypeInfo(Type, Map<String, TypeInformation<?>>) - Method in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfoFactory
 
createTypeWithCharsetAndCollation(RelDataType, Charset, SqlCollation) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
createTypeWithKey(Keys.SelectorFunctionKeys<T, K>) - Static method in class org.apache.flink.api.java.operators.KeyFunctions
 
createTypeWithKey(Keys.SelectorFunctionKeys<T, K1>, Keys.SelectorFunctionKeys<T, K2>) - Static method in class org.apache.flink.api.java.operators.KeyFunctions
 
createTypeWithNullability(RelDataType, boolean) - Method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
createUnboundedAndCurrentRowOverWindow(StreamQueryConfig, CodeGenerator, DataStream<CRow>, boolean, boolean) - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamOverAggregate
 
createUnboundedOverProcessFunction(CodeGenerator, Seq<Pair<AggregateCall, String>>, RelDataType, TypeInformation<Row>, Seq<TypeInformation<?>>, StreamQueryConfig, boolean, boolean, boolean) - Method in class org.apache.flink.table.runtime.aggregate.AggregateUtil$
Create an ProcessFunction for unbounded OVER window to evaluate final aggregate value.
createUnboundedOverProcessFunction(CodeGenerator, Seq<Pair<AggregateCall, String>>, RelDataType, TypeInformation<Row>, Seq<TypeInformation<?>>, StreamQueryConfig, boolean, boolean, boolean) - Static method in class org.apache.flink.table.runtime.aggregate.AggregateUtil
Create an ProcessFunction for unbounded OVER window to evaluate final aggregate value.
createUnionCascade(List<? extends Operator<T>>) - Static method in class org.apache.flink.api.common.operators.Operator
Takes a list of operators and creates a cascade of unions of this inputs, if needed.
createUnionCascade(Operator<T>...) - Static method in class org.apache.flink.api.common.operators.Operator
Takes a list of operators and creates a cascade of unions of this inputs, if needed.
createUnionCascade(Operator<T>, Operator<T>...) - Static method in class org.apache.flink.api.common.operators.Operator
Takes a single Operator and a list of operators and creates a cascade of unions of this inputs, if needed.
createUniqueAttributeName() - Method in class org.apache.flink.table.api.TableEnvironment
Returns a unique temporary attribute name.
createUniqueTableName() - Method in class org.apache.flink.table.api.BatchTableEnvironment
Returns a unique table name according to the internal naming pattern.
createUniqueTableName() - Method in class org.apache.flink.table.api.StreamTableEnvironment
Returns a unique table name according to the internal naming pattern.
createUnknown() - Static method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
 
createUpdateTaskMultiplePartitionInfos(ExecutionAttemptID, List<IntermediateDataSetID>, List<InputChannelDeploymentDescriptor>) - Method in class org.apache.flink.runtime.messages.TaskMessages$
 
createUpdateTaskMultiplePartitionInfos(ExecutionAttemptID, List<IntermediateDataSetID>, List<InputChannelDeploymentDescriptor>) - Static method in class org.apache.flink.runtime.messages.TaskMessages
 
createUsersPerBlock(DataSet<Tuple2<Object, ALS.Rating>>) - Method in class org.apache.flink.ml.recommendation.ALS$
Calculates the userIDs in ascending order of each user block
createUsersPerBlock(DataSet<Tuple2<Object, ALS.Rating>>) - Static method in class org.apache.flink.ml.recommendation.ALS
Calculates the userIDs in ascending order of each user block
createValue() - Method in class org.apache.flink.types.parser.BigDecParser
 
createValue() - Method in class org.apache.flink.types.parser.BigIntParser
 
createValue() - Method in class org.apache.flink.types.parser.BooleanParser
 
createValue() - Method in class org.apache.flink.types.parser.BooleanValueParser
 
createValue() - Method in class org.apache.flink.types.parser.ByteParser
 
createValue() - Method in class org.apache.flink.types.parser.ByteValueParser
 
createValue() - Method in class org.apache.flink.types.parser.DoubleParser
 
createValue() - Method in class org.apache.flink.types.parser.DoubleValueParser
 
createValue() - Method in class org.apache.flink.types.parser.FieldParser
Returns an instance of the parsed value type.
createValue() - Method in class org.apache.flink.types.parser.FloatParser
 
createValue() - Method in class org.apache.flink.types.parser.FloatValueParser
 
createValue() - Method in class org.apache.flink.types.parser.IntParser
 
createValue() - Method in class org.apache.flink.types.parser.IntValueParser
 
createValue() - Method in class org.apache.flink.types.parser.LongParser
 
createValue() - Method in class org.apache.flink.types.parser.LongValueParser
 
createValue() - Method in class org.apache.flink.types.parser.ShortParser
 
createValue() - Method in class org.apache.flink.types.parser.ShortValueParser
 
createValue() - Method in class org.apache.flink.types.parser.SqlDateParser
 
createValue() - Method in class org.apache.flink.types.parser.SqlTimeParser
 
createValue() - Method in class org.apache.flink.types.parser.SqlTimestampParser
 
createValue() - Method in class org.apache.flink.types.parser.StringParser
 
createValue() - Method in class org.apache.flink.types.parser.StringValueParser
 
createValueArray(Class<? extends Value>) - Static method in class org.apache.flink.graph.types.valuearray.ValueArrayFactory
Produce a ValueArray for the given Value type.
createValueArray(Class<? extends Value>, int) - Static method in class org.apache.flink.graph.types.valuearray.ValueArrayFactory
Produce a ValueArray for the given Value type with the given bounded size.
createValueState(ValueStateDescriptor<T>) - Method in interface org.apache.flink.api.common.state.StateBinder
Creates and returns a new ValueState.
createValueState(TypeSerializer<N>, ValueStateDescriptor<T>) - Method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
 
createValueState(TypeSerializer<N>, ValueStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
Creates and returns a new ValueState.
createValueState(TypeSerializer<N>, ValueStateDescriptor<V>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
createVertexAccumulatorsJson(AccessExecutionJobVertex) - Static method in class org.apache.flink.runtime.webmonitor.handlers.JobVertexAccumulatorsHandler
 
createVertexDetailsByTaskManagerJson(AccessExecutionJobVertex, String, MetricFetcher) - Static method in class org.apache.flink.runtime.webmonitor.handlers.JobVertexTaskManagersHandler
 
createVertexDetailsJson(AccessExecutionJobVertex, String, MetricFetcher) - Static method in class org.apache.flink.runtime.webmonitor.handlers.JobVertexDetailsHandler
 
createWorksetUpdateOutputCollector(Collector<OT>) - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
createWorksetUpdateOutputCollector() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
createYarnClusterClient(AbstractYarnClusterDescriptor, YarnClient, ApplicationReport, Configuration, boolean) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
Creates a YarnClusterClient; may be overriden in tests
createZooKeeperStateHandleStore(String, RetrievableStateStorageHelper<T>, Executor) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperUtilityFactory
Creates a ZooKeeperStateHandleStore instance with the provided arguments.
credential() - Method in class org.apache.flink.mesos.util.MesosConfiguration
The credential to authenticate the framework principal.
credentials - Variable in class org.apache.flink.api.java.hadoop.common.HadoopInputFormatCommonBase
 
credentials - Variable in class org.apache.flink.api.java.hadoop.common.HadoopOutputFormatCommonBase
 
cross(IN1, IN2) - Method in interface org.apache.flink.api.common.functions.CrossFunction
Cross UDF method.
cross(IN1, IN2) - Method in class org.apache.flink.api.common.functions.RichCrossFunction
 
cross(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
Initiates a Cross transformation.
A Cross transformation combines the elements of two DataSets into one DataSet.
cross(T1, T2) - Method in class org.apache.flink.api.java.operators.CrossOperator.DefaultCrossFunction
 
cross(T1, T2) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCrossFunction
 
cross(DataSet<O>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
cross(DataSet<O>) - Method in class org.apache.flink.api.scala.DataSet
Creates a new DataSet by forming the cartesian product of this DataSet and the other DataSet.
CrossBlockOuterFirstDescriptor - Class in org.apache.flink.optimizer.operators
 
CrossBlockOuterFirstDescriptor() - Constructor for class org.apache.flink.optimizer.operators.CrossBlockOuterFirstDescriptor
 
CrossBlockOuterFirstDescriptor(boolean, boolean) - Constructor for class org.apache.flink.optimizer.operators.CrossBlockOuterFirstDescriptor
 
CrossBlockOuterSecondDescriptor - Class in org.apache.flink.optimizer.operators
 
CrossBlockOuterSecondDescriptor() - Constructor for class org.apache.flink.optimizer.operators.CrossBlockOuterSecondDescriptor
 
CrossBlockOuterSecondDescriptor(boolean, boolean) - Constructor for class org.apache.flink.optimizer.operators.CrossBlockOuterSecondDescriptor
 
CrossDataSet<L,R> - Class in org.apache.flink.api.scala
A specific DataSet that results from a cross operation.
CrossDataSet(CrossOperator<L, R, Tuple2<L, R>>, DataSet<L>, DataSet<R>) - Constructor for class org.apache.flink.api.scala.CrossDataSet
 
CrossDataSet$ - Class in org.apache.flink.api.scala
 
CrossDataSet$() - Constructor for class org.apache.flink.api.scala.CrossDataSet$
 
CrossDriver<T1,T2,OT> - Class in org.apache.flink.runtime.operators
Cross task which is executed by a Task Manager.
CrossDriver() - Constructor for class org.apache.flink.runtime.operators.CrossDriver
 
CrossFunction<IN1,IN2,OUT> - Interface in org.apache.flink.api.common.functions
Interface for Cross functions.
crossMatchingGroup(Iterator<T1>, Iterator<T2>, FlatJoinFunction<T1, T2, O>, Collector<O>) - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
CrossNode - Class in org.apache.flink.optimizer.dag
The Optimizer representation of a Cross (Cartesian product) operator.
CrossNode(CrossOperatorBase<?, ?, ?, ?>) - Constructor for class org.apache.flink.optimizer.dag.CrossNode
Creates a new CrossNode for the given operator.
CrossOperator<I1,I2,OUT> - Class in org.apache.flink.api.java.operators
A DataSet that is the result of a Cross transformation.
CrossOperator(DataSet<I1>, DataSet<I2>, CrossFunction<I1, I2, OUT>, TypeInformation<OUT>, CrossOperatorBase.CrossHint, String) - Constructor for class org.apache.flink.api.java.operators.CrossOperator
 
CrossOperator.CrossProjection<I1,I2> - Class in org.apache.flink.api.java.operators
 
CrossOperator.DefaultCross<I1,I2> - Class in org.apache.flink.api.java.operators
A Cross transformation that wraps pairs of crossed elements into Tuple2.
It also represents the DataSet that is the result of a Cross transformation.
CrossOperator.DefaultCrossFunction<T1,T2> - Class in org.apache.flink.api.java.operators
 
CrossOperator.ProjectCross<I1,I2,OUT extends Tuple> - Class in org.apache.flink.api.java.operators
A Cross transformation that projects crossing elements or fields of crossing Tuples into result Tuples.
CrossOperator.ProjectCrossFunction<T1,T2,R extends Tuple> - Class in org.apache.flink.api.java.operators
 
CrossOperatorBase<IN1,IN2,OUT,FT extends CrossFunction<IN1,IN2,OUT>> - Class in org.apache.flink.api.common.operators.base
 
CrossOperatorBase(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.CrossOperatorBase
 
CrossOperatorBase(FT, BinaryOperatorInformation<IN1, IN2, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.CrossOperatorBase
 
CrossOperatorBase(Class<? extends FT>, BinaryOperatorInformation<IN1, IN2, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.CrossOperatorBase
 
CrossOperatorBase.CrossHint - Enum in org.apache.flink.api.common.operators.base
The cross hint tells the system which sizes to expect from the data sets
CrossOperatorBase.CrossWithLarge - Interface in org.apache.flink.api.common.operators.base
Marker interface to declare the second input as the larger one.
CrossOperatorBase.CrossWithSmall - Interface in org.apache.flink.api.common.operators.base
Marker interface to declare the second input as the smaller one.
CrossProjection(DataSet<I1>, DataSet<I2>, int[], int[], CrossOperatorBase.CrossHint) - Constructor for class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
 
CrossStreamOuterFirstDescriptor - Class in org.apache.flink.optimizer.operators
 
CrossStreamOuterFirstDescriptor() - Constructor for class org.apache.flink.optimizer.operators.CrossStreamOuterFirstDescriptor
 
CrossStreamOuterFirstDescriptor(boolean, boolean) - Constructor for class org.apache.flink.optimizer.operators.CrossStreamOuterFirstDescriptor
 
CrossStreamOuterSecondDescriptor - Class in org.apache.flink.optimizer.operators
 
CrossStreamOuterSecondDescriptor() - Constructor for class org.apache.flink.optimizer.operators.CrossStreamOuterSecondDescriptor
 
CrossStreamOuterSecondDescriptor(boolean, boolean) - Constructor for class org.apache.flink.optimizer.operators.CrossStreamOuterSecondDescriptor
 
crossWithHuge(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
Initiates a Cross transformation.
A Cross transformation combines the elements of two DataSets into one DataSet.
crossWithHuge(DataSet<O>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
crossWithHuge(DataSet<O>) - Method in class org.apache.flink.api.scala.DataSet
Special cross operation for explicitly telling the system that the left side is assumed to be a lot smaller than the right side of the cartesian product.
crossWithTiny(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
Initiates a Cross transformation.
A Cross transformation combines the elements of two DataSets into one DataSet.
crossWithTiny(DataSet<O>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
crossWithTiny(DataSet<O>) - Method in class org.apache.flink.api.scala.DataSet
Special cross operation for explicitly telling the system that the right side is assumed to be a lot smaller than the left side of the cartesian product.
CRow - Class in org.apache.flink.table.runtime.types
Wrapper for a Row to add retraction information.
CRow(Row, boolean) - Constructor for class org.apache.flink.table.runtime.types.CRow
 
CRow() - Constructor for class org.apache.flink.table.runtime.types.CRow
 
CRow$ - Class in org.apache.flink.table.runtime.types
 
CRow$() - Constructor for class org.apache.flink.table.runtime.types.CRow$
 
CRowComparator - Class in org.apache.flink.table.runtime.types
 
CRowComparator(TypeComparator<Row>) - Constructor for class org.apache.flink.table.runtime.types.CRowComparator
 
CRowCorrelateProcessRunner - Class in org.apache.flink.table.runtime
A CorrelateProcessRunner with CRow input and CRow output.
CRowCorrelateProcessRunner(String, String, String, String, TypeInformation<CRow>) - Constructor for class org.apache.flink.table.runtime.CRowCorrelateProcessRunner
 
CRowInputJavaTupleOutputMapRunner - Class in org.apache.flink.table.runtime
Convert CRow to a JTuple2
CRowInputJavaTupleOutputMapRunner(String, String, TypeInformation<Tuple2<Boolean, Object>>) - Constructor for class org.apache.flink.table.runtime.CRowInputJavaTupleOutputMapRunner
 
CRowInputMapRunner<OUT> - Class in org.apache.flink.table.runtime
MapRunner with CRow input.
CRowInputMapRunner(String, String, TypeInformation<OUT>) - Constructor for class org.apache.flink.table.runtime.CRowInputMapRunner
 
CRowInputScalaTupleOutputMapRunner - Class in org.apache.flink.table.runtime
Convert CRow to a Tuple2
CRowInputScalaTupleOutputMapRunner(String, String, TypeInformation<Tuple2<Object, Object>>) - Constructor for class org.apache.flink.table.runtime.CRowInputScalaTupleOutputMapRunner
 
CRowOutputMapRunner - Class in org.apache.flink.table.runtime
MapRunner with CRow output.
CRowOutputMapRunner(String, String, TypeInformation<CRow>) - Constructor for class org.apache.flink.table.runtime.CRowOutputMapRunner
 
CRowProcessRunner - Class in org.apache.flink.table.runtime
ProcessRunner with CRow input and CRow output.
CRowProcessRunner(String, String, TypeInformation<CRow>) - Constructor for class org.apache.flink.table.runtime.CRowProcessRunner
 
CRowSerializer - Class in org.apache.flink.table.runtime.types
 
CRowSerializer(TypeSerializer<Row>) - Constructor for class org.apache.flink.table.runtime.types.CRowSerializer
 
CRowSerializer$ - Class in org.apache.flink.table.runtime.types
 
CRowSerializer$() - Constructor for class org.apache.flink.table.runtime.types.CRowSerializer$
 
CRowSerializer.CRowSerializerConfigSnapshot - Class in org.apache.flink.table.runtime.types
 
CRowSerializer.CRowSerializerConfigSnapshot$ - Class in org.apache.flink.table.runtime.types
 
CRowSerializerConfigSnapshot(TypeSerializer<Row>) - Constructor for class org.apache.flink.table.runtime.types.CRowSerializer.CRowSerializerConfigSnapshot
 
CRowSerializerConfigSnapshot() - Constructor for class org.apache.flink.table.runtime.types.CRowSerializer.CRowSerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
CRowSerializerConfigSnapshot$() - Constructor for class org.apache.flink.table.runtime.types.CRowSerializer.CRowSerializerConfigSnapshot$
 
CRowTimeWindowPropertyCollector - Class in org.apache.flink.table.runtime.aggregate
 
CRowTimeWindowPropertyCollector(Option<Object>, Option<Object>) - Constructor for class org.apache.flink.table.runtime.aggregate.CRowTimeWindowPropertyCollector
 
CRowTypeInfo - Class in org.apache.flink.table.runtime.types
 
CRowTypeInfo(RowTypeInfo) - Constructor for class org.apache.flink.table.runtime.types.CRowTypeInfo
 
CRowTypeInfo$ - Class in org.apache.flink.table.runtime.types
 
CRowTypeInfo$() - Constructor for class org.apache.flink.table.runtime.types.CRowTypeInfo$
 
CRowValuesInputFormat - Class in org.apache.flink.table.runtime.io
 
CRowValuesInputFormat(String, String, TypeInformation<CRow>) - Constructor for class org.apache.flink.table.runtime.io.CRowValuesInputFormat
 
CRowWrappingCollector - Class in org.apache.flink.table.runtime
The collector is used to wrap a Row to a CRow
CRowWrappingCollector() - Constructor for class org.apache.flink.table.runtime.CRowWrappingCollector
 
CrudExternalCatalog - Interface in org.apache.flink.table.catalog
The CrudExternalCatalog provides methods to create, drop, and alter (sub-)catalogs or tables.
CSV<K extends Comparable<K>> - Class in org.apache.flink.graph.drivers.input
Read a Graph from a CSV file using IntValue, LongValue, or StringValue keys.
CSV() - Constructor for class org.apache.flink.graph.drivers.input.CSV
 
CSV - Interface in org.apache.flink.graph.drivers.output
Write algorithm output to file using CSV format.
CsvFormatter - Class in org.apache.flink.table.sinks
Formats a Row into a String with fields separated by the field delimiter.
CsvFormatter(String) - Constructor for class org.apache.flink.table.sinks.CsvFormatter
 
CsvInputFormat<OUT> - Class in org.apache.flink.api.java.io
 
CsvInputFormat(Path) - Constructor for class org.apache.flink.api.java.io.CsvInputFormat
 
CsvOutputFormat<T extends Tuple> - Class in org.apache.flink.api.java.io
This is an OutputFormat to serialize Tuples to text.
CsvOutputFormat(Path) - Constructor for class org.apache.flink.api.java.io.CsvOutputFormat
Creates an instance of CsvOutputFormat.
CsvOutputFormat(Path, String) - Constructor for class org.apache.flink.api.java.io.CsvOutputFormat
Creates an instance of CsvOutputFormat.
CsvOutputFormat(Path, String, String) - Constructor for class org.apache.flink.api.java.io.CsvOutputFormat
Creates an instance of CsvOutputFormat.
CsvReader - Class in org.apache.flink.api.java.io
A builder class to instantiate a CSV parsing data source.
CsvReader(Path, ExecutionEnvironment) - Constructor for class org.apache.flink.api.java.io.CsvReader
 
CsvReader(String, ExecutionEnvironment) - Constructor for class org.apache.flink.api.java.io.CsvReader
 
CsvTableSink - Class in org.apache.flink.table.sinks
A simple TableSink to emit data as CSV files.
CsvTableSink(String, Option<String>, Option<Object>, Option<FileSystem.WriteMode>) - Constructor for class org.apache.flink.table.sinks.CsvTableSink
 
CsvTableSink(String, String) - Constructor for class org.apache.flink.table.sinks.CsvTableSink
A simple TableSink to emit data as CSV files.
CsvTableSink(String, String, int, FileSystem.WriteMode) - Constructor for class org.apache.flink.table.sinks.CsvTableSink
A simple TableSink to emit data as CSV files.
CsvTableSink$ - Class in org.apache.flink.table.sinks
 
CsvTableSink$() - Constructor for class org.apache.flink.table.sinks.CsvTableSink$
 
CsvTableSource - Class in org.apache.flink.table.sources
A BatchTableSource and StreamTableSource for simple CSV files with a (logically) unlimited number of fields.
CsvTableSource(String, String[], TypeInformation<?>[], String, String, Character, boolean, String, boolean) - Constructor for class org.apache.flink.table.sources.CsvTableSource
 
CsvTableSource(String, String[], TypeInformation<?>[]) - Constructor for class org.apache.flink.table.sources.CsvTableSource
A BatchTableSource and StreamTableSource for simple CSV files with a (logically) unlimited number of fields.
CsvTableSource$ - Class in org.apache.flink.table.sources
 
CsvTableSource$() - Constructor for class org.apache.flink.table.sources.CsvTableSource$
 
CsvTableSource.Builder - Class in org.apache.flink.table.sources
A builder for creating CsvTableSource instances.
CsvTableSourceConverter - Class in org.apache.flink.table.sources
The class defines a converter used to convert CsvTableSource to or from ExternalCatalogTable.
CsvTableSourceConverter() - Constructor for class org.apache.flink.table.sources.CsvTableSourceConverter
 
ctor() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.CaseClassDescriptor
 
CUBE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
CUBE operator, occurs within GROUP BY clause or nested within a GROUPING SETS.
CUME_DIST - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
CUME_DIST window function.
cumulativeCosts - Variable in class org.apache.flink.optimizer.plan.PlanNode
 
CUR_DIR - Static variable in class org.apache.flink.core.fs.Path
Character denoting the current directory.
CURRENT_CATALOG - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The CURRENT_CATALOG function.
CURRENT_DATE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The CURRENT_DATE function.
CURRENT_PATH - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The CURRENT_PATH function.
CURRENT_RANGE() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionConversions
 
CURRENT_RANGE() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
CURRENT_RANGE() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
CURRENT_ROLE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The CURRENT_ROLE function.
CURRENT_ROW() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionConversions
 
CURRENT_ROW() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
CURRENT_ROW() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
CURRENT_SCHEMA - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The CURRENT_SCHEMA function.
CURRENT_TIME - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The CURRENT_TIME [(precision)] function.
CURRENT_TIMESTAMP - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The CURRENT_TIMESTAMP [(precision)] function.
CURRENT_USER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The CURRENT_USER function.
CURRENT_VALUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The sequence current value function: CURRENT VALUE FOR sequence
currentDate - Class in org.apache.flink.table.api.scala
Returns the current SQL date in UTC time zone.
currentDate() - Constructor for class org.apache.flink.table.api.scala.currentDate
 
CurrentDate - Class in org.apache.flink.table.expressions
 
CurrentDate() - Constructor for class org.apache.flink.table.expressions.CurrentDate
 
currentDate$ - Class in org.apache.flink.table.api.scala
Returns the current SQL date in UTC time zone.
currentDate$() - Constructor for class org.apache.flink.table.api.scala.currentDate$
 
CurrentDate$ - Class in org.apache.flink.table.expressions
 
CurrentDate$() - Constructor for class org.apache.flink.table.expressions.CurrentDate$
 
currentEnumerator - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
The channel enumerator that is used while processing the current partition to create channels for the spill partitions it requires.
currentFile - Variable in class org.apache.flink.streaming.connectors.fs.RollingSink.BucketState
Deprecated.
The file that was in-progress when the last checkpoint occurred.
currentFileValidLength - Variable in class org.apache.flink.streaming.connectors.fs.RollingSink.BucketState
Deprecated.
The valid length of the in-progress file at the time of the last checkpoint.
currentIteration() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
CurrentJobIdsHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Responder that returns with a list of all JobIDs of jobs found at the target actor.
CurrentJobIdsHandler(FiniteDuration) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.CurrentJobIdsHandler
 
currentJobManager() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
currentJobManager() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
 
currentJobManager() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
currentJobManager_$eq(Option<ActorRef>) - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
currentJobManager_$eq(Option<ActorRef>) - Static method in class org.apache.flink.yarn.YarnTaskManager
 
currentJobs() - Method in class org.apache.flink.runtime.jobmanager.JobManager
Either running or not yet archived jobs (session hasn't been ended).
CurrentJobsOverviewHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Request handler that returns a summary of the job status.
CurrentJobsOverviewHandler(FiniteDuration, boolean, boolean) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.CurrentJobsOverviewHandler
 
CurrentJobsOverviewHandler.CurrentJobsOverviewJsonArchivist - Class in org.apache.flink.runtime.webmonitor.handlers
 
CurrentJobsOverviewJsonArchivist() - Constructor for class org.apache.flink.runtime.webmonitor.handlers.CurrentJobsOverviewHandler.CurrentJobsOverviewJsonArchivist
 
CurrentJobStatus(JobID, JobStatus) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.CurrentJobStatus
 
CurrentJobStatus$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.CurrentJobStatus$
 
currentKey - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
The currently active key.
currentlyRegisteredTaskManagers() - Method in class org.apache.flink.runtime.clusterframework.messages.RegisterResourceManagerSuccessful
 
currentlyRunningJobs() - Method in class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
currentNamespace - Variable in class org.apache.flink.runtime.state.heap.AbstractHeapState
The current namespace, which the access methods will refer to.
currentProcessingTime() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
 
currentProcessingTime() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
Returns the current processing time.
currentProcessingTime() - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
 
currentProcessingTime() - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
Returns the current processing time.
currentProcessingTime() - Method in class org.apache.flink.streaming.api.scala.function.ProcessWindowFunction.Context
Returns the current processing time.
currentProcessingTime() - Method in class org.apache.flink.streaming.api.SimpleTimerService
 
currentProcessingTime() - Method in interface org.apache.flink.streaming.api.TimerService
Returns the current processing time.
currentProcessingTime() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
 
currentProcessingTime() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction.InternalWindowContext
 
currentProcessingTime() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
 
CurrentRange - Class in org.apache.flink.table.api
 
CurrentRange() - Constructor for class org.apache.flink.table.api.CurrentRange
 
currentRange() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
currentRange() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
CurrentRange$ - Class in org.apache.flink.table.api
 
CurrentRange$() - Constructor for class org.apache.flink.table.api.CurrentRange$
 
currentRecursionDepth - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
The recursion depth of the partition that is currently processed.
currentResourceManager() - Method in class org.apache.flink.runtime.jobmanager.JobManager
The resource manager actor responsible for allocating and managing task manager resources.
currentResourceManagerConnectionId() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
currentRow - Variable in class org.apache.flink.addons.hbase.AbstractTableInputFormat
 
CurrentRow - Class in org.apache.flink.table.api
 
CurrentRow() - Constructor for class org.apache.flink.table.api.CurrentRow
 
currentRow() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
currentRow() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
CurrentRow$ - Class in org.apache.flink.table.api
 
CurrentRow$() - Constructor for class org.apache.flink.table.api.CurrentRow$
 
currentSplit - Variable in class org.apache.flink.api.common.io.FileInputFormat
The current split that this parallel instance must consume.
currentTime - Class in org.apache.flink.table.api.scala
Returns the current SQL time in UTC time zone.
currentTime() - Constructor for class org.apache.flink.table.api.scala.currentTime
 
CurrentTime - Class in org.apache.flink.table.expressions
 
CurrentTime() - Constructor for class org.apache.flink.table.expressions.CurrentTime
 
currentTime$ - Class in org.apache.flink.table.api.scala
Returns the current SQL time in UTC time zone.
currentTime$() - Constructor for class org.apache.flink.table.api.scala.currentTime$
 
CurrentTime$ - Class in org.apache.flink.table.expressions
 
CurrentTime$() - Constructor for class org.apache.flink.table.expressions.CurrentTime$
 
currentTimeMillis() - Method in interface org.apache.flink.streaming.connectors.fs.Clock
Return the current system time in milliseconds.
currentTimeMillis() - Method in class org.apache.flink.streaming.connectors.fs.SystemClock
 
currentTimeout() - Method in class org.apache.flink.yarn.YarnMessages.TriggerApplicationClientRegistration
 
CurrentTimePoint - Class in org.apache.flink.table.expressions
 
CurrentTimePoint(TypeInformation<?>, boolean) - Constructor for class org.apache.flink.table.expressions.CurrentTimePoint
 
CurrentTimePointCallGen - Class in org.apache.flink.table.codegen.calls
Generates function call to determine current time point (as date/time/timestamp) in local timezone or not.
CurrentTimePointCallGen(TypeInformation<?>, boolean) - Constructor for class org.apache.flink.table.codegen.calls.CurrentTimePointCallGen
 
currentTimestamp - Class in org.apache.flink.table.api.scala
Returns the current SQL timestamp in UTC time zone.
currentTimestamp() - Constructor for class org.apache.flink.table.api.scala.currentTimestamp
 
CurrentTimestamp - Class in org.apache.flink.table.expressions
 
CurrentTimestamp() - Constructor for class org.apache.flink.table.expressions.CurrentTimestamp
 
currentTimestamp$ - Class in org.apache.flink.table.api.scala
Returns the current SQL timestamp in UTC time zone.
currentTimestamp$() - Constructor for class org.apache.flink.table.api.scala.currentTimestamp$
 
CurrentTimestamp$ - Class in org.apache.flink.table.expressions
 
CurrentTimestamp$() - Constructor for class org.apache.flink.table.expressions.CurrentTimestamp$
 
currentTraces() - Method in class org.apache.flink.runtime.messages.StackTraceSampleMessages.SampleTaskStackTrace
 
CurrentUserRetweet - Class in org.apache.flink.contrib.tweetinputformat.model.tweet
Details the Tweet ID of the user’s own retweet (if existent) of this Tweet.
CurrentUserRetweet() - Constructor for class org.apache.flink.contrib.tweetinputformat.model.tweet.CurrentUserRetweet
 
currentWatermark() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
 
currentWatermark() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
Returns the current event-time watermark.
currentWatermark() - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
 
currentWatermark() - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
Returns the current event-time watermark.
currentWatermark() - Method in class org.apache.flink.streaming.api.scala.function.ProcessWindowFunction.Context
Returns the current event-time watermark.
currentWatermark() - Method in class org.apache.flink.streaming.api.SimpleTimerService
 
currentWatermark() - Method in interface org.apache.flink.streaming.api.TimerService
Returns the current event-time watermark.
currentWatermark() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
 
currentWatermark() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction.InternalWindowContext
 
currentWatermark() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
 
CURSOR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The CURSOR constructor.
custId() - Method in class org.apache.flink.examples.scala.relational.TPCHQuery3.Customer
 
custId() - Method in class org.apache.flink.examples.scala.relational.TPCHQuery3.Order
 
custId() - Method in class org.apache.flink.table.examples.scala.TPCHQuery3Table.Order
 
CustomCommandLine<ClusterType extends ClusterClient> - Interface in org.apache.flink.client.cli
Custom command-line interface to load hooks for the command-line interface.
Customer() - Constructor for class org.apache.flink.examples.java.relational.TPCHQuery3.Customer
 
Customer(long, String) - Constructor for class org.apache.flink.examples.scala.relational.TPCHQuery3.Customer
 
Customer(long, String) - Constructor for class org.apache.flink.table.examples.scala.TPCHQuery3Table.Customer
 
Customer$() - Constructor for class org.apache.flink.examples.scala.relational.TPCHQuery3.Customer$
 
Customer$() - Constructor for class org.apache.flink.table.examples.scala.TPCHQuery3Table.Customer$
 
customPartitioner - Variable in class org.apache.flink.api.java.operators.Grouping
 
CustomPartitionerWrapper<K,T> - Class in org.apache.flink.streaming.runtime.partitioner
Partitioner that selects the channel with a user defined partitioner function on a key.
CustomPartitionerWrapper(Partitioner<K>, KeySelector<T, K>) - Constructor for class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
 
CustomTypeWrapper - Class in org.apache.flink.python.api.types
Container for serialized python objects, generally assumed to be custom objects.
CustomTypeWrapper(byte, byte[]) - Constructor for class org.apache.flink.python.api.types.CustomTypeWrapper
 
CustomTypeWrapperSerializer(CustomTypeWrapper) - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.CustomTypeWrapperSerializer
 
CustomUnaryOperation<IN,OUT> - Interface in org.apache.flink.api.java.operators
 
CycleGraph - Class in org.apache.flink.graph.drivers.input
Generate a CycleGraph.
CycleGraph() - Constructor for class org.apache.flink.graph.drivers.input.CycleGraph
 
CycleGraph - Class in org.apache.flink.graph.generator
 
CycleGraph(ExecutionEnvironment, long) - Constructor for class org.apache.flink.graph.generator.CycleGraph
An undirected Graph with n vertices where each vertex vi is connected to adjacent vertices v(i+1)%n and v(i-1)%n.

D

D1 - Static variable in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.EdgeWithDegrees
 
D1 - Static variable in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
 
D2 - Static variable in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.EdgeWithDegrees
 
D2 - Static variable in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
 
DagConnection - Class in org.apache.flink.optimizer.dag
A connection between to operators.
DagConnection(OptimizerNode, OptimizerNode, ExecutionMode) - Constructor for class org.apache.flink.optimizer.dag.DagConnection
Creates a new Connection between two nodes.
DagConnection(OptimizerNode, OptimizerNode, ShipStrategyType, ExecutionMode) - Constructor for class org.apache.flink.optimizer.dag.DagConnection
Creates a new Connection between two nodes.
DagConnection(OptimizerNode, ExecutionMode) - Constructor for class org.apache.flink.optimizer.dag.DagConnection
Constructor to create a result from an operator that is not consumed by another operator.
DamBehavior - Enum in org.apache.flink.runtime.operators
Enumeration for the different dam behaviors of an algorithm or a driver strategy.
damOnInput(int) - Method in enum org.apache.flink.runtime.operators.DriverStrategy
 
Dampener(double, double) - Constructor for class org.apache.flink.examples.java.graph.PageRank.Dampener
 
dams() - Method in enum org.apache.flink.runtime.operators.util.LocalStrategy
 
DashboardConfigHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Responder that returns the parameters that define how the asynchronous requests against this web server should behave.
DashboardConfigHandler(long) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.DashboardConfigHandler
 
data - Variable in class org.apache.flink.api.java.utils.ParameterTool
 
Data() - Constructor for class org.apache.flink.examples.java.ml.LinearRegression.Data
 
Data(double, double) - Constructor for class org.apache.flink.examples.java.ml.LinearRegression.Data
 
DATA - Static variable in class org.apache.flink.examples.java.ml.util.LinearRegressionData
 
Data(double, double) - Constructor for class org.apache.flink.examples.scala.ml.LinearRegression.Data
 
data() - Method in class org.apache.flink.mesos.scheduler.messages.FrameworkMessage
 
data() - Method in class org.apache.flink.ml.math.DenseMatrix
 
data() - Method in class org.apache.flink.ml.math.DenseVector
 
data() - Method in class org.apache.flink.ml.math.distributed.DistributedRowMatrix
 
data() - Method in class org.apache.flink.ml.math.SparseMatrix
 
data() - Method in class org.apache.flink.ml.math.SparseVector
 
data() - Method in class org.apache.flink.ml.outlier.StochasticOutlierSelection.BreezeLabeledVector
 
data - Variable in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
The state data.
Data$() - Constructor for class org.apache.flink.examples.scala.ml.LinearRegression.Data$
 
DATA_TMP_DIR - Static variable in class org.apache.flink.python.api.PythonOptions
The config parameter defining where the memory-mapped files will be created.
DataDistribution - Interface in org.apache.flink.api.common.distributions
 
DatadogHttpClient - Class in org.apache.flink.metrics.datadog
Http client talking to Datadog
DatadogHttpClient(String) - Constructor for class org.apache.flink.metrics.datadog.DatadogHttpClient
 
DatadogHttpReporter - Class in org.apache.flink.metrics.datadog
Metric Reporter for Datadog Variables in metrics scope will be sent to Datadog as tags
DatadogHttpReporter() - Constructor for class org.apache.flink.metrics.datadog.DatadogHttpReporter
 
DataExchangeMode - Enum in org.apache.flink.runtime.io.network
Defines how the data exchange between two specific operators happens.
DataInputDecoder - Class in org.apache.flink.api.avro
 
DataInputDecoder() - Constructor for class org.apache.flink.api.avro.DataInputDecoder
 
DataInputDecoder - Class in org.apache.flink.api.java.typeutils.runtime
 
DataInputDecoder() - Constructor for class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
DataInputDeserializer - Class in org.apache.flink.runtime.util
A simple and efficient deserializer for the DataInput interface.
DataInputDeserializer() - Constructor for class org.apache.flink.runtime.util.DataInputDeserializer
 
DataInputDeserializer(byte[]) - Constructor for class org.apache.flink.runtime.util.DataInputDeserializer
 
DataInputDeserializer(byte[], int, int) - Constructor for class org.apache.flink.runtime.util.DataInputDeserializer
 
DataInputDeserializer(ByteBuffer) - Constructor for class org.apache.flink.runtime.util.DataInputDeserializer
 
DataInputView - Interface in org.apache.flink.core.memory
This interface defines a view over some memory that can be used to sequentially read the contents of the memory.
DataInputViewStream - Class in org.apache.flink.api.java.typeutils.runtime
An input stream that draws its data from a DataInputView.
DataInputViewStream(DataInputView) - Constructor for class org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
 
DataInputViewStreamWrapper - Class in org.apache.flink.core.memory
Utility class that turns an InputStream into a DataInputView.
DataInputViewStreamWrapper(InputStream) - Constructor for class org.apache.flink.core.memory.DataInputViewStreamWrapper
 
DataOutputEncoder - Class in org.apache.flink.api.avro
 
DataOutputEncoder() - Constructor for class org.apache.flink.api.avro.DataOutputEncoder
 
DataOutputEncoder - Class in org.apache.flink.api.java.typeutils.runtime
 
DataOutputEncoder() - Constructor for class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
DataOutputSerializer - Class in org.apache.flink.runtime.util
A simple and efficient serializer for the DataOutput interface.
DataOutputSerializer(int) - Constructor for class org.apache.flink.runtime.util.DataOutputSerializer
 
DataOutputView - Interface in org.apache.flink.core.memory
This interface defines a view over some memory that can be used to sequentially write contents to the memory.
DataOutputViewStream - Class in org.apache.flink.api.java.typeutils.runtime
 
DataOutputViewStream(DataOutputView) - Constructor for class org.apache.flink.api.java.typeutils.runtime.DataOutputViewStream
 
DataOutputViewStreamWrapper - Class in org.apache.flink.core.memory
Utility class that turns an OutputStream into a DataOutputView.
DataOutputViewStreamWrapper(OutputStream) - Constructor for class org.apache.flink.core.memory.DataOutputViewStreamWrapper
 
DATAPOINTS - Static variable in class org.apache.flink.test.testdata.KMeansData
 
DATAPOINTS_2D - Static variable in class org.apache.flink.test.testdata.KMeansData
 
dataPort() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
Returns the port instance's task manager expects to receive transfer envelopes on.
DataSet<T> - Class in org.apache.flink.api.java
A DataSet represents a collection of elements of the same type.
A DataSet can be transformed into another DataSet by applying a transformation as for example DataSet.map(org.apache.flink.api.common.functions.MapFunction), DataSet.reduce(org.apache.flink.api.common.functions.ReduceFunction), DataSet.join(DataSet), or DataSet.coGroup(DataSet).
DataSet(ExecutionEnvironment, TypeInformation<T>) - Constructor for class org.apache.flink.api.java.DataSet
 
DataSet<T> - Class in org.apache.flink.api.scala
The DataSet, the basic abstraction of Flink.
DataSet(DataSet<T>, ClassTag<T>) - Constructor for class org.apache.flink.api.scala.DataSet
 
DATASET() - Method in class org.apache.flink.table.plan.nodes.FlinkConventions$
 
DATASET() - Static method in class org.apache.flink.table.plan.nodes.FlinkConventions
 
dataSet() - Method in class org.apache.flink.table.plan.schema.DataSetTable
 
DATASET_NORM_RULES() - Method in class org.apache.flink.table.plan.rules.FlinkRuleSets$
RuleSet to normalize plans for batch / DataSet execution
DATASET_NORM_RULES() - Static method in class org.apache.flink.table.plan.rules.FlinkRuleSets
RuleSet to normalize plans for batch / DataSet execution
DATASET_OPT_RULES() - Method in class org.apache.flink.table.plan.rules.FlinkRuleSets$
RuleSet to optimize plans for batch / DataSet execution
DATASET_OPT_RULES() - Static method in class org.apache.flink.table.plan.rules.FlinkRuleSets
RuleSet to optimize plans for batch / DataSet execution
DataSetAggFunction - Class in org.apache.flink.table.runtime.aggregate
RichGroupReduceFunction to compute aggregates that do not support pre-aggregation for batch (DataSet) queries.
DataSetAggFunction(GeneratedAggregationsFunction) - Constructor for class org.apache.flink.table.runtime.aggregate.DataSetAggFunction
 
DataSetAggregate - Class in org.apache.flink.table.plan.nodes.dataset
Flink RelNode which matches along with a LogicalAggregate.
DataSetAggregate(RelOptCluster, RelTraitSet, RelNode, Seq<Pair<AggregateCall, String>>, RelDataType, RelDataType, int[], boolean) - Constructor for class org.apache.flink.table.plan.nodes.dataset.DataSetAggregate
 
DataSetAggregateRule - Class in org.apache.flink.table.plan.rules.dataSet
 
DataSetAggregateRule() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateRule
 
DataSetAggregateRule$ - Class in org.apache.flink.table.plan.rules.dataSet
 
DataSetAggregateRule$() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateRule$
 
DataSetAggregateWithNullValuesRule - Class in org.apache.flink.table.plan.rules.dataSet
Rule for insert Row with null records into a DataSetAggregate.
DataSetAggregateWithNullValuesRule() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateWithNullValuesRule
 
DataSetAggregateWithNullValuesRule$ - Class in org.apache.flink.table.plan.rules.dataSet
 
DataSetAggregateWithNullValuesRule$() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateWithNullValuesRule$
 
DataSetAnalytic<T,R> - Interface in org.apache.flink.graph.asm.dataset
A DataSetAnalytic is similar to a CustomUnaryOperation but is terminal and results are retrieved via accumulators.
DataSetCalc - Class in org.apache.flink.table.plan.nodes.dataset
Flink RelNode which matches along with LogicalCalc.
DataSetCalc(RelOptCluster, RelTraitSet, RelNode, RelDataType, RexProgram, String) - Constructor for class org.apache.flink.table.plan.nodes.dataset.DataSetCalc
 
DataSetCalcRule - Class in org.apache.flink.table.plan.rules.dataSet
 
DataSetCalcRule() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetCalcRule
 
DataSetCalcRule$ - Class in org.apache.flink.table.plan.rules.dataSet
 
DataSetCalcRule$() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetCalcRule$
 
DataSetConversions<T> - Class in org.apache.flink.table.api.scala
Holds methods to convert a DataSet into a Table.
DataSetConversions(DataSet<T>, TypeInformation<T>) - Constructor for class org.apache.flink.table.api.scala.DataSetConversions
 
DataSetCorrelate - Class in org.apache.flink.table.plan.nodes.dataset
Flink RelNode which matches along with join a user defined table function.
DataSetCorrelate(RelOptCluster, RelTraitSet, RelNode, FlinkLogicalTableFunctionScan, Option<RexNode>, RelDataType, RelDataType, SemiJoinType, String) - Constructor for class org.apache.flink.table.plan.nodes.dataset.DataSetCorrelate
 
DataSetCorrelateRule - Class in org.apache.flink.table.plan.rules.dataSet
 
DataSetCorrelateRule() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetCorrelateRule
 
DataSetCorrelateRule$ - Class in org.apache.flink.table.plan.rules.dataSet
 
DataSetCorrelateRule$() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetCorrelateRule$
 
DataSetCost - Class in org.apache.flink.table.plan.cost
This class is based on Apache Calcite's org.apache.calcite.plan.volcano.VolcanoCost and has an adapted cost comparison method isLe(other: RelOptCost) that takes io and cpu into account.
DataSetCost(double, double, double) - Constructor for class org.apache.flink.table.plan.cost.DataSetCost
 
DataSetCost$ - Class in org.apache.flink.table.plan.cost
 
DataSetCost$() - Constructor for class org.apache.flink.table.plan.cost.DataSetCost$
 
DataSetCostFactory - Class in org.apache.flink.table.plan.cost
This class is based on Apache Calcite's org.apache.calcite.plan.volcano.VolcanoCost#Factory.
DataSetCostFactory() - Constructor for class org.apache.flink.table.plan.cost.DataSetCostFactory
 
DataSetDistinct - Class in org.apache.flink.table.plan.nodes.dataset
DataSet RelNode for a Distinct (LogicalAggregate without aggregation functions).
DataSetDistinct(RelOptCluster, RelTraitSet, RelNode, RelDataType, String) - Constructor for class org.apache.flink.table.plan.nodes.dataset.DataSetDistinct
 
DataSetDistinctRule - Class in org.apache.flink.table.plan.rules.dataSet
 
DataSetDistinctRule() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetDistinctRule
 
DataSetDistinctRule$ - Class in org.apache.flink.table.plan.rules.dataSet
 
DataSetDistinctRule$() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetDistinctRule$
 
DataSetFinalAggFunction - Class in org.apache.flink.table.runtime.aggregate
RichGroupReduceFunction to compute the final result of a pre-aggregated aggregation for batch (DataSet) queries.
DataSetFinalAggFunction(GeneratedAggregationsFunction) - Constructor for class org.apache.flink.table.runtime.aggregate.DataSetFinalAggFunction
 
DataSetIntersect - Class in org.apache.flink.table.plan.nodes.dataset
Flink RelNode which translates Intersect into CoGroup Operator.
DataSetIntersect(RelOptCluster, RelTraitSet, RelNode, RelNode, RelDataType, boolean) - Constructor for class org.apache.flink.table.plan.nodes.dataset.DataSetIntersect
 
DataSetIntersectRule - Class in org.apache.flink.table.plan.rules.dataSet
 
DataSetIntersectRule() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetIntersectRule
 
DataSetIntersectRule$ - Class in org.apache.flink.table.plan.rules.dataSet
 
DataSetIntersectRule$() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetIntersectRule$
 
DataSetJoin - Class in org.apache.flink.table.plan.nodes.dataset
Flink RelNode which matches along with JoinOperator and its related operations.
DataSetJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RelDataType, RexNode, RelDataType, JoinInfo, List<IntPair>, JoinRelType, JoinOperatorBase.JoinHint, String) - Constructor for class org.apache.flink.table.plan.nodes.dataset.DataSetJoin
 
DataSetJoinRule - Class in org.apache.flink.table.plan.rules.dataSet
 
DataSetJoinRule() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetJoinRule
 
DataSetJoinRule$ - Class in org.apache.flink.table.plan.rules.dataSet
 
DataSetJoinRule$() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetJoinRule$
 
DataSetLogicalWindowAggregateRule - Class in org.apache.flink.table.plan.rules.dataSet
 
DataSetLogicalWindowAggregateRule() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetLogicalWindowAggregateRule
 
DataSetLogicalWindowAggregateRule$ - Class in org.apache.flink.table.plan.rules.dataSet
 
DataSetLogicalWindowAggregateRule$() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetLogicalWindowAggregateRule$
 
DataSetMinus - Class in org.apache.flink.table.plan.nodes.dataset
Flink RelNode which implements set minus operation.
DataSetMinus(RelOptCluster, RelTraitSet, RelNode, RelNode, RelDataType, boolean) - Constructor for class org.apache.flink.table.plan.nodes.dataset.DataSetMinus
 
DataSetMinusRule - Class in org.apache.flink.table.plan.rules.dataSet
 
DataSetMinusRule() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetMinusRule
 
DataSetMinusRule$ - Class in org.apache.flink.table.plan.rules.dataSet
 
DataSetMinusRule$() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetMinusRule$
 
DataSetPreAggFunction - Class in org.apache.flink.table.runtime.aggregate
GroupCombineFunction and MapPartitionFunction to compute pre-aggregates for batch (DataSet) queries.
DataSetPreAggFunction(GeneratedAggregationsFunction) - Constructor for class org.apache.flink.table.runtime.aggregate.DataSetPreAggFunction
 
DataSetRel - Interface in org.apache.flink.table.plan.nodes.dataset
 
DataSetScan - Class in org.apache.flink.table.plan.nodes.dataset
Flink RelNode which matches along with DataSource.
DataSetScan(RelOptCluster, RelTraitSet, RelOptTable, RelDataType) - Constructor for class org.apache.flink.table.plan.nodes.dataset.DataSetScan
 
DataSetScanRule - Class in org.apache.flink.table.plan.rules.dataSet
 
DataSetScanRule() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetScanRule
 
DataSetScanRule$ - Class in org.apache.flink.table.plan.rules.dataSet
 
DataSetScanRule$() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetScanRule$
 
DataSetSessionWindowAggReduceGroupFunction - Class in org.apache.flink.table.runtime.aggregate
It wraps the aggregate logic inside of GroupReduceOperator.
DataSetSessionWindowAggReduceGroupFunction(GeneratedAggregationsFunction, int, Option<Object>, Option<Object>, long, boolean) - Constructor for class org.apache.flink.table.runtime.aggregate.DataSetSessionWindowAggReduceGroupFunction
 
DataSetSessionWindowAggregatePreProcessor - Class in org.apache.flink.table.runtime.aggregate
This wraps the aggregate logic inside of GroupCombineOperator.
DataSetSessionWindowAggregatePreProcessor(GeneratedAggregationsFunction, int, long, TypeInformation<Row>) - Constructor for class org.apache.flink.table.runtime.aggregate.DataSetSessionWindowAggregatePreProcessor
 
DataSetSingleRowJoin - Class in org.apache.flink.table.plan.nodes.dataset
Flink RelNode that executes a Join where one of inputs is a single row.
DataSetSingleRowJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, boolean, RelDataType, RexNode, RelDataType, JoinRelType, String) - Constructor for class org.apache.flink.table.plan.nodes.dataset.DataSetSingleRowJoin
 
DataSetSingleRowJoinRule - Class in org.apache.flink.table.plan.rules.dataSet
 
DataSetSingleRowJoinRule() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetSingleRowJoinRule
 
DataSetSingleRowJoinRule$ - Class in org.apache.flink.table.plan.rules.dataSet
 
DataSetSingleRowJoinRule$() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetSingleRowJoinRule$
 
DataSetSlideTimeWindowAggFlatMapFunction - Class in org.apache.flink.table.runtime.aggregate
It is used for sliding windows on batch for time-windows.
DataSetSlideTimeWindowAggFlatMapFunction(int, long, long, TypeInformation<Row>) - Constructor for class org.apache.flink.table.runtime.aggregate.DataSetSlideTimeWindowAggFlatMapFunction
 
DataSetSlideTimeWindowAggReduceGroupFunction - Class in org.apache.flink.table.runtime.aggregate
It is used for sliding windows on batch for time-windows.
DataSetSlideTimeWindowAggReduceGroupFunction(GeneratedAggregationsFunction, int, long, long, TypeInformation<Row>) - Constructor for class org.apache.flink.table.runtime.aggregate.DataSetSlideTimeWindowAggReduceGroupFunction
 
DataSetSlideWindowAggReduceCombineFunction - Class in org.apache.flink.table.runtime.aggregate
Wraps the aggregate logic inside of GroupReduceOperator and GroupCombineOperator.
DataSetSlideWindowAggReduceCombineFunction(GeneratedAggregationsFunction, GeneratedAggregationsFunction, int, Option<Object>, Option<Object>, long) - Constructor for class org.apache.flink.table.runtime.aggregate.DataSetSlideWindowAggReduceCombineFunction
 
DataSetSlideWindowAggReduceGroupFunction - Class in org.apache.flink.table.runtime.aggregate
It wraps the aggregate logic inside of GroupReduceOperator.
DataSetSlideWindowAggReduceGroupFunction(GeneratedAggregationsFunction, int, Option<Object>, Option<Object>, long) - Constructor for class org.apache.flink.table.runtime.aggregate.DataSetSlideWindowAggReduceGroupFunction
 
DataSetSort - Class in org.apache.flink.table.plan.nodes.dataset
 
DataSetSort(RelOptCluster, RelTraitSet, RelNode, RelCollation, RelDataType, RexNode, RexNode) - Constructor for class org.apache.flink.table.plan.nodes.dataset.DataSetSort
 
DataSetSortRule - Class in org.apache.flink.table.plan.rules.dataSet
 
DataSetSortRule() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetSortRule
 
DataSetSortRule$ - Class in org.apache.flink.table.plan.rules.dataSet
 
DataSetSortRule$() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetSortRule$
 
dataSetTable() - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetScan
 
DataSetTable<T> - Class in org.apache.flink.table.plan.schema
 
DataSetTable(DataSet<T>, int[], String[], FlinkStatistic) - Constructor for class org.apache.flink.table.plan.schema.DataSetTable
 
DataSetTable$ - Class in org.apache.flink.table.plan.schema
 
DataSetTable$() - Constructor for class org.apache.flink.table.plan.schema.DataSetTable$
 
DataSetTumbleCountWindowAggReduceGroupFunction - Class in org.apache.flink.table.runtime.aggregate
It wraps the aggregate logic inside of GroupReduceOperator.
DataSetTumbleCountWindowAggReduceGroupFunction(GeneratedAggregationsFunction, long) - Constructor for class org.apache.flink.table.runtime.aggregate.DataSetTumbleCountWindowAggReduceGroupFunction
 
DataSetTumbleTimeWindowAggReduceCombineFunction - Class in org.apache.flink.table.runtime.aggregate
It wraps the aggregate logic inside of GroupReduceOperator and GroupCombineOperator.
DataSetTumbleTimeWindowAggReduceCombineFunction(GeneratedAggregationsFunction, GeneratedAggregationsFunction, long, Option<Object>, Option<Object>, int) - Constructor for class org.apache.flink.table.runtime.aggregate.DataSetTumbleTimeWindowAggReduceCombineFunction
 
DataSetTumbleTimeWindowAggReduceGroupFunction - Class in org.apache.flink.table.runtime.aggregate
It wraps the aggregate logic inside of GroupReduceOperator.
DataSetTumbleTimeWindowAggReduceGroupFunction(GeneratedAggregationsFunction, long, Option<Object>, Option<Object>, int) - Constructor for class org.apache.flink.table.runtime.aggregate.DataSetTumbleTimeWindowAggReduceGroupFunction
 
DataSetUnion - Class in org.apache.flink.table.plan.nodes.dataset
Flink RelNode which matches along with UnionOperator.
DataSetUnion(RelOptCluster, RelTraitSet, RelNode, RelNode, RelDataType) - Constructor for class org.apache.flink.table.plan.nodes.dataset.DataSetUnion
 
DataSetUnionRule - Class in org.apache.flink.table.plan.rules.dataSet
 
DataSetUnionRule() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetUnionRule
 
DataSetUnionRule$ - Class in org.apache.flink.table.plan.rules.dataSet
 
DataSetUnionRule$() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetUnionRule$
 
DataSetUtils - Class in org.apache.flink.api.java.utils
This class provides simple utility methods for zipping elements in a data set with an index or with a unique identifier.
DataSetValues - Class in org.apache.flink.table.plan.nodes.dataset
DataSet RelNode for a LogicalValues.
DataSetValues(RelOptCluster, RelTraitSet, RelDataType, ImmutableList<ImmutableList<RexLiteral>>, String) - Constructor for class org.apache.flink.table.plan.nodes.dataset.DataSetValues
 
DataSetValuesRule - Class in org.apache.flink.table.plan.rules.dataSet
 
DataSetValuesRule() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetValuesRule
 
DataSetValuesRule$ - Class in org.apache.flink.table.plan.rules.dataSet
 
DataSetValuesRule$() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetValuesRule$
 
DataSetWindowAggMapFunction - Class in org.apache.flink.table.runtime.aggregate
This map function only works for windows on batch tables.
DataSetWindowAggMapFunction(GeneratedAggregationsFunction, int, Option<Object>, TypeInformation<Row>) - Constructor for class org.apache.flink.table.runtime.aggregate.DataSetWindowAggMapFunction
 
DataSetWindowAggregate - Class in org.apache.flink.table.plan.nodes.dataset
Flink RelNode which matches along with a LogicalWindowAggregate.
DataSetWindowAggregate(LogicalWindow, Seq<FlinkRelBuilder.NamedWindowProperty>, RelOptCluster, RelTraitSet, RelNode, Seq<Pair<AggregateCall, String>>, RelDataType, RelDataType, int[]) - Constructor for class org.apache.flink.table.plan.nodes.dataset.DataSetWindowAggregate
 
DataSetWindowAggregateRule - Class in org.apache.flink.table.plan.rules.dataSet
 
DataSetWindowAggregateRule() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetWindowAggregateRule
 
DataSetWindowAggregateRule$ - Class in org.apache.flink.table.plan.rules.dataSet
 
DataSetWindowAggregateRule$() - Constructor for class org.apache.flink.table.plan.rules.dataSet.DataSetWindowAggregateRule$
 
DataSink<T> - Class in org.apache.flink.api.java.operators
 
DataSink(DataSet<T>, OutputFormat<T>, TypeInformation<T>) - Constructor for class org.apache.flink.api.java.operators.DataSink
 
DataSinkNode - Class in org.apache.flink.optimizer.dag
The Optimizer representation of a data sink.
DataSinkNode(GenericDataSinkBase<?>) - Constructor for class org.apache.flink.optimizer.dag.DataSinkNode
Creates a new DataSinkNode for the given sink operator.
DataSinkTask<IT> - Class in org.apache.flink.runtime.operators
DataSinkTask which is executed by a task manager.
DataSinkTask() - Constructor for class org.apache.flink.runtime.operators.DataSinkTask
 
DataSource<OUT> - Class in org.apache.flink.api.java.operators
An operation that creates a new data set (data source).
DataSource(ExecutionEnvironment, InputFormat<OUT, ?>, TypeInformation<OUT>, String) - Constructor for class org.apache.flink.api.java.operators.DataSource
Creates a new data source.
DataSourceNode - Class in org.apache.flink.optimizer.dag
The optimizer's internal representation of a data source.
DataSourceNode(GenericDataSourceBase<?, ?>) - Constructor for class org.apache.flink.optimizer.dag.DataSourceNode
Creates a new DataSourceNode for the given contract.
DataSourceTask<OT> - Class in org.apache.flink.runtime.operators
DataSourceTask which is executed by a task manager.
DataSourceTask() - Constructor for class org.apache.flink.runtime.operators.DataSourceTask
 
DataStatistics - Class in org.apache.flink.optimizer
The collection of access methods that can be used to retrieve statistical information about the data processed in a job.
DataStatistics() - Constructor for class org.apache.flink.optimizer.DataStatistics
Creates a new statistics object, with an empty cache.
DataStream<T> - Class in org.apache.flink.streaming.api.datastream
A DataStream represents a stream of elements of the same type.
DataStream(StreamExecutionEnvironment, StreamTransformation<T>) - Constructor for class org.apache.flink.streaming.api.datastream.DataStream
Create a new DataStream in the given execution environment with partitioning set to forward by default.
DataStream<T> - Class in org.apache.flink.streaming.api.scala
 
DataStream(DataStream<T>) - Constructor for class org.apache.flink.streaming.api.scala.DataStream
 
DATASTREAM() - Method in class org.apache.flink.table.plan.nodes.FlinkConventions$
 
DATASTREAM() - Static method in class org.apache.flink.table.plan.nodes.FlinkConventions
 
dataStream() - Method in class org.apache.flink.table.plan.schema.DataStreamTable
 
DATASTREAM_DECO_RULES() - Method in class org.apache.flink.table.plan.rules.FlinkRuleSets$
RuleSet to decorate plans for stream / DataStream execution
DATASTREAM_DECO_RULES() - Static method in class org.apache.flink.table.plan.rules.FlinkRuleSets
RuleSet to decorate plans for stream / DataStream execution
DATASTREAM_NORM_RULES() - Method in class org.apache.flink.table.plan.rules.FlinkRuleSets$
RuleSet to normalize plans for stream / DataStream execution
DATASTREAM_NORM_RULES() - Static method in class org.apache.flink.table.plan.rules.FlinkRuleSets
RuleSet to normalize plans for stream / DataStream execution
DATASTREAM_OPT_RULES() - Method in class org.apache.flink.table.plan.rules.FlinkRuleSets$
RuleSet to optimize plans for stream / DataStream execution
DATASTREAM_OPT_RULES() - Static method in class org.apache.flink.table.plan.rules.FlinkRuleSets
RuleSet to optimize plans for stream / DataStream execution
DataStreamCalc - Class in org.apache.flink.table.plan.nodes.datastream
Flink RelNode which matches along with FlatMapOperator.
DataStreamCalc(RelOptCluster, RelTraitSet, RelNode, RowSchema, RowSchema, RexProgram, String) - Constructor for class org.apache.flink.table.plan.nodes.datastream.DataStreamCalc
 
DataStreamCalcRule - Class in org.apache.flink.table.plan.rules.datastream
 
DataStreamCalcRule() - Constructor for class org.apache.flink.table.plan.rules.datastream.DataStreamCalcRule
 
DataStreamCalcRule$ - Class in org.apache.flink.table.plan.rules.datastream
 
DataStreamCalcRule$() - Constructor for class org.apache.flink.table.plan.rules.datastream.DataStreamCalcRule$
 
DataStreamConversions<T> - Class in org.apache.flink.table.api.scala
Holds methods to convert a DataStream into a Table.
DataStreamConversions(DataStream<T>, TypeInformation<T>) - Constructor for class org.apache.flink.table.api.scala.DataStreamConversions
 
DataStreamCorrelate - Class in org.apache.flink.table.plan.nodes.datastream
Flink RelNode which matches along with join a user defined table function.
DataStreamCorrelate(RelOptCluster, RelTraitSet, RowSchema, RelNode, FlinkLogicalTableFunctionScan, Option<RexNode>, RowSchema, RowSchema, SemiJoinType, String) - Constructor for class org.apache.flink.table.plan.nodes.datastream.DataStreamCorrelate
 
DataStreamCorrelateRule - Class in org.apache.flink.table.plan.rules.datastream
 
DataStreamCorrelateRule() - Constructor for class org.apache.flink.table.plan.rules.datastream.DataStreamCorrelateRule
 
DataStreamCorrelateRule$ - Class in org.apache.flink.table.plan.rules.datastream
 
DataStreamCorrelateRule$() - Constructor for class org.apache.flink.table.plan.rules.datastream.DataStreamCorrelateRule$
 
DataStreamGroupAggregate - Class in org.apache.flink.table.plan.nodes.datastream
Flink RelNode for data stream unbounded group aggregate
DataStreamGroupAggregate(RelOptCluster, RelTraitSet, RelNode, Seq<Pair<AggregateCall, String>>, RowSchema, RowSchema, int[]) - Constructor for class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupAggregate
 
DataStreamGroupAggregateRule - Class in org.apache.flink.table.plan.rules.datastream
Rule to convert a LogicalAggregate into a DataStreamGroupAggregate.
DataStreamGroupAggregateRule() - Constructor for class org.apache.flink.table.plan.rules.datastream.DataStreamGroupAggregateRule
 
DataStreamGroupAggregateRule$ - Class in org.apache.flink.table.plan.rules.datastream
 
DataStreamGroupAggregateRule$() - Constructor for class org.apache.flink.table.plan.rules.datastream.DataStreamGroupAggregateRule$
 
DataStreamGroupWindowAggregate - Class in org.apache.flink.table.plan.nodes.datastream
 
DataStreamGroupWindowAggregate(LogicalWindow, Seq<FlinkRelBuilder.NamedWindowProperty>, RelOptCluster, RelTraitSet, RelNode, Seq<Pair<AggregateCall, String>>, RowSchema, RowSchema, int[]) - Constructor for class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
DataStreamGroupWindowAggregate$ - Class in org.apache.flink.table.plan.nodes.datastream
 
DataStreamGroupWindowAggregate$() - Constructor for class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate$
 
DataStreamGroupWindowAggregateRule - Class in org.apache.flink.table.plan.rules.datastream
 
DataStreamGroupWindowAggregateRule() - Constructor for class org.apache.flink.table.plan.rules.datastream.DataStreamGroupWindowAggregateRule
 
DataStreamGroupWindowAggregateRule$ - Class in org.apache.flink.table.plan.rules.datastream
 
DataStreamGroupWindowAggregateRule$() - Constructor for class org.apache.flink.table.plan.rules.datastream.DataStreamGroupWindowAggregateRule$
 
DataStreamLogicalWindowAggregateRule - Class in org.apache.flink.table.plan.rules.datastream
 
DataStreamLogicalWindowAggregateRule() - Constructor for class org.apache.flink.table.plan.rules.datastream.DataStreamLogicalWindowAggregateRule
 
DataStreamLogicalWindowAggregateRule$ - Class in org.apache.flink.table.plan.rules.datastream
 
DataStreamLogicalWindowAggregateRule$() - Constructor for class org.apache.flink.table.plan.rules.datastream.DataStreamLogicalWindowAggregateRule$
 
DataStreamOverAggregate - Class in org.apache.flink.table.plan.nodes.datastream
 
DataStreamOverAggregate(Window, RelOptCluster, RelTraitSet, RelNode, RowSchema, RowSchema) - Constructor for class org.apache.flink.table.plan.nodes.datastream.DataStreamOverAggregate
 
DataStreamOverAggregateRule - Class in org.apache.flink.table.plan.rules.datastream
 
DataStreamOverAggregateRule() - Constructor for class org.apache.flink.table.plan.rules.datastream.DataStreamOverAggregateRule
 
DataStreamOverAggregateRule$ - Class in org.apache.flink.table.plan.rules.datastream
 
DataStreamOverAggregateRule$() - Constructor for class org.apache.flink.table.plan.rules.datastream.DataStreamOverAggregateRule$
 
DataStreamRel - Interface in org.apache.flink.table.plan.nodes.datastream
 
DataStreamRetractionRules - Class in org.apache.flink.table.plan.rules.datastream
Collection of rules to annotate DataStreamRel nodes with retraction information.
DataStreamRetractionRules() - Constructor for class org.apache.flink.table.plan.rules.datastream.DataStreamRetractionRules
 
DataStreamRetractionRules$ - Class in org.apache.flink.table.plan.rules.datastream
Collection of rules to annotate DataStreamRel nodes with retraction information.
DataStreamRetractionRules$() - Constructor for class org.apache.flink.table.plan.rules.datastream.DataStreamRetractionRules$
 
DataStreamRetractionRules.AssignDefaultRetractionRule - Class in org.apache.flink.table.plan.rules.datastream
Rule that assigns the default retraction information to DataStreamRel nodes.
DataStreamRetractionRules.SetAccModeRule - Class in org.apache.flink.table.plan.rules.datastream
Sets the AccMode of DataStreamRel nodes.
DataStreamRetractionRules.SetUpdatesAsRetractionRule - Class in org.apache.flink.table.plan.rules.datastream
Rule that annotates all DataStreamRel nodes that need to sent out update changes with retraction messages.
DataStreamScan - Class in org.apache.flink.table.plan.nodes.datastream
Flink RelNode which matches along with DataStreamSource.
DataStreamScan(RelOptCluster, RelTraitSet, RelOptTable, RowSchema) - Constructor for class org.apache.flink.table.plan.nodes.datastream.DataStreamScan
 
DataStreamScanRule - Class in org.apache.flink.table.plan.rules.datastream
 
DataStreamScanRule() - Constructor for class org.apache.flink.table.plan.rules.datastream.DataStreamScanRule
 
DataStreamScanRule$ - Class in org.apache.flink.table.plan.rules.datastream
 
DataStreamScanRule$() - Constructor for class org.apache.flink.table.plan.rules.datastream.DataStreamScanRule$
 
DataStreamSink<T> - Class in org.apache.flink.streaming.api.datastream
A Stream Sink.
DataStreamSink(DataStream<T>, StreamSink<T>) - Constructor for class org.apache.flink.streaming.api.datastream.DataStreamSink
 
DataStreamSource<T> - Class in org.apache.flink.streaming.api.datastream
The DataStreamSource represents the starting point of a DataStream.
DataStreamSource(StreamExecutionEnvironment, TypeInformation<T>, StreamSource<T, ?>, boolean, String) - Constructor for class org.apache.flink.streaming.api.datastream.DataStreamSource
 
DataStreamSource(SingleOutputStreamOperator<T>) - Constructor for class org.apache.flink.streaming.api.datastream.DataStreamSource
 
dataStreamTable() - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamScan
 
DataStreamTable<T> - Class in org.apache.flink.table.plan.schema
 
DataStreamTable(DataStream<T>, int[], String[], Option<Tuple2<Object, String>>, Option<Tuple2<Object, String>>, FlinkStatistic) - Constructor for class org.apache.flink.table.plan.schema.DataStreamTable
 
DataStreamTable$ - Class in org.apache.flink.table.plan.schema
 
DataStreamTable$() - Constructor for class org.apache.flink.table.plan.schema.DataStreamTable$
 
DataStreamUnion - Class in org.apache.flink.table.plan.nodes.datastream
Flink RelNode which matches along with Union.
DataStreamUnion(RelOptCluster, RelTraitSet, RelNode, RelNode, RowSchema) - Constructor for class org.apache.flink.table.plan.nodes.datastream.DataStreamUnion
 
DataStreamUnionRule - Class in org.apache.flink.table.plan.rules.datastream
 
DataStreamUnionRule() - Constructor for class org.apache.flink.table.plan.rules.datastream.DataStreamUnionRule
 
DataStreamUnionRule$ - Class in org.apache.flink.table.plan.rules.datastream
 
DataStreamUnionRule$() - Constructor for class org.apache.flink.table.plan.rules.datastream.DataStreamUnionRule$
 
DataStreamUtils - Class in org.apache.flink.contrib.streaming
 
DataStreamValues - Class in org.apache.flink.table.plan.nodes.datastream
DataStream RelNode for LogicalValues.
DataStreamValues(RelOptCluster, RelTraitSet, RowSchema, ImmutableList<ImmutableList<RexLiteral>>, String) - Constructor for class org.apache.flink.table.plan.nodes.datastream.DataStreamValues
 
DataStreamValuesRule - Class in org.apache.flink.table.plan.rules.datastream
 
DataStreamValuesRule() - Constructor for class org.apache.flink.table.plan.rules.datastream.DataStreamValuesRule
 
DataStreamValuesRule$ - Class in org.apache.flink.table.plan.rules.datastream
 
DataStreamValuesRule$() - Constructor for class org.apache.flink.table.plan.rules.datastream.DataStreamValuesRule$
 
dataType() - Method in class org.apache.flink.streaming.api.scala.DataStream
Returns the TypeInformation for the elements of this DataStream.
dataType() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
dataType() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
DATE - Static variable in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
date() - Method in class org.apache.flink.runtime.clusterframework.messages.InfoMessage
 
DATE_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
DateComparator - Class in org.apache.flink.api.common.typeutils.base
 
DateComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.DateComparator
 
DateSerializer - Class in org.apache.flink.api.common.typeutils.base
 
DateSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.DateSerializer
 
DATETIME_PLUS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Infix datetime plus operator, 'DATETIME + INTERVAL'.
DateTimeBucketer<T> - Class in org.apache.flink.streaming.connectors.fs.bucketing
A Bucketer that assigns to buckets based on current system time.
DateTimeBucketer() - Constructor for class org.apache.flink.streaming.connectors.fs.bucketing.DateTimeBucketer
Creates a new DateTimeBucketer with format string "yyyy-MM-dd--HH".
DateTimeBucketer(String) - Constructor for class org.apache.flink.streaming.connectors.fs.bucketing.DateTimeBucketer
Creates a new DateTimeBucketer with the given date/time format string.
DateTimeBucketer - Class in org.apache.flink.streaming.connectors.fs
Deprecated.
use DateTimeBucketer instead.
DateTimeBucketer() - Constructor for class org.apache.flink.streaming.connectors.fs.DateTimeBucketer
Deprecated.
Creates a new DateTimeBucketer with format string "yyyy-MM-dd--HH".
DateTimeBucketer(String) - Constructor for class org.apache.flink.streaming.connectors.fs.DateTimeBucketer
Deprecated.
Creates a new DateTimeBucketer with the given date/time format string.
day() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Creates an interval of the given number of days.
DAY() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
DAY() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
DAY() - Method in class org.apache.flink.table.expressions.TimeIntervalUnit$
 
DAY() - Static method in class org.apache.flink.table.expressions.TimeIntervalUnit
 
DAY() - Method in class org.apache.flink.table.expressions.TimePointUnit$
 
DAY() - Static method in class org.apache.flink.table.expressions.TimePointUnit
 
DAY_TO_HOUR() - Method in class org.apache.flink.table.expressions.TimeIntervalUnit$
 
DAY_TO_HOUR() - Static method in class org.apache.flink.table.expressions.TimeIntervalUnit
 
DAY_TO_MINUTE() - Method in class org.apache.flink.table.expressions.TimeIntervalUnit$
 
DAY_TO_MINUTE() - Static method in class org.apache.flink.table.expressions.TimeIntervalUnit
 
DAY_TO_SECOND() - Method in class org.apache.flink.table.expressions.TimeIntervalUnit$
 
DAY_TO_SECOND() - Static method in class org.apache.flink.table.expressions.TimeIntervalUnit
 
DAYOFMONTH - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The SQL DAYOFMONTH operator.
DAYOFWEEK - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The SQL DAYOFWEEK operator.
DAYOFYEAR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The SQL DAYOFYEAR operator.
days(long) - Static method in class org.apache.flink.api.common.time.Time
Creates a new Time that represents the given number of days.
days(long) - Static method in class org.apache.flink.streaming.api.windowing.time.Time
Creates a new Time that represents the given number of days.
days() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Creates an interval of the given number of days.
DAYS() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
DAYS() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
db - Variable in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
Our RocksDB data base, this is used by the actual subclasses of AbstractRocksDBState to store state.
DC_TMP_DIR - Static variable in class org.apache.flink.python.api.PythonOptions
The config parameter defining where the flink python library and user supplied files will be uploaded to before registering them with the Distributed Cache.
DCounter - Class in org.apache.flink.metrics.datadog
Mapping of counter between Flink and Datadog
DCounter(Counter, String, String, List<String>) - Constructor for class org.apache.flink.metrics.datadog.DCounter
 
deactivate(String) - Method in class org.apache.flink.storm.api.FlinkLocalCluster
 
deactivate() - Method in class org.apache.flink.storm.util.AbstractLineSpout
 
deactivate() - Method in class org.apache.flink.storm.util.NullTerminatingSpout
 
deadline() - Method in class org.apache.flink.runtime.messages.RegistrationMessages.TriggerTaskManagerRegistration
 
deadline() - Method in class org.apache.flink.yarn.YarnMessages.TriggerApplicationClientRegistration
 
debugEvent() - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
debugEvent() - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
debugEvent() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
debugEvent() - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
dec() - Method in interface org.apache.flink.metrics.Counter
Decrement the current count by 1.
dec(long) - Method in interface org.apache.flink.metrics.Counter
Decrement the current count by the given value.
dec() - Method in class org.apache.flink.metrics.SimpleCounter
Decrement the current count by 1.
dec(long) - Method in class org.apache.flink.metrics.SimpleCounter
Decrement the current count by the given value.
decay() - Method in class org.apache.flink.ml.optimization.LearningRateMethod.InvScaling
 
decay() - Method in class org.apache.flink.ml.optimization.LearningRateMethod.Xu
 
DECIMAL - Static variable in class org.apache.flink.api.common.typeinfo.Types
 
DECIMAL() - Method in class org.apache.flink.table.api.Types$
 
DECIMAL() - Static method in class org.apache.flink.table.api.Types
 
DECIMAL() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
DECIMAL() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
DecimalAvgAccumulator - Class in org.apache.flink.table.functions.aggfunctions
The initial accumulator for Big Decimal Avg aggregate function
DecimalAvgAccumulator() - Constructor for class org.apache.flink.table.functions.aggfunctions.DecimalAvgAccumulator
 
DecimalAvgAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Base class for built-in Big Decimal Avg aggregate function
DecimalAvgAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.DecimalAvgAggFunction
 
DecimalMaxAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Big Decimal Max aggregate function
DecimalMaxAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.DecimalMaxAggFunction
 
DecimalMaxWithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Big Decimal Max with retraction aggregate function
DecimalMaxWithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.DecimalMaxWithRetractAggFunction
 
DecimalMinAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Big Decimal Min aggregate function
DecimalMinAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.DecimalMinAggFunction
 
DecimalMinWithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Big Decimal Min with retraction aggregate function
DecimalMinWithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.DecimalMinWithRetractAggFunction
 
decimalNumber() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
DecimalSum0AggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Big Decimal Sum0 aggregate function
DecimalSum0AggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.DecimalSum0AggFunction
 
DecimalSum0WithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Big Decimal Sum0 with retract aggregate function
DecimalSum0WithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.DecimalSum0WithRetractAggFunction
 
DecimalSumAccumulator - Class in org.apache.flink.table.functions.aggfunctions
The initial accumulator for Big Decimal Sum aggregate function
DecimalSumAccumulator() - Constructor for class org.apache.flink.table.functions.aggfunctions.DecimalSumAccumulator
 
DecimalSumAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Big Decimal Sum aggregate function
DecimalSumAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.DecimalSumAggFunction
 
DecimalSumWithRetractAccumulator - Class in org.apache.flink.table.functions.aggfunctions
The initial accumulator for Big Decimal Sum with retract aggregate function
DecimalSumWithRetractAccumulator() - Constructor for class org.apache.flink.table.functions.aggfunctions.DecimalSumWithRetractAccumulator
 
DecimalSumWithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Big Decimal Sum with retract aggregate function
DecimalSumWithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.DecimalSumWithRetractAggFunction
 
declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.flink.storm.exclamation.operators.ExclamationBolt
 
declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.flink.storm.split.operators.RandomSpout
 
declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.flink.storm.split.operators.VerifyAndEnrichBolt
 
declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.flink.storm.util.AbstractBoltSink
 
declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.flink.storm.util.AbstractLineSpout
 
declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.flink.storm.util.NullTerminatingSpout
 
declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.flink.storm.wordcount.operators.BoltCounter
 
declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.flink.storm.wordcount.operators.BoltCounterByName
 
declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.flink.storm.wordcount.operators.BoltTokenizer
 
declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.flink.storm.wordcount.operators.BoltTokenizerByName
 
declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.flink.storm.wordcount.operators.WordCountFileSpout
 
declareOutputFields(OutputFieldsDeclarer) - Method in class org.apache.flink.storm.wordcount.operators.WordCountInMemorySpout
 
Decline(String) - Constructor for class org.apache.flink.runtime.registration.RegistrationResponse.Decline
Creates a new rejection message.
declineCheckpoint(JobID, ExecutionAttemptID, long, Throwable) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointCoordinatorGateway
 
declineCheckpoint(long, Throwable) - Method in interface org.apache.flink.runtime.execution.Environment
Declines a checkpoint.
declineCheckpoint(JobID, ExecutionAttemptID, long, Throwable) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
DeclineCheckpoint - Class in org.apache.flink.runtime.messages.checkpoint
This message is sent from the TaskManager to the JobManager to tell the checkpoint coordinator that a checkpoint request could not be heeded.
DeclineCheckpoint(JobID, ExecutionAttemptID, long) - Constructor for class org.apache.flink.runtime.messages.checkpoint.DeclineCheckpoint
 
DeclineCheckpoint(JobID, ExecutionAttemptID, long, Throwable) - Constructor for class org.apache.flink.runtime.messages.checkpoint.DeclineCheckpoint
 
declineCheckpoint(JobID, ExecutionAttemptID, long, Throwable) - Method in class org.apache.flink.runtime.taskexecutor.rpc.RpcCheckpointResponder
 
declineCheckpoint(JobID, ExecutionAttemptID, long, Throwable) - Method in class org.apache.flink.runtime.taskmanager.ActorGatewayCheckpointResponder
 
declineCheckpoint(JobID, ExecutionAttemptID, long, Throwable) - Method in interface org.apache.flink.runtime.taskmanager.CheckpointResponder
Declines the given checkpoint.
declineCheckpoint(long, Throwable) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
decodeDynamicProperties(String) - Static method in class org.apache.flink.mesos.cli.FlinkMesosSessionCli
Decode encoded dynamic properties.
decorate(Object) - Method in class org.apache.flink.runtime.messages.LeaderSessionMessageDecorator
 
decorate(Object) - Method in interface org.apache.flink.runtime.messages.MessageDecorator
Decorates a message
decorateInputStream(FSDataInputStream, FileInputSplit) - Method in class org.apache.flink.api.common.io.FileInputFormat
This method allows to wrap/decorate the raw FSDataInputStream for a certain file split, e.g., for decoding.
decorateMessage(Object) - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
decorateMessage(Object) - Method in class org.apache.flink.runtime.akka.FlinkUntypedActor
This method should be called for every outgoing message.
decorateMessage(Object) - Method in interface org.apache.flink.runtime.FlinkActor
Factory method for messages.
decorateMessage(Object) - Static method in class org.apache.flink.runtime.jobmanager.JobManager
 
decorateMessage(Object) - Method in interface org.apache.flink.runtime.LeaderSessionMessageFilter
Wrap RequiresLeaderSessionID messages in a LeaderSessionMessage
decorateMessage(Object) - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
 
decorateMessage(Object) - Static method in class org.apache.flink.yarn.ApplicationClient
 
decorateMessage(Object) - Static method in class org.apache.flink.yarn.YarnTaskManager
 
decorrelate(SqlNode, RelNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
If sub-query is correlated and decorrelation is enabled, performs decorrelation.
decorrelateQuery(RelNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
 
decrement() - Method in class org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
Decrements the reference count and returns whether the reference counter entered the disposed state.
decrementReference(BatchTask<?, ?>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization
 
decrementReferenceIfHeld(BatchTask<?, ?>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization
 
DEFAULT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
DEFAULT operator indicates that an argument to a function call is to take its default value..
DEFAULT - Static variable in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
Default configuration.
DEFAULT - Static variable in class org.apache.flink.api.common.operators.ResourceSpec
 
DEFAULT() - Method in class org.apache.flink.table.api.TableConfig$
 
DEFAULT() - Static method in class org.apache.flink.table.api.TableConfig
 
DEFAULT() - Method in class org.apache.flink.table.calcite.CalciteConfig$
 
DEFAULT() - Method in class org.apache.flink.table.plan.nodes.datastream.AccModeTrait$
 
DEFAULT() - Static method in class org.apache.flink.table.plan.nodes.datastream.AccModeTrait
 
DEFAULT() - Method in class org.apache.flink.table.plan.nodes.datastream.UpdateAsRetractionTrait$
 
DEFAULT() - Static method in class org.apache.flink.table.plan.nodes.datastream.UpdateAsRetractionTrait
 
Default$() - Constructor for class org.apache.flink.ml.optimization.LearningRateMethod.Default$
 
DEFAULT_A - Static variable in class org.apache.flink.graph.generator.RMatGraph
 
DEFAULT_AKKA_ASK_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_AKKA_ASK_TIMEOUT - Static variable in class org.apache.flink.test.util.TestBaseUtils
 
DEFAULT_AKKA_CLIENT_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_AKKA_DISPATCHER_THROUGHPUT - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_AKKA_FRAMESIZE - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_AKKA_LOG_LIFECYCLE_EVENTS - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_AKKA_LOOKUP_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_AKKA_SSL_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_AKKA_STARTUP_TIMEOUT - Static variable in class org.apache.flink.test.util.TestBaseUtils
 
DEFAULT_AKKA_TRANSPORT_HEARTBEAT_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_AKKA_TRANSPORT_HEARTBEAT_PAUSE - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_AKKA_TRANSPORT_THRESHOLD - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_AKKA_WATCH_THRESHOLD - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_B - Static variable in class org.apache.flink.graph.generator.RMatGraph
 
DEFAULT_BLOB_FETCH_BACKLOG - Static variable in class org.apache.flink.configuration.ConfigConstants
Default BLOB fetch connection backlog.
DEFAULT_BLOB_FETCH_CONCURRENT - Static variable in class org.apache.flink.configuration.ConfigConstants
Default number of concurrent BLOB fetch operations.
DEFAULT_BLOB_FETCH_RETRIES - Static variable in class org.apache.flink.configuration.ConfigConstants
Default number of retries for failed BLOB fetches.
DEFAULT_BLOB_SERVER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
Default BLOB server port.
DEFAULT_BLOB_SERVICE_SSL_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
The default value to override ssl support for blob service transport
DEFAULT_C - Static variable in class org.apache.flink.graph.generator.RMatGraph
 
DEFAULT_CAPACITY_IN_BYTES - Static variable in class org.apache.flink.graph.types.valuearray.IntValueArray
 
DEFAULT_CAPACITY_IN_BYTES - Static variable in class org.apache.flink.graph.types.valuearray.LongValueArray
 
DEFAULT_CAPACITY_IN_BYTES - Static variable in class org.apache.flink.graph.types.valuearray.StringValueArray
 
DEFAULT_CHANNEL - Static variable in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditsSource
IRC channel to join
DEFAULT_CHARSET - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_DELIMITED_FORMAT_MAX_LINE_SAMPLES - Static variable in class org.apache.flink.configuration.ConfigConstants
The default maximum number of line samples taken by the delimited input format.
DEFAULT_DELIMITED_FORMAT_MAX_SAMPLE_LEN - Static variable in class org.apache.flink.configuration.ConfigConstants
The default maximum sample length before sampling is aborted (2 MiBytes).
DEFAULT_DELIMITED_FORMAT_MIN_LINE_SAMPLES - Static variable in class org.apache.flink.configuration.ConfigConstants
The default minimum number of line samples taken by the delimited input format.
DEFAULT_EDGES - Static variable in class org.apache.flink.graph.examples.data.ConnectedComponentsDefaultData
 
DEFAULT_EDGES - Static variable in class org.apache.flink.graph.examples.data.SingleSourceShortestPathsData
 
DEFAULT_EXECUTION_RETRIES - Static variable in class org.apache.flink.configuration.ConfigConstants
The default number of execution retries.
DEFAULT_FACTORY - Static variable in class org.apache.flink.runtime.state.SharedStateRegistry
A singleton object for the default implementation of a SharedStateRegistryFactory
DEFAULT_FIELD_DELIMITER - Static variable in class org.apache.flink.api.java.io.CsvInputFormat
 
DEFAULT_FIELD_DELIMITER - Static variable in class org.apache.flink.api.java.io.CsvOutputFormat
 
DEFAULT_FIELD_DELIMITER - Static variable in class org.apache.flink.api.scala.operators.ScalaCsvOutputFormat
 
DEFAULT_FILE_STATE_THRESHOLD - Static variable in class org.apache.flink.migration.runtime.state.filesystem.FsStateBackend
Deprecated.
By default, state smaller than 1024 bytes will not be written to files, but will be stored directly with the metadata
DEFAULT_FILE_STATE_THRESHOLD - Static variable in class org.apache.flink.runtime.state.filesystem.FsStateBackend
By default, state smaller than 1024 bytes will not be written to files, but will be stored directly with the metadata
DEFAULT_FILESYSTEM_ALWAYS_CREATE_DIRECTORY - Static variable in class org.apache.flink.configuration.ConfigConstants
The default behavior for output directory creating (create only directory when parallelism > 1).
DEFAULT_FILESYSTEM_OVERWRITE - Static variable in class org.apache.flink.configuration.ConfigConstants
The default behavior with respect to overwriting existing files (= not overwrite)
DEFAULT_FILESYSTEM_SCHEME - Static variable in class org.apache.flink.configuration.ConfigConstants
The default filesystem to be used, if no other scheme is specified in the user-provided URI (= local filesystem)
DEFAULT_FS_STREAM_OPENING_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
The default timeout for filesystem stream opening: infinite (means max long milliseconds).
DEFAULT_GET_PARTITIONS_RETRIES - Static variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer08
Default number of retries for getting the partition info.
DEFAULT_GROUP_SIZE - Static variable in class org.apache.flink.graph.library.similarity.JaccardIndex
 
DEFAULT_HA_JOB_MANAGER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
Default port used by the job manager if not in standalone recovery mode.
DEFAULT_HA_MODE - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_HA_ZOOKEEPER_CLIENT_ACL - Static variable in class org.apache.flink.configuration.ConfigConstants
ACL options supported "creator" or "open"
DEFAULT_HOST - Static variable in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditsSource
Hostname of the server to connect to.
DEFAULT_ID - Static variable in class org.apache.flink.storm.wrappers.BoltWrapper
The default input component ID.
DEFAULT_IN_SUB_QUERY_THRESHOLD - Static variable in class org.apache.calcite.sql2rel.SqlToRelConverter
Size of the smallest IN list that will be converted to a semijoin to a static table.
DEFAULT_IN_SUBQUERY_THRESHOLD - Static variable in class org.apache.calcite.sql2rel.SqlToRelConverter
Deprecated.
DEFAULT_JOB_ID - Static variable in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
This JobID should be used to identify the old JobManager when using the HighAvailabilityServices.
DEFAULT_JOB_MANAGER_IPC_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
The default network port to connect to for communication with the job manager.
DEFAULT_JOB_MANAGER_WEB_ARCHIVE_COUNT - Static variable in class org.apache.flink.configuration.ConfigConstants
The default number of archived jobs for the jobmanager
DEFAULT_JOB_MANAGER_WEB_BACK_PRESSURE_CLEAN_UP_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
Time after which cached stats are cleaned up.
DEFAULT_JOB_MANAGER_WEB_BACK_PRESSURE_DELAY - Static variable in class org.apache.flink.configuration.ConfigConstants
Delay between samples to determine back pressure.
DEFAULT_JOB_MANAGER_WEB_BACK_PRESSURE_NUM_SAMPLES - Static variable in class org.apache.flink.configuration.ConfigConstants
Number of samples to take to determine back pressure.
DEFAULT_JOB_MANAGER_WEB_BACK_PRESSURE_REFRESH_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
Time after which available stats are deprecated and need to be refreshed (by resampling).
DEFAULT_JOB_MANAGER_WEB_CHECKPOINTS_DISABLE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Config key has been deprecated. Therefore, no default value required.
DEFAULT_JOB_MANAGER_WEB_CHECKPOINTS_HISTORY_SIZE - Static variable in class org.apache.flink.configuration.ConfigConstants
Default number of checkpoints to remember for recent history.
DEFAULT_JOB_MANAGER_WEB_FRONTEND_ADDRESS - Static variable in class org.apache.flink.configuration.ConfigConstants
The config key for the address of the JobManager web frontend.
DEFAULT_JOB_MANAGER_WEB_FRONTEND_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
The config key for the port of the JobManager web frontend.
DEFAULT_JOB_MANAGER_WEB_FRONTEND_PORT - Static variable in class org.apache.flink.runtime.webmonitor.WebMonitorConfig
Default port for the web dashboard (= 8081)
DEFAULT_JOB_MANAGER_WEB_REFRESH_INTERVAL - Static variable in class org.apache.flink.runtime.webmonitor.WebMonitorConfig
Default refresh interval for the web dashboard (= 3000 msecs)
DEFAULT_JOB_MANAGER_WEB_SSL_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
Default value to override SSL support for the JobManager web UI
DEFAULT_JOB_MANAGER_WEB_SUBMIT_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
By default, submitting jobs from the web-frontend is allowed.
DEFAULT_JOB_NAME - Static variable in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
The default name to use for a streaming job if no other name has been specified.
DEFAULT_LEADER_ID - Static variable in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
This UUID should be used when no proper leader election happens, but a simple pre-configured leader is used.
DEFAULT_LIBRARY_CACHE_MANAGER_CLEANUP_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
The default library cache manager cleanup interval in seconds
DEFAULT_LINE_DELIMITER - Static variable in class org.apache.flink.api.java.io.CsvInputFormat
 
DEFAULT_LINE_DELIMITER - Static variable in class org.apache.flink.api.java.io.CsvOutputFormat
 
DEFAULT_LINE_DELIMITER - Static variable in class org.apache.flink.api.scala.operators.ScalaCsvOutputFormat
 
DEFAULT_LOCAL_NUMBER_JOB_MANAGER - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_LOCAL_NUMBER_RESOURCE_MANAGER - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_LOCAL_NUMBER_TASK_MANAGER - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_LOWER_BOUND_MAX_PARALLELISM - Static variable in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
The default lower bound for max parallelism if nothing was configured by the user.
DEFAULT_LOWER_BOUND_MAX_PARALLELISM - Static variable in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
DEFAULT_MAX_CONCURRENT_CHECKPOINTS - Static variable in class org.apache.flink.streaming.api.environment.CheckpointConfig
The default limit of concurrently happening checkpoints: one.
DEFAULT_MEMORY_MANAGER_MEMORY_FRACTION - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
TaskManagerOptions.MANAGED_MEMORY_FRACTION provides the default value now
DEFAULT_MESOS_ARTIFACT_SERVER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
The default network port to listen on for the Mesos artifact server.
DEFAULT_MESOS_ARTIFACT_SERVER_SSL_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
Default value to override SSL support for the Artifact Server
DEFAULT_MESOS_FAILOVER_TIMEOUT_SECS - Static variable in class org.apache.flink.configuration.ConfigConstants
The default failover timeout provided to Mesos (10 mins)
DEFAULT_MESOS_RESOURCEMANAGER_FRAMEWORK_NAME - Static variable in class org.apache.flink.configuration.ConfigConstants
The default Mesos framework name for the ResourceManager to use.
DEFAULT_MESOS_RESOURCEMANAGER_FRAMEWORK_ROLE - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_MESOS_RESOURCEMANAGER_FRAMEWORK_USER - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_METRICS_LATENCY_HISTORY_SIZE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_MIN_PAUSE_BETWEEN_CHECKPOINTS - Static variable in class org.apache.flink.streaming.api.environment.CheckpointConfig
The default minimum pause to be made between checkpoints: none.
DEFAULT_MODE - Static variable in class org.apache.flink.streaming.api.environment.CheckpointConfig
The default checkpoint mode: exactly once.
DEFAULT_NOISE - Static variable in class org.apache.flink.graph.generator.RMatGraph
 
DEFAULT_OPERATOR_STATE_NAME - Static variable in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
The default namespace for state in cases where no state name is provided
DEFAULT_PAGE_SIZE - Static variable in class org.apache.flink.runtime.memory.MemoryManager
The default memory page size.
DEFAULT_PARALLELISM - Static variable in class org.apache.flink.configuration.ConfigConstants
The default parallelism for operations.
DEFAULT_PARALLELISM - Static variable in class org.apache.flink.streaming.util.StreamingMultipleProgramsTestBase
 
DEFAULT_PARALLELISM - Static variable in class org.apache.flink.streaming.util.StreamingProgramTestBase
 
DEFAULT_PARALLELISM - Static variable in class org.apache.flink.test.util.MultipleProgramsTestBase
 
DEFAULT_PARALLELISM_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
The config parameter defining the default parallelism for jobs.
DEFAULT_PARALLELISM_KEY - Static variable in class org.apache.flink.configuration.CoreOptions
 
DEFAULT_POLL_TIMEOUT - Static variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
From Kafka's Javadoc: The time, in milliseconds, spent waiting in poll if data is not available.
DEFAULT_PORT - Static variable in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditsSource
Port of the server to connect to.
DEFAULT_PROCTIME_ATTRIBUTE() - Method in class org.apache.flink.table.api.TableEnvironment$
 
DEFAULT_PROCTIME_ATTRIBUTE() - Static method in class org.apache.flink.table.api.TableEnvironment
 
DEFAULT_RECOVERY_JOB_MANAGER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
DEFAULT_RECOVERY_MODE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Deprecated in favour of ConfigConstants.DEFAULT_HA_MODE
DEFAULT_REQUEST_TIMEOUT - Static variable in class org.apache.flink.runtime.webmonitor.WebRuntimeMonitor
By default, all requests to the JobManager have a timeout of 10 seconds
DEFAULT_RESOURCE_MANAGER_IPC_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
The default network port of the resource manager.
DEFAULT_RETRACTION_INSTANCE() - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamRetractionRules$
Rule instance that assigns default retraction to DataStreamRel nodes.
DEFAULT_RETRACTION_INSTANCE() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamRetractionRules
Rule instance that assigns default retraction to DataStreamRel nodes.
DEFAULT_ROWTIME_ATTRIBUTE() - Method in class org.apache.flink.table.api.TableEnvironment$
 
DEFAULT_ROWTIME_ATTRIBUTE() - Static method in class org.apache.flink.table.api.TableEnvironment
 
DEFAULT_RUNTIME_HASH_JOIN_BLOOM_FILTERS - Static variable in class org.apache.flink.configuration.ConfigConstants
Default setting for the switch for hash join bloom filters for spilled partitions.
DEFAULT_SECURITY_SSL_ALGORITHMS - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_SECURITY_SSL_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_SECURITY_SSL_PROTOCOL - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_SECURITY_SSL_VERIFY_HOSTNAME - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_SEED - Static variable in class org.apache.flink.graph.generator.random.JDKRandomGeneratorFactory
 
DEFAULT_SEED - Static variable in class org.apache.flink.graph.generator.random.MersenneTwisterFactory
 
DEFAULT_SORT_SPILLING_THRESHOLD - Static variable in class org.apache.flink.configuration.ConfigConstants
The default percentage of the sort memory to be full before data is spilled.
DEFAULT_SORT_SPILLING_THRESHOLD_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Key for the default spilling threshold.
DEFAULT_SPILLING_MAX_FAN - Static variable in class org.apache.flink.configuration.ConfigConstants
The default value for the maximum spilling fan in/out.
DEFAULT_SPILLING_MAX_FAN_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Parameter for the maximum fan for out-of-core algorithms.
DEFAULT_STATE_BACKEND - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_TASK_CANCELLATION_INTERVAL_MILLIS - Static variable in class org.apache.flink.configuration.ConfigConstants
DEFAULT_TASK_MANAGER_DATA_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
The default network port the task manager expects to receive transfer envelopes on.
DEFAULT_TASK_MANAGER_DATA_SSL_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
The default value to override ssl support for task manager's data transport
DEFAULT_TASK_MANAGER_DEBUG_MEMORY_USAGE_LOG_INTERVAL_MS - Static variable in class org.apache.flink.configuration.ConfigConstants
The interval (in ms) for the log thread to log the current memory usage.
DEFAULT_TASK_MANAGER_DEBUG_MEMORY_USAGE_START_LOG_THREAD - Static variable in class org.apache.flink.configuration.ConfigConstants
Flag indicating whether to start a thread, which repeatedly logs the memory usage of the JVM.
DEFAULT_TASK_MANAGER_INITIAL_REGISTRATION_PAUSE - Static variable in class org.apache.flink.configuration.ConfigConstants
The default task manager's initial registration pause.
DEFAULT_TASK_MANAGER_IPC_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
The default network port the task manager expects incoming IPC connections.
DEFAULT_TASK_MANAGER_MAX_REGISTRATION_DURATION - Static variable in class org.apache.flink.configuration.ConfigConstants
The default task manager's maximum registration duration
DEFAULT_TASK_MANAGER_MAX_REGISTRATION_PAUSE - Static variable in class org.apache.flink.configuration.ConfigConstants
The default task manager's maximum registration pause.
DEFAULT_TASK_MANAGER_MEMORY_PRE_ALLOCATE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
TaskManagerOptions.MANAGED_MEMORY_PRE_ALLOCATE provides the default value now
DEFAULT_TASK_MANAGER_MEMORY_SEGMENT_SIZE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
TaskManagerOptions.MEMORY_SEGMENT_SIZE provides the default value now
DEFAULT_TASK_MANAGER_NETWORK_DEFAULT_IO_MODE - Static variable in class org.apache.flink.configuration.ConfigConstants
The implementation to use for spillable/spilled intermediate results, which have both synchronous and asynchronous implementations: "sync" or "async".
DEFAULT_TASK_MANAGER_NETWORK_NUM_BUFFERS - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
TaskManagerOptions.NETWORK_NUM_BUFFERS provides the default value now
DEFAULT_TASK_MANAGER_REFUSED_REGISTRATION_PAUSE - Static variable in class org.apache.flink.configuration.ConfigConstants
The default task manager's refused registration pause.
DEFAULT_TASK_MANAGER_TMP_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
The default directory for temporary files of the task manager.
DEFAULT_TIMEOUT - Static variable in class org.apache.flink.streaming.api.environment.CheckpointConfig
The default timeout of a checkpoint attempt: 10 minutes.
DEFAULT_TIMEOUT - Static variable in class org.apache.flink.test.util.TestBaseUtils
 
DEFAULT_UNDEFINED - Static variable in class org.apache.flink.api.java.utils.ParameterTool
 
DEFAULT_USE_LARGE_RECORD_HANDLER - Static variable in class org.apache.flink.configuration.ConfigConstants
Whether to use the LargeRecordHandler when spilling.
DEFAULT_YARN_APPLICATION_MASTER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Not used anymore, but remain here until Flink 2.0
DEFAULT_YARN_CONTAINER_START_COMMAND_TEMPLATE - Static variable in class org.apache.flink.configuration.ConfigConstants
Start command template for Flink on YARN containers
DEFAULT_YARN_HEAP_CUTOFF - Static variable in class org.apache.flink.configuration.ConfigConstants
Minimum amount of memory to subtract from the process memory to get the TaskManager heap size.
DEFAULT_YARN_HEAP_CUTOFF_RATIO - Static variable in class org.apache.flink.configuration.ConfigConstants
Relative amount of memory to subtract from Java process memory to get the TaskManager heap size
DEFAULT_YARN_HEARTBEAT_DELAY() - Method in class org.apache.flink.yarn.YarnJobManager
 
DEFAULT_YARN_JOB_MANAGER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
Default port for the application master is 0, which means the operating system assigns an ephemeral port
DEFAULT_YARN_MIN_HEAP_CUTOFF - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Not used anymore, but remain here until Flink 2.0
DEFAULT_ZOOKEEPER_CHECKPOINT_COUNTER_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_ZOOKEEPER_CHECKPOINTS_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_ZOOKEEPER_CLIENT_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
ZooKeeper default client port.
DEFAULT_ZOOKEEPER_CLIENT_PORT - Static variable in class org.apache.flink.runtime.zookeeper.FlinkZooKeeperQuorumPeer
ZooKeeper default client port.
DEFAULT_ZOOKEEPER_CONNECTION_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_ZOOKEEPER_DIR_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_ZOOKEEPER_INIT_LIMIT - Static variable in class org.apache.flink.configuration.ConfigConstants
ZooKeeper default init limit.
DEFAULT_ZOOKEEPER_INIT_LIMIT - Static variable in class org.apache.flink.runtime.zookeeper.FlinkZooKeeperQuorumPeer
ZooKeeper default init limit.
DEFAULT_ZOOKEEPER_JOBGRAPHS_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_ZOOKEEPER_LATCH_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_ZOOKEEPER_LEADER_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_ZOOKEEPER_LEADER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
ZooKeeper default leader port.
DEFAULT_ZOOKEEPER_LEADER_PORT - Static variable in class org.apache.flink.runtime.zookeeper.FlinkZooKeeperQuorumPeer
ZooKeeper default leader port.
DEFAULT_ZOOKEEPER_MAX_RETRY_ATTEMPTS - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_ZOOKEEPER_MESOS_WORKERS_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_ZOOKEEPER_NAMESPACE_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_ZOOKEEPER_PEER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
ZooKeeper default peer port.
DEFAULT_ZOOKEEPER_PEER_PORT - Static variable in class org.apache.flink.runtime.zookeeper.FlinkZooKeeperQuorumPeer
ZooKeeper default peer port.
DEFAULT_ZOOKEEPER_RETRY_WAIT - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_ZOOKEEPER_SASL_DISABLE - Static variable in class org.apache.flink.configuration.ConfigConstants
Defaults for ZK client security
DEFAULT_ZOOKEEPER_SESSION_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
 
DEFAULT_ZOOKEEPER_SYNC_LIMIT - Static variable in class org.apache.flink.configuration.ConfigConstants
ZooKeeper default sync limit.
DEFAULT_ZOOKEEPER_SYNC_LIMIT - Static variable in class org.apache.flink.runtime.zookeeper.FlinkZooKeeperQuorumPeer
ZooKeeper default sync limit.
DefaultBroadcastVariableInitializer<T> - Class in org.apache.flink.runtime.broadcast
 
DefaultCLI - Class in org.apache.flink.client.cli
The default CLI which is used for interaction with standalone clusters.
DefaultCLI() - Constructor for class org.apache.flink.client.cli.DefaultCLI
 
DefaultCostEstimator - Class in org.apache.flink.optimizer.costs
A default cost estimator that has access to basic size and cardinality estimates.
DefaultCostEstimator() - Constructor for class org.apache.flink.optimizer.costs.DefaultCostEstimator
 
DefaultCross(DataSet<I1>, DataSet<I2>, CrossOperatorBase.CrossHint, String) - Constructor for class org.apache.flink.api.java.operators.CrossOperator.DefaultCross
 
DefaultCrossFunction() - Constructor for class org.apache.flink.api.java.operators.CrossOperator.DefaultCrossFunction
 
defaultData - Variable in class org.apache.flink.api.java.utils.ParameterTool
 
defaultEvaluateDataSetOperation(PredictOperation<Instance, Model, Testing, PredictionValue>, TypeInformation<Testing>, TypeInformation<PredictionValue>) - Method in class org.apache.flink.ml.pipeline.Predictor$
Default EvaluateDataSetOperation which takes a PredictOperation to calculate a tuple of true label value and predicted label value.
DefaultFlatJoinFunction() - Constructor for class org.apache.flink.api.java.operators.JoinOperator.DefaultFlatJoinFunction
 
DefaultInputSplitAssigner - Class in org.apache.flink.api.common.io
This is the default implementation of the InputSplitAssigner interface.
DefaultInputSplitAssigner(InputSplit[]) - Constructor for class org.apache.flink.api.common.io.DefaultInputSplitAssigner
 
DefaultInputSplitAssigner(Collection<? extends InputSplit>) - Constructor for class org.apache.flink.api.common.io.DefaultInputSplitAssigner
 
DefaultJoin(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, JoinOperatorBase.JoinHint, String, JoinType) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.DefaultJoin
 
DefaultKeyedStateStore - Class in org.apache.flink.runtime.state
Default implementation of KeyedStateStore that currently forwards state registration to a RuntimeContext.
DefaultKeyedStateStore(KeyedStateBackend<?>, ExecutionConfig) - Constructor for class org.apache.flink.runtime.state.DefaultKeyedStateStore
 
DefaultLocalClusterFactory() - Constructor for class org.apache.flink.storm.api.FlinkLocalCluster.DefaultLocalClusterFactory
 
defaultMetricRegistryConfiguration() - Static method in class org.apache.flink.runtime.metrics.MetricRegistryConfiguration
 
defaultName - Variable in class org.apache.flink.api.java.operators.FilterOperator
 
defaultName - Variable in class org.apache.flink.api.java.operators.FlatMapOperator
 
defaultName - Variable in class org.apache.flink.api.java.operators.MapOperator
 
defaultName - Variable in class org.apache.flink.api.java.operators.MapPartitionOperator
 
DefaultOperatorStateBackend - Class in org.apache.flink.runtime.state
Default implementation of OperatorStateStore that provides the ability to make snapshots.
DefaultOperatorStateBackend(ClassLoader, ExecutionConfig, boolean) - Constructor for class org.apache.flink.runtime.state.DefaultOperatorStateBackend
 
defaultParallelism - Variable in class org.apache.flink.api.common.Plan
The default parallelism to use for nodes that have no explicitly specified parallelism.
defaultPredictDataSetOperation(PredictOperation<Instance, Model, Testing, PredictionValue>, TypeInformation<Testing>, TypeInformation<PredictionValue>) - Method in class org.apache.flink.ml.pipeline.Predictor$
Default PredictDataSetOperation which takes a PredictOperation to calculate a tuple of testing element and its prediction value.
DefaultQuarantineHandler - Class in org.apache.flink.runtime.akka
Default quarantine handler which logs the quarantining events, then shuts down the given actor system by sending Kill to all actors and then shutting the JVM down with the given exit code.
DefaultQuarantineHandler(Time, int, Logger) - Constructor for class org.apache.flink.runtime.akka.DefaultQuarantineHandler
 
defaultSavepointDir() - Method in class org.apache.flink.runtime.jobmanager.JobManager
The default directory for savepoints.
defaultSchema() - Method in class org.apache.flink.table.calcite.FlinkPlannerImpl
 
defaultTopicId - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
The name of the default topic this producer is writing data to.
defaultTransformDataSetOperation(TransformOperation<Instance, Model, Input, Output>, TypeInformation<Output>, ClassTag<Output>) - Method in class org.apache.flink.ml.pipeline.Transformer$
 
defaultValue - Variable in class org.apache.flink.api.common.state.StateDescriptor
The default value returned by the state when no other value is bound to a key
defaultValue(String) - Method in class org.apache.flink.api.java.utils.Option
Define a default value for the option.
defaultValue() - Method in class org.apache.flink.configuration.ConfigOption
Returns the default value, or null, if there is no default value.
defaultValue(T) - Method in class org.apache.flink.configuration.ConfigOptions.OptionBuilder
Creates a ConfigOption with the given default value.
defaultValue - Variable in class org.apache.flink.graph.drivers.parameter.SimpleParameter
 
defaultValue() - Method in class org.apache.flink.ml.classification.SVM.Blocks$
 
defaultValue() - Method in class org.apache.flink.ml.classification.SVM.Iterations$
 
defaultValue() - Method in class org.apache.flink.ml.classification.SVM.LocalIterations$
 
defaultValue() - Method in class org.apache.flink.ml.classification.SVM.OutputDecisionFunction$
 
defaultValue() - Method in class org.apache.flink.ml.classification.SVM.Regularization$
 
defaultValue() - Method in class org.apache.flink.ml.classification.SVM.Seed$
 
defaultValue() - Method in class org.apache.flink.ml.classification.SVM.Stepsize$
 
defaultValue() - Method in class org.apache.flink.ml.classification.SVM.ThresholdValue$
 
defaultValue() - Method in interface org.apache.flink.ml.common.Parameter
Default value of parameter.
defaultValue() - Method in class org.apache.flink.ml.nn.KNN.Blocks$
 
defaultValue() - Method in class org.apache.flink.ml.nn.KNN.DistanceMetric$
 
defaultValue() - Method in class org.apache.flink.ml.nn.KNN.K$
 
defaultValue() - Method in class org.apache.flink.ml.nn.KNN.SizeHint$
 
defaultValue() - Method in class org.apache.flink.ml.nn.KNN.UseQuadTree$
 
defaultValue() - Method in class org.apache.flink.ml.optimization.IterativeSolver.ConvergenceThreshold$
 
defaultValue() - Method in class org.apache.flink.ml.optimization.IterativeSolver.Iterations$
 
defaultValue() - Method in class org.apache.flink.ml.optimization.IterativeSolver.LearningRate$
 
defaultValue() - Method in class org.apache.flink.ml.optimization.IterativeSolver.LearningRateMethodValue$
 
defaultValue() - Method in class org.apache.flink.ml.optimization.Solver.LossFunction$
 
defaultValue() - Method in class org.apache.flink.ml.optimization.Solver.RegularizationConstant$
 
defaultValue() - Method in class org.apache.flink.ml.optimization.Solver.RegularizationPenaltyValue$
 
defaultValue() - Method in class org.apache.flink.ml.outlier.StochasticOutlierSelection.ErrorTolerance$
 
defaultValue() - Method in class org.apache.flink.ml.outlier.StochasticOutlierSelection.MaxIterations$
 
defaultValue() - Method in class org.apache.flink.ml.outlier.StochasticOutlierSelection.Perplexity$
 
defaultValue() - Method in class org.apache.flink.ml.preprocessing.MinMaxScaler.Max$
 
defaultValue() - Method in class org.apache.flink.ml.preprocessing.MinMaxScaler.Min$
 
defaultValue() - Method in class org.apache.flink.ml.preprocessing.PolynomialFeatures.Degree$
 
defaultValue() - Method in class org.apache.flink.ml.preprocessing.StandardScaler.Mean$
 
defaultValue() - Method in class org.apache.flink.ml.preprocessing.StandardScaler.Std$
 
defaultValue() - Method in class org.apache.flink.ml.recommendation.ALS.Blocks$
 
defaultValue() - Method in class org.apache.flink.ml.recommendation.ALS.Iterations$
 
defaultValue() - Method in class org.apache.flink.ml.recommendation.ALS.Lambda$
 
defaultValue() - Method in class org.apache.flink.ml.recommendation.ALS.NumFactors$
 
defaultValue() - Method in class org.apache.flink.ml.recommendation.ALS.Seed$
 
defaultValue() - Method in class org.apache.flink.ml.recommendation.ALS.TemporaryPath$
 
defaultValue() - Method in class org.apache.flink.ml.regression.MultipleLinearRegression.ConvergenceThreshold$
 
defaultValue() - Method in class org.apache.flink.ml.regression.MultipleLinearRegression.Iterations$
 
defaultValue() - Method in class org.apache.flink.ml.regression.MultipleLinearRegression.LearningRateMethodValue$
 
defaultValue() - Method in class org.apache.flink.ml.regression.MultipleLinearRegression.Stepsize$
 
DefinedFieldNames - Interface in org.apache.flink.table.sources
Trait that defines custom field names and their indices in the underlying data type.
DefinedProctimeAttribute - Interface in org.apache.flink.table.sources
Defines a logical processing-time attribute for a TableSource.
DefinedRowtimeAttribute - Interface in org.apache.flink.table.sources
Defines a logical event-time attribute for a TableSource.
DeflateInflaterInputStreamFactory - Class in org.apache.flink.api.common.io.compression
Factory for input streams that decompress the "deflate" compression format.
DeflateInflaterInputStreamFactory() - Constructor for class org.apache.flink.api.common.io.compression.DeflateInflaterInputStreamFactory
 
DEFUALT_BOLT_NAME - Static variable in class org.apache.flink.storm.wrappers.BoltWrapper
The default bolt ID.
Degree$() - Constructor for class org.apache.flink.ml.preprocessing.PolynomialFeatures.Degree$
 
DegreeAnnotationFunctions - Class in org.apache.flink.graph.asm.degree.annotate
 
DegreeAnnotationFunctions() - Constructor for class org.apache.flink.graph.asm.degree.annotate.DegreeAnnotationFunctions
 
DegreeAnnotationFunctions.DegreeCount<K> - Class in org.apache.flink.graph.asm.degree.annotate
Combines the vertex degree count.
DegreeAnnotationFunctions.JoinEdgeDegreeWithVertexDegree<K,EV,D> - Class in org.apache.flink.graph.asm.degree.annotate
Composes the vertex degree with this edge value.
DegreeAnnotationFunctions.JoinEdgeWithVertexDegree<K,EV,D> - Class in org.apache.flink.graph.asm.degree.annotate
Assigns the vertex degree to this edge value.
DegreeAnnotationFunctions.JoinVertexWithVertexDegree<K,VV> - Class in org.apache.flink.graph.asm.degree.annotate
Performs a left outer join to apply a zero count for vertices with out- or in-degree of zero.
DegreeAnnotationFunctions.MapEdgeToSourceId<K,EV> - Class in org.apache.flink.graph.asm.degree.annotate
Emits the source vertex ID along with an initial count.
DegreeAnnotationFunctions.MapEdgeToTargetId<K,EV> - Class in org.apache.flink.graph.asm.degree.annotate
Emits the target vertex ID along with an initial count.
DegreeCount() - Constructor for class org.apache.flink.graph.asm.degree.annotate.DegreeAnnotationFunctions.DegreeCount
 
DEGREES - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
Degrees() - Constructor for class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees.Degrees
 
Degrees(LongValue, LongValue, LongValue) - Constructor for class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees.Degrees
 
degrees() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Converts numeric from radians to degrees.
DEGREES() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
DEGREES() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
Degrees - Class in org.apache.flink.table.expressions
 
Degrees(Expression) - Constructor for class org.apache.flink.table.expressions.Degrees
 
Degrees$ - Class in org.apache.flink.table.expressions
 
Degrees$() - Constructor for class org.apache.flink.table.expressions.Degrees$
 
DEGREES_DEC() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
DEGREES_DEC() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
delayBetweenSamples() - Method in class org.apache.flink.runtime.messages.StackTraceSampleMessages.SampleTaskStackTrace
 
delayBetweenSamples() - Method in class org.apache.flink.runtime.messages.StackTraceSampleMessages.TriggerStackTraceSample
 
delegate - Variable in class org.apache.flink.core.fs.AbstractMultiFSDataInputStream
Inner stream for the currently accessed segment of the virtual global stream
delegate - Variable in class org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
 
DelegatingConfiguration - Class in org.apache.flink.configuration
A configuration that manages a subset of keys with a common prefix from a given configuration.
DelegatingConfiguration() - Constructor for class org.apache.flink.configuration.DelegatingConfiguration
Default constructor for serialization.
DelegatingConfiguration(Configuration, String) - Constructor for class org.apache.flink.configuration.DelegatingConfiguration
Creates a new delegating configuration which stores its key/value pairs in the given configuration using the specifies key prefix.
delete(Path, boolean) - Method in class org.apache.flink.core.fs.FileSystem
Delete a file.
delete(Path, boolean) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
delete(Path, boolean) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
delete(BlobKey) - Method in class org.apache.flink.runtime.blob.BlobCache
Deletes the file associated with the given key from the BLOB cache.
delete(BlobKey) - Method in class org.apache.flink.runtime.blob.BlobClient
Deletes the BLOB identified by the given BLOB key from the BLOB server.
delete(JobID, String) - Method in class org.apache.flink.runtime.blob.BlobClient
Deletes the BLOB identified by the given job ID and key from the BLOB server.
delete(BlobKey) - Method in class org.apache.flink.runtime.blob.BlobServer
This method deletes the file associated to the blob key if it exists in the local storage of the blob server.
delete(BlobKey) - Method in interface org.apache.flink.runtime.blob.BlobService
This method deletes the file associated with the provided blob key.
delete(BlobKey) - Method in interface org.apache.flink.runtime.blob.BlobStore
Tries to delete a blob from storage.
delete(JobID, String) - Method in interface org.apache.flink.runtime.blob.BlobStore
Tries to delete a blob from storage.
delete(BlobKey) - Method in class org.apache.flink.runtime.blob.FileSystemBlobStore
 
delete(JobID, String) - Method in class org.apache.flink.runtime.blob.FileSystemBlobStore
 
delete(BlobKey) - Method in class org.apache.flink.runtime.blob.VoidBlobStore
 
delete(JobID, String) - Method in class org.apache.flink.runtime.blob.VoidBlobStore
 
delete(Path, boolean) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
 
delete(Path, boolean) - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
 
deleteAll(JobID) - Method in class org.apache.flink.runtime.blob.BlobClient
Deletes all BLOBs belonging to the job with the given ID from the BLOB server
deleteAll(JobID) - Method in interface org.apache.flink.runtime.blob.BlobStore
Tries to delete all blobs for the given job from storage.
deleteAll(JobID) - Method in class org.apache.flink.runtime.blob.FileSystemBlobStore
 
deleteAll(JobID) - Method in class org.apache.flink.runtime.blob.VoidBlobStore
 
deleteChannel() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
 
deleteChannel() - Method in interface org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
Deletes the file underlying this I/O channel.
deleteChannel(FileIOChannel.ID) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
Deletes the file underlying the given channel.
deleteCleanupTimer(W) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
Deletes the cleanup timer set for the contents of the provided window.
deleteDirectory(File) - Static method in class org.apache.flink.util.FileUtils
Deletes the given directory recursively.
deleteDirectoryQuietly(File) - Static method in class org.apache.flink.util.FileUtils
Deletes the given directory recursively, not reporting any I/O exceptions that occur.
deleteEventTimeTimer(N, long) - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
 
deleteEventTimeTimer(N, long) - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
Deletes the timer for the given key and namespace.
deleteEventTimeTimer(long) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
Delete the event-time trigger for the given time.
deleteEventTimeTimer(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
deleteExtractedLibraries() - Method in class org.apache.flink.client.program.PackagedProgram
Deletes all temporary files created for contained packaged libraries.
deleteExtractedLibraries(List<File>) - Static method in class org.apache.flink.client.program.PackagedProgram
 
deleteFileOrDirectory(File) - Static method in class org.apache.flink.util.FileUtils
Removes the given file or directory recursively.
deleteGlobal(BlobKey) - Method in class org.apache.flink.runtime.blob.BlobCache
Deletes the file associated with the given key from the BLOB cache and BLOB server.
deleteOnCancellation() - Method in class org.apache.flink.runtime.jobgraph.tasks.ExternalizedCheckpointSettings
Returns true if externalized checkpoints should be deleted on cancellation.
deleteOnCancellation() - Method in enum org.apache.flink.streaming.api.environment.CheckpointConfig.ExternalizedCheckpointCleanup
Returns whether persistent checkpoints shall be discarded on cancellation of the job.
deletePathIfEmpty(FileSystem, Path) - Static method in class org.apache.flink.util.FileUtils
Deletes the path if it is empty.
deleteProcessingTimeTimer(N, long) - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
 
deleteProcessingTimeTimer(N, long) - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
Deletes the timer for the given key and namespace.
deleteProcessingTimeTimer(long) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
Delete the processing time trigger for the given time.
deleteProcessingTimeTimer(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
deleteRecursively(File) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
deleteSavepointDirectory(String) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointStore
Deletes a savepoint directory.
deleteTmpFile(String, JobID) - Method in class org.apache.flink.runtime.filecache.FileCache
Deletes the local file after a 5 second delay.
DELIMITED_FORMAT_MAX_LINE_SAMPLES_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
The maximum number of line samples to be taken by the delimited input format, if no other value is specified for the data source.
DELIMITED_FORMAT_MAX_SAMPLE_LENGTH_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
The maximum length of a single sampled record before the sampling is aborted.
DELIMITED_FORMAT_MIN_LINE_SAMPLES_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
The minimum number of line samples to be taken by the delimited input format, if no other value is specified for the data source.
DelimitedInputFormat<OT> - Class in org.apache.flink.api.common.io
Base implementation for input formats that split the input at a delimiter into records.
DelimitedInputFormat() - Constructor for class org.apache.flink.api.common.io.DelimitedInputFormat
 
DelimitedInputFormat(Path, Configuration) - Constructor for class org.apache.flink.api.common.io.DelimitedInputFormat
 
delimiterNext(byte[], int, byte[]) - Static method in class org.apache.flink.types.parser.FieldParser
Checks if the delimiter starts at the given start position of the byte array.
delta() - Method in class org.apache.flink.api.java.summarize.aggregation.CompensatedSum
The correction term
DELTA - Static variable in class org.apache.flink.graph.examples.data.CommunityDetectionData
 
DeltaEvictor<T,W extends Window> - Class in org.apache.flink.streaming.api.windowing.evictors
An Evictor that keeps elements based on a DeltaFunction and a threshold.
DeltaFunction<DATA> - Interface in org.apache.flink.streaming.api.functions.windowing.delta
This interface allows the implementation of a function which calculates the delta between two data points.
DeltaIteration<ST,WT> - Class in org.apache.flink.api.java.operators
The DeltaIteration represents the start of a delta iteration.
DeltaIteration(ExecutionEnvironment, TypeInformation<ST>, DataSet<ST>, DataSet<WT>, Keys<ST>, int) - Constructor for class org.apache.flink.api.java.operators.DeltaIteration
 
DeltaIteration.SolutionSetPlaceHolder<ST> - Class in org.apache.flink.api.java.operators
A DataSet that acts as a placeholder for the solution set during the iteration.
DeltaIteration.WorksetPlaceHolder<WT> - Class in org.apache.flink.api.java.operators
A DataSet that acts as a placeholder for the workset during the iteration.
DeltaIterationBase<ST,WT> - Class in org.apache.flink.api.common.operators.base
A DeltaIteration is similar to a BulkIterationBase, but maintains state across the individual iteration steps.
DeltaIterationBase(BinaryOperatorInformation<ST, WT, ST>, int) - Constructor for class org.apache.flink.api.common.operators.base.DeltaIterationBase
 
DeltaIterationBase(BinaryOperatorInformation<ST, WT, ST>, int[]) - Constructor for class org.apache.flink.api.common.operators.base.DeltaIterationBase
 
DeltaIterationBase(BinaryOperatorInformation<ST, WT, ST>, int, String) - Constructor for class org.apache.flink.api.common.operators.base.DeltaIterationBase
 
DeltaIterationBase(BinaryOperatorInformation<ST, WT, ST>, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.DeltaIterationBase
 
DeltaIterationBase.SolutionSetPlaceHolder<ST> - Class in org.apache.flink.api.common.operators.base
Specialized operator to use as a recognizable place-holder for the solution set input to the step function.
DeltaIterationBase.WorksetPlaceHolder<WT> - Class in org.apache.flink.api.common.operators.base
Specialized operator to use as a recognizable place-holder for the working set input to the step function.
DeltaIterationResultSet<ST,WT> - Class in org.apache.flink.api.java.operators
 
DeltaPageRank - Class in org.apache.flink.examples.scala.graph
 
DeltaPageRank() - Constructor for class org.apache.flink.examples.scala.graph.DeltaPageRank
 
DeltaPageRank$ - Class in org.apache.flink.examples.scala.graph
 
DeltaPageRank$() - Constructor for class org.apache.flink.examples.scala.graph.DeltaPageRank$
 
DeltaTrigger<T,W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
A Trigger that fires based on a DeltaFunction and a threshold.
DENSE_RANK - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
DENSE_RANK window function.
DenseMatrix - Class in org.apache.flink.ml.math
Dense matrix implementation of Matrix.
DenseMatrix(int, int, double[]) - Constructor for class org.apache.flink.ml.math.DenseMatrix
 
DenseMatrix$ - Class in org.apache.flink.ml.math
 
DenseMatrix$() - Constructor for class org.apache.flink.ml.math.DenseMatrix$
 
DenseVector - Class in org.apache.flink.ml.math
Dense vector implementation of Vector.
DenseVector(double[]) - Constructor for class org.apache.flink.ml.math.DenseVector
 
DenseVector$ - Class in org.apache.flink.ml.math
 
DenseVector$() - Constructor for class org.apache.flink.ml.math.DenseVector$
 
denseVectorBuilder() - Method in class org.apache.flink.ml.math.VectorBuilder$
Type class implementation for DenseVector
denseVectorConverter() - Method in class org.apache.flink.ml.math.DenseVector$
BreezeVectorConverter implementation for DenseVector
denseVectorConverter() - Static method in class org.apache.flink.ml.math.DenseVector
BreezeVectorConverter implementation for DenseVector
DependencyVisitor - Class in org.apache.flink.runtime.util
This class tracks class dependency with ASM visitors.
DependencyVisitor(int) - Constructor for class org.apache.flink.runtime.util.DependencyVisitor
 
DependencyVisitor.AnnotationVisitorImpl - Class in org.apache.flink.runtime.util
 
DependencyVisitor.FieldVisitorImpl - Class in org.apache.flink.runtime.util
 
DependencyVisitor.MethodVisitorImpl - Class in org.apache.flink.runtime.util
 
DependencyVisitor.SignatureVisitorImpl - Class in org.apache.flink.runtime.util
 
deploy() - Method in interface org.apache.flink.client.deployment.ClusterDescriptor
Triggers deployment of a cluster
deploy() - Method in class org.apache.flink.client.deployment.StandaloneClusterDescriptor
 
deploy() - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
 
deployInternal() - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
This method will block until the ApplicationMaster/JobManager have been deployed on YARN.
deployNewYarnCluster(FlinkShell.YarnConfig) - Method in class org.apache.flink.api.scala.FlinkShell$
 
deployNewYarnCluster(FlinkShell.YarnConfig) - Static method in class org.apache.flink.api.scala.FlinkShell
 
deployToSlot(SimpleSlot) - Method in class org.apache.flink.runtime.executiongraph.Execution
 
deployToSlot(SimpleSlot) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
deprecatedKeys() - Method in class org.apache.flink.configuration.ConfigOption
Gets the deprecated keys, in the order to be checked.
depth() - Method in class org.apache.flink.core.fs.Path
Returns the number of elements in this path.
deregisterConverterRule(RelOptPlanner, ConverterRule) - Static method in class org.apache.flink.table.plan.nodes.datastream.AccModeTraitDef
 
deregisterConverterRule(RelOptPlanner, ConverterRule) - Static method in class org.apache.flink.table.plan.nodes.datastream.UpdateAsRetractionTraitDef
 
derivative(double, double) - Method in class org.apache.flink.ml.optimization.HingeLoss$
Calculates the derivative of the loss function with respect to the prediction
derivative(double, double) - Static method in class org.apache.flink.ml.optimization.HingeLoss
Calculates the derivative of the loss function with respect to the prediction
derivative(double, double) - Method in class org.apache.flink.ml.optimization.LogisticLoss$
Calculates the derivative of the loss function with respect to the prediction
derivative(double, double) - Static method in class org.apache.flink.ml.optimization.LogisticLoss
Calculates the derivative of the loss function with respect to the prediction
derivative(double, double) - Method in interface org.apache.flink.ml.optimization.PartialLossFunction
Calculates the derivative of the PartialLossFunction
derivative(double, double) - Method in class org.apache.flink.ml.optimization.SquaredLoss$
Calculates the derivative of the PartialLossFunction
derivative(double, double) - Static method in class org.apache.flink.ml.optimization.SquaredLoss
Calculates the derivative of the PartialLossFunction
deriveRowType() - Method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
deriveRowType() - Method in class org.apache.flink.table.plan.nodes.dataset.BatchTableSourceScan
 
deriveRowType() - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetAggregate
 
deriveRowType() - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetCalc
 
deriveRowType() - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetCorrelate
 
deriveRowType() - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetDistinct
 
deriveRowType() - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetIntersect
 
deriveRowType() - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetJoin
 
deriveRowType() - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetMinus
 
deriveRowType() - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetScan
 
deriveRowType() - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetSingleRowJoin
 
deriveRowType() - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetSort
 
deriveRowType() - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetUnion
 
deriveRowType() - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetValues
 
deriveRowType() - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetWindowAggregate
 
deriveRowType() - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamCalc
 
deriveRowType() - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamCorrelate
 
deriveRowType() - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupAggregate
 
deriveRowType() - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
deriveRowType() - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamOverAggregate
 
deriveRowType() - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamScan
 
deriveRowType() - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamUnion
 
deriveRowType() - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamValues
 
deriveRowType() - Method in class org.apache.flink.table.plan.nodes.datastream.StreamTableSourceScan
 
deriveRowType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
deriveRowType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
deriveRowType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
deriveRowType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
deriveRowType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
deriveRowType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
deriveRowType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
deriveRowType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
deriveRowType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
deriveRowType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
deriveRowType() - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
deriveRowType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
deriveRowType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
deriveRowType() - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
deriveRowType() - Method in class org.apache.flink.table.plan.nodes.PhysicalTableSourceScan
 
deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
deriveType(SqlValidator, SqlValidatorScope, SqlCall) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
DESC - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
desc() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.FieldDescriptor
 
desc() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Specifies descending order of an expression i.e.
desc(RexNode) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
Desc - Class in org.apache.flink.table.expressions
 
Desc(Expression) - Constructor for class org.apache.flink.table.expressions.Desc
 
DESC() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
DESC() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
Desc$ - Class in org.apache.flink.table.expressions
 
Desc$() - Constructor for class org.apache.flink.table.expressions.Desc$
 
description() - Method in class org.apache.flink.runtime.messages.TaskManagerMessages.FatalError
 
DeserializationDelegate<T> - Interface in org.apache.flink.runtime.plugable
 
DeserializationException - Exception in org.apache.flink.types
An exception specifying that the deserialization caused an error.
DeserializationException() - Constructor for exception org.apache.flink.types.DeserializationException
Constructs an DeserializationException with null as its error detail message.
DeserializationException(String, Throwable) - Constructor for exception org.apache.flink.types.DeserializationException
Constructs an DeserializationException with the specified detail message and cause.
DeserializationException(String) - Constructor for exception org.apache.flink.types.DeserializationException
Constructs an DeserializationException with the specified detail message.
DeserializationException(Throwable) - Constructor for exception org.apache.flink.types.DeserializationException
Constructs an DeserializationException with the specified cause.
DeserializationSchema<T> - Interface in org.apache.flink.streaming.util.serialization
The deserialization schema describes how to turn the byte messages delivered by certain data sources (for example Apache Kafka) into data types (Java/Scala objects) that are processed by Flink.
deserialize(T, DataInputView) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
 
deserialize(T, DataInputView) - Method in class org.apache.flink.api.common.io.SerializedInputFormat
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
deserialize(boolean[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
deserialize(byte[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
deserialize(char[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
deserialize(double[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
deserialize(float[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
deserialize(int[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
deserialize(long[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
deserialize(short[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
deserialize(String[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
deserialize(BigDecimal, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
deserialize(BigInteger, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
deserialize(Boolean, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
deserialize(BooleanValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
 
deserialize(Byte, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
deserialize(ByteValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
 
deserialize(Character, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
deserialize(CharValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
 
deserialize(Date, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
deserialize(Double, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
deserialize(DoubleValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
deserialize(T, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
 
deserialize(Float, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
deserialize(FloatValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
deserialize(C[], DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
 
deserialize(Integer, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
deserialize(IntValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
 
deserialize(List<T>, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
 
deserialize(Long, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
deserialize(LongValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
deserialize(Map<K, V>, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
deserialize(NullValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
 
deserialize(Short, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
deserialize(ShortValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
deserialize(Date, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
deserialize(Time, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
deserialize(Timestamp, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
 
deserialize(String, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
deserialize(StringValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
 
deserialize(Void, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
 
deserialize(DataInputView) - Method in interface org.apache.flink.api.common.typeutils.TypeDeserializer
De-serializes a record from the given source input view.
deserialize(T, DataInputView) - Method in interface org.apache.flink.api.common.typeutils.TypeDeserializer
De-serializes a record from the given source input view into the given reuse record instance if mutable.
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.TypeDeserializerAdapter
 
deserialize(T, DataInputView) - Method in class org.apache.flink.api.common.typeutils.TypeDeserializerAdapter
 
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
De-serializes a record from the given source input view.
deserialize(T, DataInputView) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
De-serializes a record from the given source input view into the given reuse record instance if mutable.
deserialize(DataInputView) - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
deserialize(T, DataInputView) - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
deserialize(T, DataInputView) - Method in class org.apache.flink.api.java.io.TypeSerializerInputFormat
 
deserialize(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
 
deserialize(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
deserialize(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
deserialize(Either<L, R>, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
deserialize(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
deserialize(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
deserialize(Row, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
deserialize(Tuple0, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
deserialize(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
deserialize(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
 
deserialize(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
 
deserialize(T, DataInputView) - Method in class org.apache.flink.api.scala.typeutils.CaseClassSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.scala.typeutils.CaseClassSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.scala.typeutils.EitherSerializer
 
deserialize(T, DataInputView) - Method in class org.apache.flink.api.scala.typeutils.EitherSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.scala.typeutils.EnumValueSerializer
 
deserialize(Enumeration.Value, DataInputView) - Method in class org.apache.flink.api.scala.typeutils.EnumValueSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.scala.typeutils.NothingSerializer
 
deserialize(Object, DataInputView) - Method in class org.apache.flink.api.scala.typeutils.NothingSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.scala.typeutils.OptionSerializer
 
deserialize(Option<A>, DataInputView) - Method in class org.apache.flink.api.scala.typeutils.OptionSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.scala.typeutils.TraversableSerializer
 
deserialize(T, DataInputView) - Method in class org.apache.flink.api.scala.typeutils.TraversableSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.scala.typeutils.TrySerializer
 
deserialize(Try<A>, DataInputView) - Method in class org.apache.flink.api.scala.typeutils.TrySerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.api.scala.typeutils.UnitSerializer
 
deserialize(BoxedUnit, DataInputView) - Method in class org.apache.flink.api.scala.typeutils.UnitSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
 
deserialize(DeweyNumber, DataInputView) - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.cep.nfa.NFA.NFASerializer
 
deserialize(NFA<T>, DataInputView) - Method in class org.apache.flink.cep.nfa.NFA.NFASerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.cep.nfa.NFA.Serializer
 
deserialize(NFA<T>, DataInputView) - Method in class org.apache.flink.cep.nfa.NFA.Serializer
 
deserialize(DataInputView) - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
 
deserialize(SharedBuffer, DataInputView) - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.cep.NonDuplicatingTypeSerializer
Deserializes an object from the input view.
deserialize(T, DataInputView) - Method in class org.apache.flink.cep.NonDuplicatingTypeSerializer
 
deserialize(int, byte[]) - Method in interface org.apache.flink.core.io.SimpleVersionedSerializer
De-serializes the given data (bytes) which was serialized with the scheme of the indicated version.
deserialize(DataInputView) - Method in class org.apache.flink.graph.types.valuearray.IntValueArraySerializer
 
deserialize(IntValueArray, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.IntValueArraySerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.graph.types.valuearray.LongValueArraySerializer
 
deserialize(LongValueArray, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.LongValueArraySerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.graph.types.valuearray.NullValueArraySerializer
 
deserialize(NullValueArray, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.NullValueArraySerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.graph.types.valuearray.StringValueArraySerializer
 
deserialize(StringValueArray, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.StringValueArraySerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.migration.MigrationNamespaceSerializerProxy
Deprecated.
 
deserialize(Serializable, DataInputView) - Method in class org.apache.flink.migration.MigrationNamespaceSerializerProxy
Deprecated.
 
deserialize(DataInputStream, ClassLoader) - Method in class org.apache.flink.migration.runtime.checkpoint.savepoint.SavepointV0Serializer
 
deserialize(String, HeapKeyedStateBackend<K>) - Method in class org.apache.flink.migration.runtime.state.filesystem.AbstractFsStateSnapshot
Deprecated.
 
deserialize(String, HeapKeyedStateBackend<K>) - Method in class org.apache.flink.migration.runtime.state.memory.AbstractMemStateSnapshot
Deprecated.
 
deserialize(String, HeapKeyedStateBackend<K>) - Method in class org.apache.flink.migration.runtime.state.memory.AbstractMigrationRestoreStrategy
Deprecated.
 
deserialize(String, HeapKeyedStateBackend<K>) - Method in interface org.apache.flink.migration.runtime.state.memory.MigrationRestoreSnapshot
Deprecated.
 
deserialize(DataInputView) - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer
 
deserialize(StreamElement, DataInputView) - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.StreamRecordSerializer
 
deserialize(StreamRecord<T>, DataInputView) - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.StreamRecordSerializer
 
deserialize(DataInputStream, ClassLoader) - Method in interface org.apache.flink.runtime.checkpoint.savepoint.SavepointSerializer
Deserializes a savepoint from an input stream.
deserialize(DataInputStream, ClassLoader) - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
deserialize(MetricDumpSerialization.MetricSerializationResult) - Method in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricDumpDeserializer
De-serializes metrics from the given byte array and returns them as a list of MetricDump.
deserialize(DataInputView) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
deserialize(ArrayList<T>, DataInputView) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.runtime.state.HashMapSerializer
 
deserialize(HashMap<K, V>, DataInputView) - Method in class org.apache.flink.runtime.state.HashMapSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
 
deserialize(VoidNamespace, DataInputView) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
 
deserialize(InternalTimer<K, N>, DataInputView) - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
 
deserialize(GlobalWindow, DataInputView) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
 
deserialize(DataInputView) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
deserialize(TimeWindow, DataInputView) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
deserialize(DataInputView) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
deserialize(StreamElement, DataInputView) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
deserialize(byte[]) - Method in class org.apache.flink.streaming.util.serialization.AbstractDeserializationSchema
De-serializes the byte message.
deserialize(byte[]) - Method in class org.apache.flink.streaming.util.serialization.AvroRowDeserializationSchema
 
deserialize(byte[]) - Method in interface org.apache.flink.streaming.util.serialization.DeserializationSchema
Deserializes the byte message.
deserialize(byte[]) - Method in class org.apache.flink.streaming.util.serialization.JSONDeserializationSchema
 
deserialize(byte[], byte[], String, int, long) - Method in class org.apache.flink.streaming.util.serialization.JSONKeyValueDeserializationSchema
 
deserialize(byte[]) - Method in class org.apache.flink.streaming.util.serialization.JsonRowDeserializationSchema
 
deserialize(byte[], byte[], String, int, long) - Method in interface org.apache.flink.streaming.util.serialization.KeyedDeserializationSchema
Deserializes the byte message.
deserialize(byte[], byte[], String, int, long) - Method in class org.apache.flink.streaming.util.serialization.KeyedDeserializationSchemaWrapper
 
deserialize(byte[]) - Method in class org.apache.flink.streaming.util.serialization.SimpleStringSchema
 
deserialize(byte[], byte[], String, int, long) - Method in class org.apache.flink.streaming.util.serialization.TypeInformationKeyValueSerializationSchema
 
deserialize(byte[]) - Method in class org.apache.flink.streaming.util.serialization.TypeInformationSerializationSchema
 
deserialize(String) - Method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils$
 
deserialize(String) - Static method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils
 
deserialize(DataInputView) - Method in class org.apache.flink.table.runtime.types.CRowSerializer
 
deserialize(CRow, DataInputView) - Method in class org.apache.flink.table.runtime.types.CRowSerializer
 
deserialize(DataInputView) - Method in class org.apache.flink.types.Record
 
deserializeAccumulators(Map<String, SerializedValue<Object>>, ClassLoader) - Static method in class org.apache.flink.api.common.accumulators.AccumulatorHelper
Takes the serialized accumulator results and tries to deserialize them using the provided class loader.
deserializedFields1 - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
deserializedFields2 - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
deserializeError(ClassLoader) - Method in exception org.apache.flink.runtime.util.SerializedThrowable
 
deserializeField(ObjectInputStream) - Static method in class org.apache.flink.api.java.typeutils.runtime.FieldSerializer
 
deserializeFromByteArray(TypeSerializer<T>, byte[]) - Static method in class org.apache.flink.util.InstantiationUtil
 
deserializeFromByteArray(TypeSerializer<T>, T, byte[]) - Static method in class org.apache.flink.util.InstantiationUtil
 
deserializeHeader(ByteBuf) - Static method in class org.apache.flink.runtime.query.netty.message.KvStateRequestSerializer
Deserializes the header and returns the request type.
deserializeKeyAndNamespace(byte[], TypeSerializer<K>, TypeSerializer<N>) - Static method in class org.apache.flink.runtime.query.netty.message.KvStateRequestSerializer
Deserializes the key and namespace into a Tuple2.
deserializeKeyedStateHandle(DataInputStream) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
deserializeKvStateRequest(ByteBuf) - Static method in class org.apache.flink.runtime.query.netty.message.KvStateRequestSerializer
Deserializes the KvState request message.
deserializeKvStateRequestFailure(ByteBuf) - Static method in class org.apache.flink.runtime.query.netty.message.KvStateRequestSerializer
Deserializes the KvState request failure.
deserializeKvStateRequestResult(ByteBuf) - Static method in class org.apache.flink.runtime.query.netty.message.KvStateRequestSerializer
Deserializes the KvState request result.
deserializeList(ArrayList<byte[]>, TypeSerializer<T>) - Static method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
deserializeList(byte[], TypeSerializer<T>) - Static method in class org.apache.flink.runtime.query.netty.message.KvStateRequestSerializer
Deserializes all values with the given serializer.
deserializeMap(byte[], TypeSerializer<UK>, TypeSerializer<UV>) - Static method in class org.apache.flink.runtime.query.netty.message.KvStateRequestSerializer
Deserializes all kv pairs with the given serializer.
deserializeObject(byte[], ClassLoader) - Static method in class org.apache.flink.migration.util.MigrationInstantiationUtil
 
deserializeObject(InputStream, ClassLoader) - Static method in class org.apache.flink.migration.util.MigrationInstantiationUtil
 
deserializeObject(byte[], ClassLoader) - Static method in class org.apache.flink.util.InstantiationUtil
 
deserializeObject(InputStream, ClassLoader) - Static method in class org.apache.flink.util.InstantiationUtil
 
deserializeOperatorStateHandle(DataInputStream) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
deserializer - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
The schema to convert between Kafka's byte messages, and Flink's objects
deserializeServerFailure(ByteBuf) - Static method in class org.apache.flink.runtime.query.netty.message.KvStateRequestSerializer
Deserializes the KvState request failure.
deserializeStreamStateHandle(DataInputStream) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
deserializeUserAccumulators(ClassLoader) - Method in class org.apache.flink.runtime.accumulators.AccumulatorSnapshot
Gets the user-defined accumulators values.
deserializeValue(ClassLoader) - Method in class org.apache.flink.migration.util.SerializedValue
Deprecated.
 
deserializeValue(byte[], TypeSerializer<T>) - Static method in class org.apache.flink.runtime.query.netty.message.KvStateRequestSerializer
Deserializes the value with the given serializer.
deserializeValue(ClassLoader) - Method in class org.apache.flink.util.SerializedValue
 
dest - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
dest - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
 
destroy() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
destroyAllBufferPools() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
Destroys all buffer pools that allocate their buffers from this buffer pool (created via NetworkBufferPool.createBufferPool(int, int)).
destroyBufferPool(BufferPool) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPoolFactory
Destroy callback for updating factory book keeping.
destroyBufferPool(BufferPool) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
destroyBufferPool() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
 
destroyProcess(Process) - Static method in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
DETACHED_OPTION - Static variable in class org.apache.flink.client.cli.CliFrontendParser
 
DetachedEnvironment - Class in org.apache.flink.client.program
Execution Environment for remote execution with the Client in detached mode.
DetachedEnvironment(ClusterClient, List<URL>, List<URL>, ClassLoader, SavepointRestoreSettings) - Constructor for class org.apache.flink.client.program.DetachedEnvironment
 
DetachedEnvironment.DetachedJobExecutionResult - Class in org.apache.flink.client.program
 
determineLargestTumblingSize(long, long) - Method in class org.apache.flink.table.runtime.aggregate.AggregateUtil$
 
determineLargestTumblingSize(long, long) - Static method in class org.apache.flink.table.runtime.aggregate.AggregateUtil
 
DeweyNumber - Class in org.apache.flink.cep.nfa
Versioning scheme which allows to retrieve dependencies between different versions.
DeweyNumber(int) - Constructor for class org.apache.flink.cep.nfa.DeweyNumber
 
DeweyNumber(DeweyNumber) - Constructor for class org.apache.flink.cep.nfa.DeweyNumber
 
DeweyNumber.DeweyNumberSerializer - Class in org.apache.flink.cep.nfa
A TypeSerializer for the DeweyNumber which serves as a version number.
DeweyNumberSerializer() - Constructor for class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
 
DGauge - Class in org.apache.flink.metrics.datadog
Mapping of gauge between Flink and Datadog
DGauge(Gauge<Number>, String, String, List<String>) - Constructor for class org.apache.flink.metrics.datadog.DGauge
 
diagnostics() - Method in class org.apache.flink.yarn.YarnMessages.LocalStopYarnSession
 
difference(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.Graph
Performs Difference on the vertex and edge sets of the input graphs removes common vertices and edges.
difference(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.scala.Graph
Performs Difference on the vertex and edge sets of the input graphs removes common vertices and edges.
DIMENSION() - Method in class org.apache.flink.ml.MLUtils$
 
DIMENSION() - Static method in class org.apache.flink.ml.MLUtils
 
directBuffer() - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
 
directBuffer(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
 
directBuffer(int, int) - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
 
DirectedOutput<OUT> - Class in org.apache.flink.streaming.api.collector.selector
Wrapping Output that forwards to other Outputs based on a list of OutputSelectors.
DirectedOutput(List<OutputSelector<OUT>>, List<Tuple2<Output<StreamRecord<OUT>>, StreamEdge>>) - Constructor for class org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
directExecutor() - Static method in class org.apache.flink.runtime.concurrent.Executors
Return a direct executor.
disableAllContextAndOtherEnvironments() - Static method in class org.apache.flink.api.java.ScalaShellRemoteEnvironment
 
disableAllContextAndOtherEnvironments() - Static method in class org.apache.flink.api.java.ScalaShellRemoteStreamEnvironment
 
disableAutoTypeRegistration() - Method in class org.apache.flink.api.common.ExecutionConfig
Control whether Flink is automatically registering all types in the user programs with Kryo.
disableChaining() - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
Turns off chaining for this operator so thread co-location will not be used as an optimization.
disableChaining() - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Turns off chaining for this operator so thread co-location will not be used as an optimization.
disableChaining() - Method in class org.apache.flink.streaming.api.scala.DataStream
Turns off chaining for this operator so thread co-location will not be used as an optimization.
disableChaining() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink
Turns off chaining for this operator so thread co-location will not be used as an optimization.
disableChaining() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010.FlinkKafkaProducer010Configuration
 
disableCleanupOnOpen() - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
Deprecated.
This option is deprecated and remains only for backwards compatibility. We do not clean up lingering files anymore.
disableCleanupOnOpen() - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
Deprecated.
This option is deprecated and remains only for backwards compatibility. We do not clean up lingering files anymore.
disableClosureCleaner() - Method in class org.apache.flink.api.common.ExecutionConfig
Disables the ClosureCleaner.
disabled() - Static method in class org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
Gets the configuration describing the queryable state as deactivated.
DisabledKvStateRequestStats - Class in org.apache.flink.runtime.query.netty
Disabled KvStateRequestStats implementation.
DisabledKvStateRequestStats() - Constructor for class org.apache.flink.runtime.query.netty.DisabledKvStateRequestStats
 
disableFlushOnCheckpoint() - Method in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase
Disable flushing on checkpoint.
disableForceAvro() - Method in class org.apache.flink.api.common.ExecutionConfig
 
disableForceKryo() - Method in class org.apache.flink.api.common.ExecutionConfig
Disable use of Kryo serializer for all POJOs.
disableGenericTypes() - Method in class org.apache.flink.api.common.ExecutionConfig
Disables the use of generic types (types that would be serialized via Kryo).
disableObjectReuse() - Method in class org.apache.flink.api.common.ExecutionConfig
Disables reusing objects that Flink internally uses for deserialization and passing data to user-code functions.
disableOperatorChaining() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Disables operator chaining for streaming operators.
disableOperatorChaining() - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Disables operator chaining for streaming operators.
disableSysoutLogging() - Method in class org.apache.flink.api.common.ExecutionConfig
Disables the printing of progress update messages to System.out
discard(ClassLoader) - Method in class org.apache.flink.migration.runtime.checkpoint.SubtaskState
Deprecated.
 
DiscardingOutputFormat<T> - Class in org.apache.flink.api.java.io
An output format that simply discards all elements.
DiscardingOutputFormat() - Constructor for class org.apache.flink.api.java.io.DiscardingOutputFormat
 
DiscardingSink<T> - Class in org.apache.flink.streaming.api.functions.sink
A stream sink that ignores all elements.
DiscardingSink() - Constructor for class org.apache.flink.streaming.api.functions.sink.DiscardingSink
 
discardOnFailedStoring() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
discardOnShutdown(JobStatus) - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
discardOnSubsume() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
discardState() - Method in class org.apache.flink.migration.contrib.streaming.state.RocksDBStateBackend.FinalFullyAsyncSnapshot
Deprecated.
 
discardState() - Method in class org.apache.flink.migration.runtime.state.AbstractStateBackend.DataInputViewHandle
Deprecated.
 
discardState() - Method in class org.apache.flink.migration.runtime.state.filesystem.AbstractFileStateHandle
Deprecated.
Discard the state by deleting the file that stores the state.
discardState() - Method in class org.apache.flink.migration.runtime.state.memory.AbstractMemStateSnapshot
Deprecated.
Discarding the heap state is a no-op.
discardState() - Method in class org.apache.flink.migration.runtime.state.memory.ByteStreamStateHandle
Deprecated.
 
discardState() - Method in class org.apache.flink.migration.runtime.state.memory.SerializedStateHandle
Discarding heap-memory backed state is a no-op, so this method does nothing.
discardState() - Method in interface org.apache.flink.migration.runtime.state.StateObject
Deprecated.
Discards the state referred to by this handle, to free up resources in the persistent storage.
discardState() - Method in class org.apache.flink.migration.state.MigrationStreamStateHandle
Deprecated.
 
discardState() - Method in class org.apache.flink.migration.streaming.runtime.tasks.StreamTaskStateList
Deprecated.
 
discardState() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
 
discardState() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
 
discardState() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
 
discardState() - Method in class org.apache.flink.runtime.checkpoint.TaskState
Deprecated.
 
discardState() - Method in class org.apache.flink.runtime.state.ChainedStateHandle
 
discardState() - Method in class org.apache.flink.runtime.state.filesystem.FileStateHandle
Discard the state by deleting the file that stores the state.
discardState() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
 
discardState() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
 
discardState() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
 
discardState() - Method in class org.apache.flink.runtime.state.MultiStreamStateHandle
 
discardState() - Method in class org.apache.flink.runtime.state.OperatorStateHandle
 
discardState() - Method in class org.apache.flink.runtime.state.PlaceholderStreamStateHandle
 
discardState() - Method in class org.apache.flink.runtime.state.RetrievableStreamStateHandle
 
discardState() - Method in interface org.apache.flink.runtime.state.StateObject
Discards the state referred to and solemnly owned by this handle, to free up resources in the persistent storage.
discardStateFuture(RunnableFuture<? extends StateObject>) - Static method in class org.apache.flink.runtime.state.StateUtil
Discards the given state future by first trying to cancel it.
Disconnect(InstanceID, Exception) - Constructor for class org.apache.flink.runtime.messages.Messages.Disconnect
 
disconnect() - Method in class org.apache.flink.yarn.YarnClusterClient
Disconnect from the Yarn cluster
Disconnect$() - Constructor for class org.apache.flink.runtime.messages.Messages.Disconnect$
 
Disconnected - Class in org.apache.flink.mesos.scheduler.messages
Message sent by the callback handler to the scheduler actor when the scheduler becomes "disconnected" from the master (e.g., the master fails and another is taking over).
Disconnected() - Constructor for class org.apache.flink.mesos.scheduler.messages.Disconnected
 
disconnected(SchedulerDriver) - Method in class org.apache.flink.mesos.scheduler.SchedulerProxy
 
disconnectFromJobManager(InstanceID, Exception) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
disconnectFromJobManager(InstanceID, Exception) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Disconnect the task manager from the job manager.
disconnectFromJobManager(InstanceID, Exception) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
disconnectFromJobManager() - Method in class org.apache.flink.yarn.ApplicationClient
Disconnects this ApplicationClient from the connected YarnJobManager and cancels the polling timer.
disconnectJobManager(JobID, Exception) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
disconnectJobManager(JobID, Exception) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Disconnects a JobManager specified by the given resourceID from the ResourceManager.
disconnectJobManager(JobID, Exception) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
disconnectJobManager(JobID, Exception) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Disconnects the given JobManager from the TaskManager.
disconnectResourceManager() - Method in class org.apache.flink.runtime.instance.SlotPool
 
disconnectResourceManager() - Method in interface org.apache.flink.runtime.instance.SlotPoolGateway
Disconnects the slot pool from its current Resource Manager.
disconnectResourceManager(UUID, UUID, Exception) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
disconnectResourceManager(UUID, UUID, Exception) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
Disconnects the resource manager from the job manager because of the given cause.
disconnectResourceManager(Exception) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
disconnectResourceManager(Exception) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Disconnects the ResourceManager from the TaskManager.
disconnectTaskManager(ResourceID, Exception) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
disconnectTaskManager(ResourceID, Exception) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
Disconnects the given TaskExecutor from the JobMaster.
disconnectTaskManager(ResourceID, Exception) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
disconnectTaskManager(ResourceID, Exception) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Disconnects a TaskManager specified by the given resourceID from the ResourceManager.
discount() - Method in class org.apache.flink.examples.scala.relational.TPCHQuery3.Lineitem
 
discount() - Method in class org.apache.flink.table.examples.scala.TPCHQuery3Table.Lineitem
 
DispatcherThreadFactory - Class in org.apache.flink.runtime.taskmanager
Thread factory that creates threads with a given name, associates them with a given thread group, and set them to daemon mode.
DispatcherThreadFactory(ThreadGroup, String) - Constructor for class org.apache.flink.runtime.taskmanager.DispatcherThreadFactory
Creates a new thread factory.
dispose() - Method in class org.apache.flink.api.java.RemoteEnvironment
 
dispose() - Method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
Should only be called by one thread, and only after all accesses to the DB happened.
dispose() - Method in class org.apache.flink.migration.runtime.checkpoint.savepoint.SavepointV0
 
dispose() - Method in interface org.apache.flink.runtime.checkpoint.savepoint.Savepoint
Disposes the savepoint.
dispose() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
 
dispose() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
 
dispose() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
dispose() - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
Disposes the sorter.
dispose() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
dispose() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
Closes the state backend, releasing all internal resources, but does not delete any persistent checkpoint data.
dispose() - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
 
dispose() - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
Closes the backend and releases all resources.
dispose() - Method in interface org.apache.flink.runtime.state.OperatorStateBackend
Disposes the backend and releases all resources.
dispose() - Method in class org.apache.flink.storm.wrappers.BoltWrapper
 
dispose() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
 
dispose() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
This method is called at the very end of the operator's life, both in the case of a successful completion of the operation, and in the case of a failure and canceling.
dispose() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
dispose() - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
dispose() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
This method is called at the very end of the operator's life, both in the case of a successful completion of the operation, and in the case of a failure and canceling.
dispose() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
Deprecated.
 
dispose() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
 
dispose() - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
 
dispose() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
disposeIfNotUsed() - Method in class org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
 
DisposeSavepoint(String) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.DisposeSavepoint
 
DisposeSavepoint$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.DisposeSavepoint$
 
DisposeSavepointFailure(Throwable) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.DisposeSavepointFailure
 
DisposeSavepointFailure$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.DisposeSavepointFailure$
 
DisposeSavepointSuccess$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.DisposeSavepointSuccess$
 
disposeSortBuffers(boolean) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Releases the memory that is registered for in-memory sorted run generation.
distance(Vector, Vector) - Method in class org.apache.flink.ml.metrics.distances.ChebyshevDistanceMetric
 
distance(Vector, Vector) - Method in class org.apache.flink.ml.metrics.distances.CosineDistanceMetric
 
distance(Vector, Vector) - Method in interface org.apache.flink.ml.metrics.distances.DistanceMetric
Returns the distance between the arguments.
distance(Vector, Vector) - Method in class org.apache.flink.ml.metrics.distances.EuclideanDistanceMetric
 
distance(Vector, Vector) - Method in class org.apache.flink.ml.metrics.distances.ManhattanDistanceMetric
 
distance(Vector, Vector) - Method in class org.apache.flink.ml.metrics.distances.MinkowskiDistanceMetric
 
distance(Vector, Vector) - Method in class org.apache.flink.ml.metrics.distances.SquaredEuclideanDistanceMetric
 
distance(Vector, Vector) - Method in class org.apache.flink.ml.metrics.distances.TanimotoDistanceMetric
 
distance() - Method in class org.apache.flink.streaming.scala.examples.windowing.TopSpeedWindowing.CarEvent
 
DistanceMetric - Interface in org.apache.flink.ml.metrics.distances
DistanceMeasure interface is used for object which determines distance between two points.
DistanceMetric$() - Constructor for class org.apache.flink.ml.nn.KNN.DistanceMetric$
 
DistCp - Class in org.apache.flink.examples.java.distcp
A main class of the Flink distcp utility.
DistCp() - Constructor for class org.apache.flink.examples.java.distcp.DistCp
 
distinct(KeySelector<T, K>) - Method in class org.apache.flink.api.java.DataSet
Returns a distinct set of a DataSet using a KeySelector function.
distinct(int...) - Method in class org.apache.flink.api.java.DataSet
Returns a distinct set of a Tuple DataSet using field position keys.
distinct(String...) - Method in class org.apache.flink.api.java.DataSet
Returns a distinct set of a DataSet using expression keys.
distinct() - Method in class org.apache.flink.api.java.DataSet
Returns a distinct set of a DataSet.
distinct(Function1<T, K>, TypeInformation<K>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
distinct() - Static method in class org.apache.flink.api.scala.CrossDataSet
 
distinct(Seq<Object>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
distinct(String, Seq<String>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
distinct(Function1<T, K>, TypeInformation<K>) - Method in class org.apache.flink.api.scala.DataSet
Creates a new DataSet containing the distinct elements of this DataSet.
distinct() - Method in class org.apache.flink.api.scala.DataSet
Returns a distinct set of this DataSet.
distinct(Seq<Object>) - Method in class org.apache.flink.api.scala.DataSet
Returns a distinct set of a tuple DataSet using field position keys.
distinct(String, Seq<String>) - Method in class org.apache.flink.api.scala.DataSet
Returns a distinct set of this DataSet using expression keys.
distinct() - Method in class org.apache.flink.table.api.Table
Removes duplicate values and returns only distinct (different) values.
distinct() - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
Distinct - Class in org.apache.flink.table.plan.logical
 
Distinct(LogicalNode) - Constructor for class org.apache.flink.table.plan.logical.Distinct
 
Distinct$ - Class in org.apache.flink.table.plan.logical
 
Distinct$() - Constructor for class org.apache.flink.table.plan.logical.Distinct$
 
DistinctFunction() - Constructor for class org.apache.flink.api.java.operators.DistinctOperator.DistinctFunction
 
DistinctOperator<T> - Class in org.apache.flink.api.java.operators
This operator represents the application of a "distinct" function on a data set, and the result data set produced by the function.
DistinctOperator(DataSet<T>, Keys<T>, String) - Constructor for class org.apache.flink.api.java.operators.DistinctOperator
 
DistinctOperator.DistinctFunction<T> - Class in org.apache.flink.api.java.operators
 
DistinctReduce - Class in org.apache.flink.table.runtime.aggregate
 
DistinctReduce() - Constructor for class org.apache.flink.table.runtime.aggregate.DistinctReduce
 
DistributedCache - Class in org.apache.flink.api.common.cache
DistributedCache provides static methods to write the registered cache files into job configuration or decode them from job configuration.
DistributedCache(Map<String, Future<Path>>) - Constructor for class org.apache.flink.api.common.cache.DistributedCache
 
DistributedCache.DistributedCacheEntry - Class in org.apache.flink.api.common.cache
 
DistributedCacheEntry(String, Boolean) - Constructor for class org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
 
DistributedMatrix - Interface in org.apache.flink.ml.math.distributed
Common trait used by distributed data structures representing a matrix.
DistributedMatrix$ - Class in org.apache.flink.ml.math.distributed
 
DistributedMatrix$() - Constructor for class org.apache.flink.ml.math.distributed.DistributedMatrix$
 
DistributedRandomSampler<T> - Class in org.apache.flink.api.java.sampling
For sampling with fraction, the sample algorithms are natively distributed, while it's not true for fixed size sample algorithms.
DistributedRandomSampler(int) - Constructor for class org.apache.flink.api.java.sampling.DistributedRandomSampler
 
DistributedRowMatrix - Class in org.apache.flink.ml.math.distributed
Represents distributed row-major matrix.
DistributedRowMatrix(DataSet<IndexedRow>, int, int) - Constructor for class org.apache.flink.ml.math.distributed.DistributedRowMatrix
 
DistributedRowMatrix$ - Class in org.apache.flink.ml.math.distributed
 
DistributedRowMatrix$() - Constructor for class org.apache.flink.ml.math.distributed.DistributedRowMatrix$
 
DistributedRuntimeUDFContext - Class in org.apache.flink.runtime.operators.util
A standalone implementation of the RuntimeContext, created by runtime UDF operators.
DistributedRuntimeUDFContext(TaskInfo, ClassLoader, ExecutionConfig, Map<String, Future<Path>>, Map<String, Accumulator<?, ?>>, MetricGroup) - Constructor for class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
 
DistributionPattern - Enum in org.apache.flink.runtime.jobgraph
A distribution pattern determines, which sub tasks of a producing task are connected to which consuming sub tasks.
div(long) - Method in class org.apache.flink.examples.java.clustering.KMeans.Point
 
div(Integer) - Method in class org.apache.flink.examples.java.ml.LinearRegression.Params
 
div(long) - Method in interface org.apache.flink.examples.scala.clustering.KMeans.Coordinate
 
div(int) - Method in class org.apache.flink.examples.scala.ml.LinearRegression.Params
 
Div - Class in org.apache.flink.table.expressions
 
Div(Expression, Expression) - Constructor for class org.apache.flink.table.expressions.Div
 
Div$ - Class in org.apache.flink.table.expressions
 
Div$() - Constructor for class org.apache.flink.table.expressions.Div$
 
DIVIDE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Arithmetic division operator, '/'.
divide(RexBuilder, RexNode, BigDecimal) - Method in class org.apache.flink.table.expressions.ExpressionUtils$
Copy of org.apache.calcite.sql2rel.StandardConvertletTable#divide().
divide(RexBuilder, RexNode, BigDecimal) - Static method in class org.apache.flink.table.expressions.ExpressionUtils
Copy of org.apache.calcite.sql2rel.StandardConvertletTable#divide().
DIVIDE_INTEGER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Internal integer arithmetic division operator, '/INT'.
divideBy(int) - Method in class org.apache.flink.optimizer.costs.Costs
 
divideBy(RelOptCost) - Method in class org.apache.flink.table.plan.cost.DataSetCost
 
DMeter - Class in org.apache.flink.metrics.datadog
Mapping of meter between Flink and Datadog Only consider rate of the meter, due to Datadog HTTP API's limited support of meter
DMeter(Meter, String, String, List<String>) - Constructor for class org.apache.flink.metrics.datadog.DMeter
 
DMetric - Class in org.apache.flink.metrics.datadog
Abstract metric of Datadog for serialization
DMetric(MetricType, String, String, List<String>) - Constructor for class org.apache.flink.metrics.datadog.DMetric
 
doAllSupportPartialMerge(Seq<AggregateCall>, RelDataType, int) - Method in class org.apache.flink.table.runtime.aggregate.AggregateUtil$
Return true if all aggregates can be partially merged.
doAllSupportPartialMerge(AggregateFunction<?, ?>[]) - Method in class org.apache.flink.table.runtime.aggregate.AggregateUtil$
Return true if all aggregates can be partially merged.
doAllSupportPartialMerge(Seq<AggregateCall>, RelDataType, int) - Static method in class org.apache.flink.table.runtime.aggregate.AggregateUtil
Return true if all aggregates can be partially merged.
doAllSupportPartialMerge(AggregateFunction<?, ?>[]) - Static method in class org.apache.flink.table.runtime.aggregate.AggregateUtil
Return true if all aggregates can be partially merged.
doCollect(Collector<Row>, long, long) - Method in class org.apache.flink.table.runtime.aggregate.DataSetSessionWindowAggregatePreProcessor
Emit the merged data of the current window.
DOCS - Static variable in class org.apache.flink.test.testdata.WebLogAnalysisData
 
DOCUMENTS - Static variable in class org.apache.flink.examples.java.relational.util.WebLogData
 
doEvaluateAndCollect(Collector<Row>, long, long) - Method in class org.apache.flink.table.runtime.aggregate.DataSetSessionWindowAggReduceGroupFunction
Evaluate and emit the data of the current window.
done(boolean) - Method in class org.apache.flink.runtime.checkpoint.AbstractAsyncSnapshotIOCallable
 
done(boolean) - Method in class org.apache.flink.runtime.io.async.AbstractAsyncIOCallable
Optional callback that subclasses can implement.
done(boolean) - Method in interface org.apache.flink.runtime.io.async.AsyncDoneCallback
the callback
done() - Method in class org.apache.flink.runtime.io.async.AsyncStoppableTaskWithCallback
 
DoneFuture<T> - Class in org.apache.flink.runtime.state
A Future that is always done and will just yield the object that was given at creation time.
DoneFuture(T) - Constructor for class org.apache.flink.runtime.state.DoneFuture
 
doRegister(Closeable, Map<Closeable, Object>) - Method in class org.apache.flink.core.fs.CloseableRegistry
 
doRegister(WrappingProxyCloseable<? extends Closeable>, Map<Closeable, SafetyNetCloseableRegistry.PhantomDelegatingCloseableRef>) - Method in class org.apache.flink.core.fs.SafetyNetCloseableRegistry
 
doRegister(C, Map<Closeable, T>) - Method in class org.apache.flink.util.AbstractCloseableRegistry
 
DOT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Dot operator, '.', used for referencing fields of records.
dot(Vector, Vector) - Method in class org.apache.flink.ml.math.BLAS$
dot(x, y)
dot(Vector, Vector) - Static method in class org.apache.flink.ml.math.BLAS
dot(x, y)
dot(Vector) - Method in class org.apache.flink.ml.math.DenseVector
Returns the dot product of the recipient and the argument
dot(Vector) - Method in class org.apache.flink.ml.math.SparseVector
Returns the dot product of the recipient and the argument
dot(Vector) - Method in interface org.apache.flink.ml.math.Vector
Returns the dot product of the recipient and the argument
dot(RexNode, String) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
dot(RexNode, int) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
DOUBLE - Static variable in class org.apache.flink.api.common.typeinfo.Types
 
DOUBLE() - Method in class org.apache.flink.table.api.Types$
 
DOUBLE() - Static method in class org.apache.flink.table.api.Types
 
DOUBLE() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
DOUBLE() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
double2Literal(double) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionConversions
 
DOUBLE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
DOUBLE_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
DOUBLE_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
DOUBLE_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
DoubleAvgAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Int Double aggregate function
DoubleAvgAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.DoubleAvgAggFunction
 
DoubleComparator - Class in org.apache.flink.api.common.typeutils.base
 
DoubleComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.DoubleComparator
 
DoubleCounter - Class in org.apache.flink.api.common.accumulators
An accumulator that sums up double values.
DoubleCounter() - Constructor for class org.apache.flink.api.common.accumulators.DoubleCounter
 
DoubleCounter(double) - Constructor for class org.apache.flink.api.common.accumulators.DoubleCounter
 
DoubleExplodeTableFunc - Class in org.apache.flink.table.plan.util
 
DoubleExplodeTableFunc() - Constructor for class org.apache.flink.table.plan.util.DoubleExplodeTableFunc
 
DoubleMaxAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Double Max aggregate function
DoubleMaxAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.DoubleMaxAggFunction
 
DoubleMaximum - Class in org.apache.flink.api.common.accumulators
An accumulator that finds the maximum double value.
DoubleMaximum() - Constructor for class org.apache.flink.api.common.accumulators.DoubleMaximum
 
DoubleMaximum(double) - Constructor for class org.apache.flink.api.common.accumulators.DoubleMaximum
 
DoubleMaxWithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Double Max with retraction aggregate function
DoubleMaxWithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.DoubleMaxWithRetractAggFunction
 
DoubleMinAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Double Min aggregate function
DoubleMinAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.DoubleMinAggFunction
 
DoubleMinimum - Class in org.apache.flink.api.common.accumulators
An accumulator that finds the minimum double value.
DoubleMinimum() - Constructor for class org.apache.flink.api.common.accumulators.DoubleMinimum
 
DoubleMinimum(double) - Constructor for class org.apache.flink.api.common.accumulators.DoubleMinimum
 
DoubleMinWithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Double Min with retraction aggregate function
DoubleMinWithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.DoubleMinWithRetractAggFunction
 
DoubleParameter - Class in org.apache.flink.graph.drivers.parameter
A Parameter storing a Double.
DoubleParameter(ParameterizedBase, String) - Constructor for class org.apache.flink.graph.drivers.parameter.DoubleParameter
Set the parameter name and add this parameter to the list of parameters stored by owner.
DoubleParser - Class in org.apache.flink.types.parser
Parses a text field into a Double.
DoubleParser() - Constructor for class org.apache.flink.types.parser.DoubleParser
 
DoublePrimitiveArrayComparator - Class in org.apache.flink.api.common.typeutils.base.array
 
DoublePrimitiveArrayComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArrayComparator
 
DoublePrimitiveArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
A serializer for double arrays.
DoublePrimitiveArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
DoubleSerializer - Class in org.apache.flink.api.common.typeutils.base
 
DoubleSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
DoubleSerializer() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.DoubleSerializer
 
DoubleSum0AggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Double Sum0 aggregate function
DoubleSum0AggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.DoubleSum0AggFunction
 
DoubleSum0WithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Double Sum0 with retract aggregate function
DoubleSum0WithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.DoubleSum0WithRetractAggFunction
 
DoubleSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.DoubleSumAgg
 
DoubleSumAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Double Sum aggregate function
DoubleSumAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.DoubleSumAggFunction
 
DoubleSumAggregator - Class in org.apache.flink.api.common.aggregators
An Aggregator that sums up DoubleValue values.
DoubleSumAggregator() - Constructor for class org.apache.flink.api.common.aggregators.DoubleSumAggregator
 
DoubleSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
Aggregator that can handle Double types
DoubleSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator
 
DoubleSummaryAggregator.MaxDoubleAggregator - Class in org.apache.flink.api.java.summarize.aggregation
 
DoubleSummaryAggregator.MinDoubleAggregator - Class in org.apache.flink.api.java.summarize.aggregation
 
DoubleSummaryAggregator.SumDoubleAggregator - Class in org.apache.flink.api.java.summarize.aggregation
 
DoubleSumWithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Double Sum with retract aggregate function
DoubleSumWithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.DoubleSumWithRetractAggFunction
 
DoubleValue - Class in org.apache.flink.types
Boxed serializable and comparable double precision floating point type, representing the primitive type double.
DoubleValue() - Constructor for class org.apache.flink.types.DoubleValue
Initializes the encapsulated double with 0.0.
DoubleValue(double) - Constructor for class org.apache.flink.types.DoubleValue
Initializes the encapsulated double with the provided value.
DoubleValueComparator - Class in org.apache.flink.api.common.typeutils.base
Specialized comparator for DoubleValue based on CopyableValueComparator.
DoubleValueComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
DoubleValueParser - Class in org.apache.flink.types.parser
Parses a text field into a DoubleValue.
DoubleValueParser() - Constructor for class org.apache.flink.types.parser.DoubleValueParser
 
DoubleValueSerializer - Class in org.apache.flink.api.common.typeutils.base
 
DoubleValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
DoubleValueSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.DoubleValueSumAgg
 
DoubleValueSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.DoubleValueSummaryAggregator
 
DoubleZeroConvergence - Class in org.apache.flink.api.common.aggregators
A ConvergenceCriterion over an Aggregator that defines convergence as reached once the aggregator holds the value zero.
DoubleZeroConvergence() - Constructor for class org.apache.flink.api.common.aggregators.DoubleZeroConvergence
 
doUnRegister(Closeable, Map<Closeable, Object>) - Method in class org.apache.flink.core.fs.CloseableRegistry
 
doUnRegister(WrappingProxyCloseable<? extends Closeable>, Map<Closeable, SafetyNetCloseableRegistry.PhantomDelegatingCloseableRef>) - Method in class org.apache.flink.core.fs.SafetyNetCloseableRegistry
 
doUnRegister(C, Map<Closeable, T>) - Method in class org.apache.flink.util.AbstractCloseableRegistry
 
DownTimeGauge - Class in org.apache.flink.runtime.executiongraph.metrics
A gauge that returns (in milliseconds) how long a job has not been not running any more, in case it is in a failing/recovering situation.
DownTimeGauge(ExecutionGraph) - Constructor for class org.apache.flink.runtime.executiongraph.metrics.DownTimeGauge
 
Driver<K,VV,EV> - Interface in org.apache.flink.graph.drivers
A driver for one or more GraphAlgorithms and/or GraphAnalytics.
driver - Variable in class org.apache.flink.runtime.operators.BatchTask
The driver that invokes the user code (the stub implementation).
Driver<S extends Function,OT> - Interface in org.apache.flink.runtime.operators
The interface to be implemented by all drivers that run alone (or as the primary driver) in a task.
driverKeys - Variable in class org.apache.flink.optimizer.plan.SingleInputPlanNode
 
driverSortOrders - Variable in class org.apache.flink.optimizer.plan.SingleInputPlanNode
 
DriverStrategy - Enum in org.apache.flink.runtime.operators
Enumeration of all available operator strategies.
dropFunction(String) - Method in class org.apache.flink.table.validate.FunctionCatalog
Drop a function and return if the function existed.
dropLeaderData(List<KafkaTopicPartitionLeader>) - Static method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartition
 
dropSubCatalog(String, boolean) - Method in interface org.apache.flink.table.catalog.CrudExternalCatalog
Deletes a sub catalog from this catalog.
dropSubCatalog(String, boolean) - Method in class org.apache.flink.table.catalog.InMemoryExternalCatalog
 
dropTable(String, boolean) - Method in interface org.apache.flink.table.catalog.CrudExternalCatalog
Deletes table from this catalog.
dropTable(String, boolean) - Method in class org.apache.flink.table.catalog.InMemoryExternalCatalog
 
dropTrivials() - Method in class org.apache.flink.optimizer.dataproperties.InterestingProperties
 
DropwizardHistogramWrapper - Class in org.apache.flink.dropwizard.metrics
Wrapper to use a Dropwizard Histogram as a Flink Histogram.
DropwizardHistogramWrapper(Histogram) - Constructor for class org.apache.flink.dropwizard.metrics.DropwizardHistogramWrapper
 
DropwizardMeterWrapper - Class in org.apache.flink.dropwizard.metrics
Wrapper to use a Dropwizard Meter as a Flink Meter.
DropwizardMeterWrapper(Meter) - Constructor for class org.apache.flink.dropwizard.metrics.DropwizardMeterWrapper
 
DSeries - Class in org.apache.flink.metrics.datadog
Json serialization between Flink and Datadog
DSeries() - Constructor for class org.apache.flink.metrics.datadog.DSeries
 
DualInputOperator<IN1,IN2,OUT,FT extends Function> - Class in org.apache.flink.api.common.operators
Abstract operator superclass for for all operators that have two inputs, like "Join", "CoGroup", or "Cross".
DualInputOperator(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.DualInputOperator
Creates a new abstract dual-input Pact with the given name wrapping the given user function.
DualInputOperator(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.DualInputOperator
Creates a new abstract dual-input operator with the given name wrapping the given user function.
DualInputPlanNode - Class in org.apache.flink.optimizer.plan
 
DualInputPlanNode(OptimizerNode, String, Channel, Channel, DriverStrategy) - Constructor for class org.apache.flink.optimizer.plan.DualInputPlanNode
 
DualInputPlanNode(OptimizerNode, String, Channel, Channel, DriverStrategy, FieldList, FieldList) - Constructor for class org.apache.flink.optimizer.plan.DualInputPlanNode
 
DualInputPlanNode(OptimizerNode, String, Channel, Channel, DriverStrategy, FieldList, FieldList, boolean[]) - Constructor for class org.apache.flink.optimizer.plan.DualInputPlanNode
 
DualInputSemanticProperties - Class in org.apache.flink.api.common.operators
Container for the semantic properties associated to a dual input operator.
DualInputSemanticProperties() - Constructor for class org.apache.flink.api.common.operators.DualInputSemanticProperties
 
DummyKryoSerializerClass() - Constructor for class org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot.DummyKryoSerializerClass
 
DummyRegisteredClass() - Constructor for class org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot.DummyRegisteredClass
 
DumpableConnection<T extends DumpableNode<T>> - Interface in org.apache.flink.optimizer.plandump
 
DumpableNode<T extends DumpableNode<T>> - Interface in org.apache.flink.optimizer.plandump
 
dumpOptimizerPlanAsJSON(OptimizedPlan, File) - Method in class org.apache.flink.optimizer.plandump.PlanJSONDumpGenerator
 
dumpOptimizerPlanAsJSON(OptimizedPlan, PrintWriter) - Method in class org.apache.flink.optimizer.plandump.PlanJSONDumpGenerator
 
dumpOptimizerPlanAsJSON(List<SinkPlanNode>, PrintWriter) - Method in class org.apache.flink.optimizer.plandump.PlanJSONDumpGenerator
 
dumpPactPlanAsJSON(List<DataSinkNode>, PrintWriter) - Method in class org.apache.flink.optimizer.plandump.PlanJSONDumpGenerator
 
dumpStreamingPlanAsJSON(File) - Method in class org.apache.flink.optimizer.plan.StreamingPlan
 
dumpStreamingPlanAsJSON(File) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArrayComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArrayComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArrayComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArrayComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArrayComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArrayComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArrayComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArrayComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.BigDecComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.BigIntComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.BooleanComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.ByteComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.CharComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.DateComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.DoubleComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.EnumComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.FloatComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.IntComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.LongComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.ShortComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Creates a copy of this class.
duplicate() - Method in interface org.apache.flink.api.common.typeutils.TypeDeserializer
Creates a deep copy of this deserializer if it is necessary, i.e.
duplicate() - Method in class org.apache.flink.api.common.typeutils.TypeDeserializerAdapter
 
duplicate() - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
Creates a deep copy of this serializer if it is necessary, i.e.
duplicate() - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
 
duplicate() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
 
duplicate() - Method in class org.apache.flink.api.scala.typeutils.CaseClassComparator
 
duplicate() - Method in class org.apache.flink.api.scala.typeutils.CaseClassSerializer
 
duplicate() - Method in class org.apache.flink.api.scala.typeutils.EitherSerializer
 
duplicate() - Method in class org.apache.flink.api.scala.typeutils.EnumValueComparator
 
duplicate() - Method in class org.apache.flink.api.scala.typeutils.EnumValueSerializer
 
duplicate() - Method in class org.apache.flink.api.scala.typeutils.NothingSerializer
 
duplicate() - Method in class org.apache.flink.api.scala.typeutils.OptionSerializer
 
duplicate() - Method in class org.apache.flink.api.scala.typeutils.OptionTypeComparator
 
duplicate() - Method in class org.apache.flink.api.scala.typeutils.TraversableSerializer
 
duplicate() - Method in class org.apache.flink.api.scala.typeutils.TrySerializer
 
duplicate() - Method in class org.apache.flink.cep.nfa.NFA.NFASerializer
 
duplicate() - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
 
duplicate() - Method in class org.apache.flink.cep.NonDuplicatingTypeSerializer
 
duplicate() - Method in class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
 
duplicate() - Method in class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
 
duplicate() - Method in class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
 
duplicate() - Method in class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
 
duplicate() - Method in class org.apache.flink.migration.MigrationNamespaceSerializerProxy
Deprecated.
 
duplicate() - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer
 
duplicate() - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.StreamRecordSerializer
 
duplicate() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
duplicate() - Method in class org.apache.flink.runtime.state.HashMapSerializer
 
duplicate() - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
 
duplicate() - Method in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter
 
duplicate() - Method in class org.apache.flink.streaming.connectors.fs.SequenceFileWriter
 
duplicate() - Method in class org.apache.flink.streaming.connectors.fs.StringWriter
 
duplicate() - Method in interface org.apache.flink.streaming.connectors.fs.Writer
Duplicates the Writer.
duplicate() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
duplicate() - Method in class org.apache.flink.table.runtime.types.CRowComparator
 
duplicate() - Method in class org.apache.flink.table.runtime.types.CRowSerializer
 
DuplicateValue() - Constructor for class org.apache.flink.examples.java.graph.ConnectedComponents.DuplicateValue
 
duration() - Method in class org.apache.flink.runtime.jobmanager.JobInfo
 
DynamicCodeLoadingException - Exception in org.apache.flink.util
An exception that is thrown if the dynamic instantiation of code fails.
DynamicCodeLoadingException(Throwable) - Constructor for exception org.apache.flink.util.DynamicCodeLoadingException
Creates a new exception with the given cause.
DynamicCodeLoadingException(String, Throwable) - Constructor for exception org.apache.flink.util.DynamicCodeLoadingException
Creates a new exception with the given message and cause.
DynamicConfiguration - Class in org.apache.flink.runtime.security
A dynamic JAAS configuration.
DynamicConfiguration(Configuration) - Constructor for class org.apache.flink.runtime.security.DynamicConfiguration
Create a dynamic configuration.

E

EARLIEST_OFFSET - Static variable in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionStateSentinel
Magic number that defines the partition should start from the earliest offset.
EchoGraph - Class in org.apache.flink.graph.drivers.input
Generate an EchoGraph.
EchoGraph() - Constructor for class org.apache.flink.graph.drivers.input.EchoGraph
 
EchoGraph - Class in org.apache.flink.graph.generator
A CirculantGraph with n vertices defined by the width of a single range of offsets centered at n/2.
EchoGraph(ExecutionEnvironment, long, long) - Constructor for class org.apache.flink.graph.generator.EchoGraph
An undirected Graph whose vertices have the same degree.
Edge() - Constructor for class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Edge
 
Edge(Integer, Integer) - Constructor for class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Edge
 
Edge(int, int) - Constructor for class org.apache.flink.examples.scala.graph.EnumTriangles.Edge
 
Edge<K,V> - Class in org.apache.flink.graph
An Edge represents a link between two vertices, the source and the target and can carry an attached value.
Edge() - Constructor for class org.apache.flink.graph.Edge
 
Edge(K, K, V) - Constructor for class org.apache.flink.graph.Edge
 
Edge$() - Constructor for class org.apache.flink.examples.scala.graph.EnumTriangles.Edge$
 
EdgeDegreePair<K,VV,EV> - Class in org.apache.flink.graph.asm.degree.annotate.undirected
Annotates edges of an undirected graph with the degree of both the source and target degree vertices.
EdgeDegreePair() - Constructor for class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeDegreePair
 
EdgeDegreesPair<K,VV,EV> - Class in org.apache.flink.graph.asm.degree.annotate.directed
Annotates edges of a directed graph with the degree, out-degree, and in-degree of both the source and target vertices.
EdgeDegreesPair() - Constructor for class org.apache.flink.graph.asm.degree.annotate.directed.EdgeDegreesPair
 
EdgeDirection - Enum in org.apache.flink.graph
edgeJoin(EV, T) - Method in interface org.apache.flink.graph.EdgeJoinFunction
Applies a transformation on the current edge value and the value of the matched tuple of the input DataSet.
EdgeJoinFunction<EV,T> - Interface in org.apache.flink.graph
EdgeList<K,VV,EV> - Class in org.apache.flink.graph.drivers
Convert a Graph to the DataSet of Edge.
EdgeList() - Constructor for class org.apache.flink.graph.drivers.EdgeList
 
EdgeMetrics<K extends Comparable<K>,VV,EV> - Class in org.apache.flink.graph.library.metric.directed
Compute the following edge metrics in a directed graph: - number of triangle triplets - number of rectangle triplets - maximum number of triangle triplets - maximum number of rectangle triplets
EdgeMetrics() - Constructor for class org.apache.flink.graph.library.metric.directed.EdgeMetrics
 
EdgeMetrics<K extends Comparable<K>,VV,EV> - Class in org.apache.flink.graph.library.metric.undirected
Compute the following edge metrics in an undirected graph: - number of triangle triplets - number of rectangle triplets - maximum number of triangle triplets - maximum number of rectangle triplets
EdgeMetrics() - Constructor for class org.apache.flink.graph.library.metric.undirected.EdgeMetrics
 
EdgeMetrics.Result - Class in org.apache.flink.graph.library.metric.directed
Wraps edge metrics.
EdgeMetrics.Result - Class in org.apache.flink.graph.library.metric.undirected
Wraps edge metrics.
EdgeOrder - Enum in org.apache.flink.graph
These bitmasks are used by edge-flipping algorithms to mark the edge order relative to the original edge direction.
edgeReader - Variable in class org.apache.flink.graph.GraphCsvReader
 
EDGES - Static variable in class org.apache.flink.examples.java.graph.util.ConnectedComponentsData
 
EDGES - Static variable in class org.apache.flink.examples.java.graph.util.EnumTrianglesData
 
EDGES - Static variable in class org.apache.flink.examples.java.graph.util.PageRankData
 
EDGES - Static variable in class org.apache.flink.graph.examples.data.ConnectedComponentsDefaultData
 
EDGES - Static variable in class org.apache.flink.graph.examples.data.EuclideanGraphData
 
EDGES - Static variable in class org.apache.flink.graph.examples.data.IncrementalSSSPData
 
EDGES - Static variable in class org.apache.flink.graph.examples.data.PageRankData
 
EDGES - Static variable in class org.apache.flink.graph.examples.data.SingleSourceShortestPathsData
 
EDGES - Static variable in class org.apache.flink.graph.examples.data.TriangleCountData
 
EDGES - Static variable in class org.apache.flink.test.testdata.EnumTriangleData
 
EDGES - Static variable in class org.apache.flink.test.testdata.PageRankData
 
EDGES_IN_SSSP - Static variable in class org.apache.flink.graph.examples.data.IncrementalSSSPData
 
EdgesFunction<K,EV,O> - Interface in org.apache.flink.graph
Interface to be implemented by the function applied to a vertex neighborhood in the Graph.groupReduceOnEdges(EdgesFunction, EdgeDirection) method.
EdgesFunction<K,EV,T> - Class in org.apache.flink.graph.scala
 
EdgesFunction() - Constructor for class org.apache.flink.graph.scala.EdgesFunction
 
EdgesFunctionWithVertexValue<K,VV,EV,O> - Interface in org.apache.flink.graph
Interface to be implemented by the function applied to a vertex neighborhood in the Graph.groupReduceOnEdges(EdgesFunctionWithVertexValue, EdgeDirection) method.
EdgesFunctionWithVertexValue<K,VV,EV,T> - Class in org.apache.flink.graph.scala
 
EdgesFunctionWithVertexValue() - Constructor for class org.apache.flink.graph.scala.EdgesFunctionWithVertexValue
 
EdgeSourceDegree<K,VV,EV> - Class in org.apache.flink.graph.asm.degree.annotate.undirected
Annotates edges of an undirected graph with degree of the source vertex.
EdgeSourceDegree() - Constructor for class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeSourceDegree
 
EdgeSourceDegrees<K,VV,EV> - Class in org.apache.flink.graph.asm.degree.annotate.directed
Annotates edges of a directed graph with the degree, out-degree, and in-degree of the source vertex.
EdgeSourceDegrees() - Constructor for class org.apache.flink.graph.asm.degree.annotate.directed.EdgeSourceDegrees
 
EdgeTargetDegree<K,VV,EV> - Class in org.apache.flink.graph.asm.degree.annotate.undirected
Annotates edges of an undirected graph with degree of the target vertex.
EdgeTargetDegree() - Constructor for class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeTargetDegree
 
EdgeTargetDegrees<K,VV,EV> - Class in org.apache.flink.graph.asm.degree.annotate.directed
Annotates edges of a directed graph with the degree, out-degree, and in-degree of the target vertex.
EdgeTargetDegrees() - Constructor for class org.apache.flink.graph.asm.degree.annotate.directed.EdgeTargetDegrees
 
EdgeToTuple2Map<K,EV> - Class in org.apache.flink.graph.utils
Create a Tuple2 DataSet from the vertices of an Edge DataSet
EdgeToTuple2Map() - Constructor for class org.apache.flink.graph.utils.EdgeToTuple2Map
 
EdgeToTuple3Map<K,EV> - Class in org.apache.flink.graph.scala.utils
 
EdgeToTuple3Map() - Constructor for class org.apache.flink.graph.scala.utils.EdgeToTuple3Map
 
EdgeToTuple3Map<K,EV> - Class in org.apache.flink.graph.utils
Create a Tuple3 DataSet from an Edge DataSet
EdgeToTuple3Map() - Constructor for class org.apache.flink.graph.utils.EdgeToTuple3Map
 
edgeTypes(Class<K>, Class<EV>) - Method in class org.apache.flink.graph.GraphCsvReader
Creates a Graph from CSV input with edge values, but without vertex values.
EdgeValue() - Constructor for class org.apache.flink.graph.library.Summarization.EdgeValue
 
EdgeWithDegrees() - Constructor for class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.EdgeWithDegrees
 
EdgeWithDegrees() - Constructor for class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
 
Either<L,R> - Class in org.apache.flink.types
This type represents a value of one two possible types, Left or Right (a disjoint union), inspired by Scala's Either type.
Either() - Constructor for class org.apache.flink.types.Either
 
Either.Left<L,R> - Class in org.apache.flink.types
A left value of Either
Either.Right<L,R> - Class in org.apache.flink.types
A right value of Either
EitherDescriptor(int, scala.reflect.macros.Context.universe, TypeDescriptors<C>.UDTDescriptor, TypeDescriptors<C>.UDTDescriptor) - Constructor for class org.apache.flink.api.scala.codegen.TypeDescriptors.EitherDescriptor
 
EitherSerializer<L,R> - Class in org.apache.flink.api.java.typeutils.runtime
A TypeSerializer for the Either type of the Java class.
EitherSerializer(TypeSerializer<L>, TypeSerializer<R>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
EitherSerializer<A,B,T extends scala.util.Either<A,B>> - Class in org.apache.flink.api.scala.typeutils
Serializer for Either.
EitherSerializer(TypeSerializer<A>, TypeSerializer<B>) - Constructor for class org.apache.flink.api.scala.typeutils.EitherSerializer
 
EitherSerializerConfigSnapshot<L,R> - Class in org.apache.flink.api.java.typeutils.runtime
Configuration snapshot for serializers of the Either type, containing configuration snapshots of the Left and Right serializers.
EitherSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.EitherSerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
EitherSerializerConfigSnapshot(TypeSerializer<L>, TypeSerializer<R>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.EitherSerializerConfigSnapshot
 
EitherTypeInfo<L,R> - Class in org.apache.flink.api.java.typeutils
A TypeInformation for the Either type of the Java API.
EitherTypeInfo(TypeInformation<L>, TypeInformation<R>) - Constructor for class org.apache.flink.api.java.typeutils.EitherTypeInfo
 
EitherTypeInfo<A,B,T extends scala.util.Either<A,B>> - Class in org.apache.flink.api.scala.typeutils
TypeInformation Either.
EitherTypeInfo(Class<T>, TypeInformation<A>, TypeInformation<B>) - Constructor for class org.apache.flink.api.scala.typeutils.EitherTypeInfo
 
EitherTypeInfoFactory<L,R> - Class in org.apache.flink.api.java.typeutils
 
EitherTypeInfoFactory() - Constructor for class org.apache.flink.api.java.typeutils.EitherTypeInfoFactory
 
Elasticsearch1ApiCallBridge - Class in org.apache.flink.streaming.connectors.elasticsearch
Implementation of ElasticsearchApiCallBridge for Elasticsearch 1.x.
Elasticsearch2ApiCallBridge - Class in org.apache.flink.streaming.connectors.elasticsearch2
Implementation of ElasticsearchApiCallBridge for Elasticsearch 2.x.
Elasticsearch5ApiCallBridge - Class in org.apache.flink.streaming.connectors.elasticsearch5
Implementation of ElasticsearchApiCallBridge for Elasticsearch 5.x.
ElasticsearchApiCallBridge - Interface in org.apache.flink.streaming.connectors.elasticsearch
An ElasticsearchApiCallBridge is used to bridge incompatible Elasticsearch Java API calls across different versions.
ElasticsearchSink<T> - Class in org.apache.flink.streaming.connectors.elasticsearch
Elasticsearch 1.x sink that requests multiple ActionRequests against a cluster for each incoming element.
ElasticsearchSink(Map<String, String>, IndexRequestBuilder<T>) - Constructor for class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSink
Deprecated.
Deprecated since version 1.2, to be removed at version 2.0. Please use ElasticsearchSink.ElasticsearchSink(Map, ElasticsearchSinkFunction) instead.
ElasticsearchSink(Map<String, String>, List<TransportAddress>, IndexRequestBuilder<T>) - Constructor for class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSink
Deprecated.
Deprecated since 1.2, to be removed at 2.0. Please use ElasticsearchSink.ElasticsearchSink(Map, List, ElasticsearchSinkFunction) instead.
ElasticsearchSink(Map<String, String>, ElasticsearchSinkFunction<T>) - Constructor for class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSink
Creates a new ElasticsearchSink that connects to the cluster using an embedded Node.
ElasticsearchSink(Map<String, String>, List<TransportAddress>, ElasticsearchSinkFunction<T>) - Constructor for class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSink
Creates a new ElasticsearchSink that connects to the cluster using a TransportClient.
ElasticsearchSink(Map<String, String>, ElasticsearchSinkFunction<T>, ActionRequestFailureHandler) - Constructor for class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSink
Creates a new ElasticsearchSink that connects to the cluster using an embedded Node.
ElasticsearchSink(Map<String, String>, List<TransportAddress>, ElasticsearchSinkFunction<T>, ActionRequestFailureHandler) - Constructor for class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSink
Creates a new ElasticsearchSink that connects to the cluster using a TransportClient.
ElasticsearchSink<T> - Class in org.apache.flink.streaming.connectors.elasticsearch2
Elasticsearch 2.x sink that requests multiple ActionRequests against a cluster for each incoming element.
ElasticsearchSink(Map<String, String>, List<InetSocketAddress>, ElasticsearchSinkFunction<T>) - Constructor for class org.apache.flink.streaming.connectors.elasticsearch2.ElasticsearchSink
ElasticsearchSink(Map<String, String>, List<InetSocketAddress>, ElasticsearchSinkFunction<T>) - Constructor for class org.apache.flink.streaming.connectors.elasticsearch2.ElasticsearchSink
Creates a new ElasticsearchSink that connects to the cluster using a TransportClient.
ElasticsearchSink(Map<String, String>, List<InetSocketAddress>, ElasticsearchSinkFunction<T>, ActionRequestFailureHandler) - Constructor for class org.apache.flink.streaming.connectors.elasticsearch2.ElasticsearchSink
Creates a new ElasticsearchSink that connects to the cluster using a TransportClient.
ElasticsearchSink<T> - Class in org.apache.flink.streaming.connectors.elasticsearch5
Elasticsearch 5.x sink that requests multiple ActionRequests against a cluster for each incoming element.
ElasticsearchSink(Map<String, String>, List<InetSocketAddress>, ElasticsearchSinkFunction<T>) - Constructor for class org.apache.flink.streaming.connectors.elasticsearch5.ElasticsearchSink
Creates a new ElasticsearchSink that connects to the cluster using a TransportClient.
ElasticsearchSink(Map<String, String>, List<InetSocketAddress>, ElasticsearchSinkFunction<T>, ActionRequestFailureHandler) - Constructor for class org.apache.flink.streaming.connectors.elasticsearch5.ElasticsearchSink
Creates a new ElasticsearchSink that connects to the cluster using a TransportClient.
ElasticsearchSinkBase<T> - Class in org.apache.flink.streaming.connectors.elasticsearch
Base class for all Flink Elasticsearch Sinks.
ElasticsearchSinkBase(ElasticsearchApiCallBridge, Map<String, String>, ElasticsearchSinkFunction<T>, ActionRequestFailureHandler) - Constructor for class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase
 
ElasticsearchSinkBase.BulkFlushBackoffPolicy - Class in org.apache.flink.streaming.connectors.elasticsearch
 
ElasticsearchSinkBase.FlushBackoffType - Enum in org.apache.flink.streaming.connectors.elasticsearch
 
ElasticsearchSinkFunction<T> - Interface in org.apache.flink.streaming.connectors.elasticsearch
Creates multiple ActionRequests from an element in a stream.
ElasticsearchSinkFunction<T> - Interface in org.apache.flink.streaming.connectors.elasticsearch2
Deprecated.
Deprecated since 1.2, to be removed at 2.0. This class has been deprecated due to package relocation. Please use ElasticsearchSinkFunction instead.
ElasticsearchUtils - Class in org.apache.flink.streaming.connectors.elasticsearch.util
Suite of utility methods for Elasticsearch.
ElasticsearchUtils() - Constructor for class org.apache.flink.streaming.connectors.elasticsearch.util.ElasticsearchUtils
 
elem() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.ArrayDescriptor
 
elem() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.OptionDescriptor
 
elem() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.TraversableDescriptor
 
elem() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.TryDescriptor
 
elem(String, Function1<Object, Object>) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
elem(Parsers) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
ELEMENT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The ELEMENT operator, used to convert a multiset with only one item to a "regular" type.
element() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Returns the sole element of an array with a single element.
element() - Method in class org.apache.flink.table.runtime.aggregate.SingleElementIterable.SingleElementIterator
 
ELEMENT_LENGTH_IN_BYTES - Static variable in class org.apache.flink.graph.types.valuearray.IntValueArray
 
ELEMENT_LENGTH_IN_BYTES - Static variable in class org.apache.flink.graph.types.valuearray.LongValueArray
 
ELEMENT_SLICE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The internal "$ELEMENT_SLICE" operator returns the first field of the only element of a multiset.
elementCount() - Method in class org.apache.flink.table.runtime.LimitFilterFunction
 
elementIDs() - Method in class org.apache.flink.ml.recommendation.ALS.InBlockInformation
 
elementIDs() - Method in class org.apache.flink.ml.recommendation.ALS.OutBlockInformation
 
elements() - Method in class org.apache.flink.table.expressions.ArrayConstructor
 
elementSerializer() - Method in class org.apache.flink.api.scala.typeutils.TraversableSerializer
 
elementTypeInfo() - Method in class org.apache.flink.api.scala.typeutils.TraversableTypeInfo
 
elemSerializer() - Method in class org.apache.flink.api.scala.typeutils.OptionSerializer
 
elemTypeInfo() - Method in class org.apache.flink.api.scala.typeutils.TryTypeInfo
 
EMail() - Constructor for class org.apache.flink.examples.java.misc.CollectionExecutionExample.EMail
 
EMail(int, String, String) - Constructor for class org.apache.flink.examples.java.misc.CollectionExecutionExample.EMail
 
EmbeddedHaServices - Class in org.apache.flink.runtime.highavailability.nonha.embedded
An implementation of the HighAvailabilityServices for the non-high-availability case where all participants (ResourceManager, JobManagers, TaskManagers) run in the same process.
EmbeddedHaServices(Executor) - Constructor for class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
 
EmbeddedLeaderService - Class in org.apache.flink.runtime.highavailability.nonha.embedded
A simple leader election service, which selects a leader among contenders and notifies listeners.
EmbeddedLeaderService(Executor) - Constructor for class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
 
emit(T) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
 
emit() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.ReduceFacade
Emits all elements currently held by the table to the collector.
emit(T) - Method in class org.apache.flink.streaming.runtime.io.StreamRecordWriter
 
emitAndReset() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.ReduceFacade
Emits all elements currently held by the table to the collector, and resets the table.
emitDataSet(DataSet<T>) - Method in interface org.apache.flink.table.sinks.BatchTableSink
Emits the DataSet.
emitDataSet(DataSet<Row>) - Method in class org.apache.flink.table.sinks.CsvTableSink
 
emitDataStream(DataStream<Row>) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSink
 
emitDataStream(DataStream<T>) - Method in interface org.apache.flink.table.sinks.AppendStreamTableSink
Emits the DataStream.
emitDataStream(DataStream<Row>) - Method in class org.apache.flink.table.sinks.CsvTableSink
 
emitDataStream(DataStream<Tuple2<Boolean, T>>) - Method in interface org.apache.flink.table.sinks.RetractStreamTableSink
Emits the DataStream.
emitDataStream(DataStream<Tuple2<Boolean, T>>) - Method in interface org.apache.flink.table.sinks.UpsertStreamTableSink
Emits the DataStream.
emitLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
emitLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator.CountingOutput
 
emitLatencyMarker(LatencyMarker) - Method in interface org.apache.flink.streaming.api.operators.Output
 
emitLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
emitMatchedSequences(Iterable<Map<String, List<IN>>>, long) - Method in class org.apache.flink.cep.operator.TimeoutKeyedCEPPatternOperator
 
emitRecord(T, KafkaTopicPartitionState<TopicPartition>, long, ConsumerRecord<?, ?>) - Method in class org.apache.flink.streaming.connectors.kafka.internal.Kafka010Fetcher
 
emitRecord(T, KafkaTopicPartitionState<TopicPartition>, long, ConsumerRecord<?, ?>) - Method in class org.apache.flink.streaming.connectors.kafka.internal.Kafka09Fetcher
 
emitRecord(T, KafkaTopicPartitionState<KPH>, long) - Method in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
Emits a record without attaching an existing timestamp to it.
emitRecordWithTimestamp(T, KafkaTopicPartitionState<KPH>, long, long) - Method in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
Emits a record attaching a timestamp to it.
emitRecordWithTimestampAndPeriodicWatermark(T, KafkaTopicPartitionState<KPH>, long, long) - Method in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
Record emission, if a timestamp will be attached from an assigner that is also a periodic watermark generator.
emitRecordWithTimestampAndPunctuatedWatermark(T, KafkaTopicPartitionState<KPH>, long, long) - Method in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
Record emission, if a timestamp will be attached from an assigner that is also a punctuated watermark generator.
emitStreamStatus(StreamStatus) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
Emitter<OUT> - Class in org.apache.flink.streaming.api.operators.async
Runnable responsible for consuming elements from the given queue and outputting them to the given output/timestampedCollector.
Emitter(Object, Output<StreamRecord<OUT>>, StreamElementQueue, OperatorActions) - Constructor for class org.apache.flink.streaming.api.operators.async.Emitter
 
emitWatermark(Watermark) - Method in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
emitWatermark(Watermark) - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
Emits the given Watermark.
emitWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator.CountingOutput
 
emitWatermark(Watermark) - Method in interface org.apache.flink.streaming.api.operators.Output
Emits a Watermark from an operator.
emitWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
empiricalRisk(DataSet<Tuple3<Object, Object, Object>>, ParameterMap) - Method in class org.apache.flink.ml.recommendation.ALS
Empirical risk of the trained model (matrix factorization).
Empty() - Method in class org.apache.flink.ml.common.ParameterMap$
 
Empty() - Static method in class org.apache.flink.ml.common.ParameterMap
 
EMPTY - Static variable in class org.apache.flink.optimizer.dataproperties.LocalProperties
 
EMPTY - Static variable in class org.apache.flink.runtime.state.TaskStateHandles
 
EMPTY - Static variable in class org.apache.flink.runtime.util.IntArrayList
 
empty() - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
EMPTY_INTERMEDIATE_ITERABLE - Variable in class org.apache.flink.api.java.sampling.DistributedRandomSampler
 
EMPTY_ITERABLE - Variable in class org.apache.flink.api.java.sampling.RandomSampler
 
EMPTY_KEY_GROUP_RANGE - Static variable in class org.apache.flink.runtime.state.KeyGroupRange
The empty key-group
EMPTY_LIST - Static variable in class org.apache.flink.api.common.operators.util.FieldList
 
EMPTY_SET - Static variable in class org.apache.flink.api.common.operators.util.FieldSet
 
emptyClassArray() - Static method in class org.apache.flink.api.common.operators.AbstractUdfOperator
Generic utility function that returns an empty class array.
EmptyFieldFilter() - Constructor for class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator.EmptyFieldFilter
 
EmptyFieldsCountAccumulator - Class in org.apache.flink.examples.java.relational
This program filters lines from a CSV file with empty fields.
EmptyFieldsCountAccumulator() - Constructor for class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator
 
EmptyFieldsCountAccumulator.EmptyFieldFilter - Class in org.apache.flink.examples.java.relational
This function filters all incoming tuples that have one or more empty fields.
EmptyFieldsCountAccumulator.StringTriple - Class in org.apache.flink.examples.java.relational
It is recommended to use POJOs (Plain old Java objects) instead of TupleX for data types with many fields.
EmptyFieldsCountAccumulator.VectorAccumulator - Class in org.apache.flink.examples.java.relational
This accumulator maintains a vector of counts.
EmptyGraph - Class in org.apache.flink.graph.drivers.input
Generate an EmptyGraph.
EmptyGraph() - Constructor for class org.apache.flink.graph.drivers.input.EmptyGraph
 
EmptyGraph - Class in org.apache.flink.graph.generator
 
EmptyGraph(ExecutionEnvironment, long) - Constructor for class org.apache.flink.graph.generator.EmptyGraph
The Graph containing no edges.
EmptyIterator<E> - Class in org.apache.flink.runtime.util
An empty iterator that never returns anything.
EmptyIterator() - Constructor for class org.apache.flink.runtime.util.EmptyIterator
 
EmptyMutableObjectIterator<E> - Class in org.apache.flink.runtime.util
An empty mutable object iterator that never returns anything.
EmptyMutableObjectIterator() - Constructor for class org.apache.flink.runtime.util.EmptyMutableObjectIterator
 
EmptySemanticProperties() - Constructor for class org.apache.flink.api.common.operators.SemanticProperties.EmptySemanticProperties
 
enableCheckpointing(long, long, long, int, ExternalizedCheckpointSettings, List<ExecutionJobVertex>, List<ExecutionJobVertex>, List<ExecutionJobVertex>, List<MasterTriggerRestoreHook<?>>, CheckpointIDCounter, CompletedCheckpointStore, String, StateBackend, CheckpointStatsTracker) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
enableCheckpointing(long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Enables checkpointing for the streaming job.
enableCheckpointing(long, CheckpointingMode) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Enables checkpointing for the streaming job.
enableCheckpointing(long, CheckpointingMode, boolean) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Deprecated.
Use StreamExecutionEnvironment.enableCheckpointing(long, CheckpointingMode) instead. Forcing checkpoints will be removed in the future.
enableCheckpointing() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
enableCheckpointing(long, CheckpointingMode, boolean) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Deprecated.
. Since .
enableCheckpointing(long, CheckpointingMode) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Enables checkpointing for the streaming job.
enableCheckpointing(long) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Enables checkpointing for the streaming job.
enableCheckpointing() - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Deprecated.
. Since .
enableClosureCleaner() - Method in class org.apache.flink.api.common.ExecutionConfig
Enables the ClosureCleaner.
enabled() - Method in class org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
Returns whether queryable state is enabled.
enableDecorrelation() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Deprecated.
enableExternalizedCheckpoints(CheckpointConfig.ExternalizedCheckpointCleanup) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
Enables checkpoints to be persisted externally.
enableForceAvro() - Method in class org.apache.flink.api.common.ExecutionConfig
Force Flink to use the AvroSerializer for POJOs.
enableForceKryo() - Method in class org.apache.flink.api.common.ExecutionConfig
Force TypeExtractor to use Kryo serializer for POJOS even though we could analyze as POJO.
enableGenericTypes() - Method in class org.apache.flink.api.common.ExecutionConfig
Enables the use generic types which are serialized via Kryo.
enableMutableUDTs() - Method in interface org.apache.flink.api.scala.codegen.TypeAnalyzer
 
enableObjectReuse() - Method in class org.apache.flink.api.common.ExecutionConfig
Enables reusing objects that Flink internally uses for deserialization and passing data to user-code functions.
enableQuotedStringParsing(char) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
enableQuotedStringParsing(byte) - Method in class org.apache.flink.types.parser.StringParser
 
enableQuotedStringParsing(byte) - Method in class org.apache.flink.types.parser.StringValueParser
 
enableSysoutLogging() - Method in class org.apache.flink.api.common.ExecutionConfig
Enables the printing of progress update messages to System.out
enableWriteAheadLog() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
Enables the write-ahead log, which allows exactly-once processing for non-deterministic algorithms that use idempotent updates.
enableWriteAheadLog(CheckpointCommitter) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
Enables the write-ahead log, which allows exactly-once processing for non-deterministic algorithms that use idempotent updates.
encodeDynamicProperties(Configuration) - Static method in class org.apache.flink.mesos.cli.FlinkMesosSessionCli
Encode dynamic properties as a string to be transported as an environment variable.
end() - Method in class org.apache.flink.runtime.jobmanager.JobInfo
 
end() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Returns the end time (exclusive) of a window when applied on a window reference.
endArray() - Method in class org.apache.flink.contrib.tweetinputformat.io.TweetHandler
 
ENDING_STATE_NAME - Static variable in class org.apache.flink.cep.nfa.compiler.NFACompiler
 
endJSON() - Method in class org.apache.flink.contrib.tweetinputformat.io.TweetHandler
 
endMarker() - Static method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
Gets the element that is passed as marker for the end of data.
endObject() - Method in class org.apache.flink.contrib.tweetinputformat.io.TweetHandler
 
endObjectEntry() - Method in class org.apache.flink.contrib.tweetinputformat.io.TweetHandler
 
EndOfPartitionEvent - Class in org.apache.flink.runtime.io.network.api
This event marks a subpartition as fully consumed.
EndOfSuperstepEvent - Class in org.apache.flink.runtime.io.network.api
Marks the end of a superstep of one particular iteration superstep.
endReached - Variable in class org.apache.flink.addons.hbase.AbstractTableInputFormat
 
endSession(JobID) - Method in class org.apache.flink.api.common.PlanExecutor
Ends the job session, identified by the given JobID.
endSession(JobID) - Method in class org.apache.flink.client.LocalExecutor
 
endSession(JobID) - Method in class org.apache.flink.client.program.ClusterClient
Tells the JobManager to finish the session (job) defined by the given ID.
endSession(JobID) - Method in class org.apache.flink.client.RemoteExecutor
 
endSessions(List<JobID>) - Method in class org.apache.flink.client.program.ClusterClient
Tells the JobManager to finish the sessions (jobs) defined by the given IDs.
endsWithDelimiter(byte[], int, byte[]) - Static method in class org.apache.flink.types.parser.FieldParser
Checks if the given bytes ends with the delimiter at the given end position.
Enrich(boolean) - Constructor for class org.apache.flink.storm.split.SpoutSplitExample.Enrich
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.api.common.typeutils.TypeDeserializerAdapter
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
Ensure compatibility of this serializer with a preceding serializer that was registered for serialization of the same managed state (if any - this method is only relevant if this serializer is registered for serialization of managed state).
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.api.scala.typeutils.EitherSerializer
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.api.scala.typeutils.EnumValueSerializer
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.api.scala.typeutils.NothingSerializer
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.api.scala.typeutils.OptionSerializer
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.api.scala.typeutils.TraversableSerializer
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.api.scala.typeutils.TrySerializer
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.cep.nfa.NFA.NFASerializer
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.cep.NonDuplicatingTypeSerializer
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.migration.MigrationNamespaceSerializerProxy
Deprecated.
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.StreamRecordSerializer
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.runtime.state.HashMapSerializer
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
ensureCompatibility(TypeSerializerConfigSnapshot) - Method in class org.apache.flink.table.runtime.types.CRowSerializer
 
ensureNotClosed() - Method in class org.apache.flink.migration.runtime.state.AbstractCloseableHandle
Deprecated.
This method checks whether the handle is closed and throws an exception if it is closed.
ensureSerializable(Object) - Static method in class org.apache.flink.api.java.ClosureCleaner
 
ensureSerializable(Object) - Method in class org.apache.flink.api.scala.ClosureCleaner$
 
ensureSerializable(Object) - Static method in class org.apache.flink.api.scala.ClosureCleaner
 
ensureYarnConfig(FlinkShell.Config) - Method in class org.apache.flink.api.scala.FlinkShell$
 
ensureYarnConfig(FlinkShell.Config) - Static method in class org.apache.flink.api.scala.FlinkShell
 
enterMainThread() - Method in class org.apache.flink.runtime.rpc.MainThreadValidatorUtil
 
Entities - Class in org.apache.flink.contrib.tweetinputformat.model.tweet.entities
Entities which have been parsed out of the text of the Tweet.
Entities() - Constructor for class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Entities
 
entries() - Method in interface org.apache.flink.api.common.state.MapState
Returns all the mappings in the state
entries() - Method in class org.apache.flink.contrib.streaming.state.RocksDBMapState
 
entries() - Method in class org.apache.flink.runtime.state.heap.HeapMapState
 
EntryIterator() - Constructor for class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.EntryIterator
 
entrySet() - Method in class org.apache.flink.storm.util.StormConfig
 
entrySet() - Method in class org.apache.flink.types.MapValue
 
enumClass() - Method in class org.apache.flink.api.scala.typeutils.EnumValueSerializer.ScalaEnumSerializerConfigSnapshot
 
EnumComparator<T extends Enum<T>> - Class in org.apache.flink.api.common.typeutils.base
 
EnumComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.EnumComparator
 
enumConstants() - Method in class org.apache.flink.api.scala.typeutils.EnumValueSerializer.ScalaEnumSerializerConfigSnapshot
 
EnumerableToLogicalTableScan - Class in org.apache.flink.table.plan.rules.logical
Rule that converts an EnumerableTableScan into a LogicalTableScan.
EnumerableToLogicalTableScan(RelOptRuleOperand, String) - Constructor for class org.apache.flink.table.plan.rules.logical.EnumerableToLogicalTableScan
 
EnumerableToLogicalTableScan$ - Class in org.apache.flink.table.plan.rules.logical
 
EnumerableToLogicalTableScan$() - Constructor for class org.apache.flink.table.plan.rules.logical.EnumerableToLogicalTableScan$
 
ENUMERATE_NESTED_FILES_FLAG - Static variable in class org.apache.flink.api.common.io.FileInputFormat
The config parameter which defines whether input directories are recursively traversed.
enumerateNestedFiles - Variable in class org.apache.flink.api.common.io.FileInputFormat
The flag to specify whether recursive traversal of the input directory structure is enabled.
Enumerator(File[], Random) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.Enumerator
 
EnumSerializer<T extends Enum<T>> - Class in org.apache.flink.api.common.typeutils.base
 
EnumSerializer(Class<T>) - Constructor for class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
EnumSerializer.EnumSerializerConfigSnapshot<T extends Enum<T>> - Class in org.apache.flink.api.common.typeutils.base
Configuration snapshot of a serializer for enumerations.
EnumSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
EnumSerializerConfigSnapshot(Class<T>, T[]) - Constructor for class org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot
 
EnumTriangleData - Class in org.apache.flink.test.testdata
 
EnumTriangleData() - Constructor for class org.apache.flink.test.testdata.EnumTriangleData
 
EnumTriangles - Class in org.apache.flink.examples.java.graph
Triangle enumeration is a pre-processing step to find closely connected parts in graphs.
EnumTriangles() - Constructor for class org.apache.flink.examples.java.graph.EnumTriangles
 
EnumTriangles - Class in org.apache.flink.examples.scala.graph
Triangle enumeration is a pre-processing step to find closely connected parts in graphs.
EnumTriangles() - Constructor for class org.apache.flink.examples.scala.graph.EnumTriangles
 
EnumTriangles$ - Class in org.apache.flink.examples.scala.graph
Triangle enumeration is a pre-processing step to find closely connected parts in graphs.
EnumTriangles$() - Constructor for class org.apache.flink.examples.scala.graph.EnumTriangles$
 
EnumTriangles.Edge - Class in org.apache.flink.examples.scala.graph
 
EnumTriangles.Edge$ - Class in org.apache.flink.examples.scala.graph
 
EnumTriangles.Triad - Class in org.apache.flink.examples.scala.graph
 
EnumTriangles.Triad$ - Class in org.apache.flink.examples.scala.graph
 
EnumTriangles.TriadBuilder - Class in org.apache.flink.examples.scala.graph
 
EnumTriangles.TupleEdgeConverter - Class in org.apache.flink.examples.java.graph
Converts a Tuple2 into an Edge
EnumTrianglesData - Class in org.apache.flink.examples.java.graph.util
Provides the default data sets used for the Triangle Enumeration example programs.
EnumTrianglesData() - Constructor for class org.apache.flink.examples.java.graph.util.EnumTrianglesData
 
EnumTrianglesDataTypes - Class in org.apache.flink.examples.java.graph.util
 
EnumTrianglesDataTypes() - Constructor for class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes
 
EnumTrianglesDataTypes.Edge - Class in org.apache.flink.examples.java.graph.util
 
EnumTrianglesDataTypes.EdgeWithDegrees - Class in org.apache.flink.examples.java.graph.util
 
EnumTrianglesDataTypes.Triad - Class in org.apache.flink.examples.java.graph.util
 
EnumTypeInfo<T extends Enum<T>> - Class in org.apache.flink.api.java.typeutils
A TypeInformation for java enumeration types.
EnumTypeInfo(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.EnumTypeInfo
 
EnumValueComparator<E extends scala.Enumeration> - Class in org.apache.flink.api.scala.typeutils
Comparator for Enumeration values.
EnumValueComparator(boolean) - Constructor for class org.apache.flink.api.scala.typeutils.EnumValueComparator
 
EnumValueDescriptor(int, scala.reflect.macros.Context.universe, scala.reflect.macros.Context.universe) - Constructor for class org.apache.flink.api.scala.codegen.TypeDescriptors.EnumValueDescriptor
 
enumValueOf(Class<?>, String) - Method in class org.apache.flink.table.codegen.CodeGenUtils$
 
enumValueOf(Class<?>, String) - Static method in class org.apache.flink.table.codegen.CodeGenUtils
 
EnumValueSerializer<E extends scala.Enumeration> - Class in org.apache.flink.api.scala.typeutils
Serializer for Enumeration values.
EnumValueSerializer(E) - Constructor for class org.apache.flink.api.scala.typeutils.EnumValueSerializer
 
EnumValueSerializer$ - Class in org.apache.flink.api.scala.typeutils
 
EnumValueSerializer$() - Constructor for class org.apache.flink.api.scala.typeutils.EnumValueSerializer$
 
EnumValueSerializer.ScalaEnumSerializerConfigSnapshot<E extends scala.Enumeration> - Class in org.apache.flink.api.scala.typeutils
 
EnumValueSerializer.ScalaEnumSerializerConfigSnapshot$ - Class in org.apache.flink.api.scala.typeutils
 
EnumValueTypeInfo<E extends scala.Enumeration> - Class in org.apache.flink.api.scala.typeutils
TypeInformation for Enumeration values.
EnumValueTypeInfo(E, Class<Enumeration.Value>) - Constructor for class org.apache.flink.api.scala.typeutils.EnumValueTypeInfo
 
env - Variable in class org.apache.flink.graph.AbstractGraphAnalytic
 
env - Variable in class org.apache.flink.graph.asm.dataset.AbstractDataSetAnalytic
 
ENV - Static variable in class org.apache.flink.yarn.AbstractYarnFlinkApplicationMasterRunner
The process environment variables
ENV_APP_ID - Static variable in class org.apache.flink.yarn.YarnConfigKeys
 
ENV_CLIENT_HOME_DIR - Static variable in class org.apache.flink.yarn.YarnConfigKeys
 
ENV_CLIENT_SHIP_FILES - Static variable in class org.apache.flink.yarn.YarnConfigKeys
 
ENV_DETACHED - Static variable in class org.apache.flink.yarn.YarnConfigKeys
 
ENV_DYNAMIC_PROPERTIES - Static variable in class org.apache.flink.yarn.YarnConfigKeys
 
ENV_FLINK_BIN_DIR - Static variable in class org.apache.flink.configuration.ConfigConstants
The environment variable name which contains the location of the bin directory
ENV_FLINK_CLASSPATH - Static variable in class org.apache.flink.yarn.YarnConfigKeys
 
ENV_FLINK_CONF_DIR - Static variable in class org.apache.flink.configuration.ConfigConstants
The environment variable name which contains the location of the configuration directory
ENV_FLINK_CONTAINER_ID - Static variable in class org.apache.flink.mesos.runtime.clusterframework.MesosConfigKeys
The Mesos task ID, used by the TM for informational purposes
ENV_FLINK_HOME_DIR - Static variable in class org.apache.flink.configuration.ConfigConstants
The environment variable name which contains the Flink installation root directory
ENV_FLINK_LIB_DIR - Static variable in class org.apache.flink.configuration.ConfigConstants
The environment variable name which contains the location of the lib folder
ENV_FLINK_TMP_DIR - Static variable in class org.apache.flink.mesos.runtime.clusterframework.MesosConfigKeys
Reserved for future enhancement
ENV_FRAMEWORK_NAME - Static variable in class org.apache.flink.mesos.runtime.clusterframework.MesosConfigKeys
Standard environment variables used in DCOS environment
ENV_HADOOP_USER_NAME - Static variable in class org.apache.flink.yarn.YarnConfigKeys
 
ENV_JVM_ARGS - Static variable in class org.apache.flink.mesos.runtime.clusterframework.MesosConfigKeys
JVM arguments, used by the JM and TM
ENV_KRB5_PATH - Static variable in class org.apache.flink.yarn.YarnConfigKeys
 
ENV_SLOTS - Static variable in class org.apache.flink.yarn.YarnConfigKeys
 
ENV_TASK_NAME - Static variable in class org.apache.flink.mesos.runtime.clusterframework.MesosConfigKeys
Standard environment variables used in DCOS environment
ENV_TM_COUNT - Static variable in class org.apache.flink.yarn.YarnConfigKeys
 
ENV_TM_MEMORY - Static variable in class org.apache.flink.yarn.YarnConfigKeys
 
ENV_YARN_SITE_XML_PATH - Static variable in class org.apache.flink.yarn.YarnConfigKeys
 
ENV_ZOOKEEPER_NAMESPACE - Static variable in class org.apache.flink.yarn.YarnConfigKeys
 
envID - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
Environment - Interface in org.apache.flink.runtime.execution
The Environment gives the code executed in a task access to the task's properties (such as name, parallelism), the configurations, the data stream readers and writers, as well as the various components that are provided by the TaskManager, such as memory manager, I/O manager, ...
environment - Variable in class org.apache.flink.streaming.api.datastream.ConnectedStreams
 
environment - Variable in class org.apache.flink.streaming.api.datastream.DataStream
 
EnvironmentInformation - Class in org.apache.flink.runtime.util
Utility class that gives access to the execution environment of the JVM, like the executing user, startup options, or the JVM version.
EnvironmentInformation.RevisionInformation - Class in org.apache.flink.runtime.util
Revision information encapsulates information about the source code revision of the Flink code.
eof() - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
EPSILON - Static variable in class org.apache.flink.api.java.sampling.RandomSampler
 
EpsilonFilter() - Constructor for class org.apache.flink.examples.java.graph.PageRank.EpsilonFilter
 
EQUALS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Logical equals operator, '='.
equals(Object) - Method in class org.apache.flink.api.common.ExecutionConfig
 
equals(Object) - Method in class org.apache.flink.api.common.operators.Ordering
 
equals(Object) - Method in class org.apache.flink.api.common.operators.ResourceSpec
 
equals(Object) - Method in class org.apache.flink.api.common.operators.util.FieldSet
 
equals(Object) - Method in class org.apache.flink.api.common.operators.util.TypeComparable
 
equals(Object) - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FixedDelayRestartStrategyConfiguration
 
equals(Object) - Method in class org.apache.flink.api.common.state.AggregatingStateDescriptor
 
equals(Object) - Method in class org.apache.flink.api.common.state.FoldingStateDescriptor
Deprecated.
 
equals(Object) - Method in class org.apache.flink.api.common.state.ListStateDescriptor
 
equals(Object) - Method in class org.apache.flink.api.common.state.MapStateDescriptor
 
equals(Object) - Method in class org.apache.flink.api.common.state.ReducingStateDescriptor
 
equals(Object) - Method in class org.apache.flink.api.common.state.StateDescriptor
 
equals(Object) - Method in class org.apache.flink.api.common.state.ValueStateDescriptor
 
equals(Object) - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.common.typeinfo.TypeHint
 
equals(Object) - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializerConfigSnapshot
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.CompositeType
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.GenericTypeSerializerConfigSnapshot
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
 
equals(Object) - Method in interface org.apache.flink.api.common.typeutils.TypeDeserializer
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.TypeDeserializerAdapter
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.TypeSerializerConfigSnapshot
 
equals(Object) - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
equals(Object) - Method in class org.apache.flink.api.java.io.SplitDataProperties.SourcePartitionerMarker
 
equals(Object) - Method in class org.apache.flink.api.java.sca.TaggedValue
 
equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple0
Deep equality for tuples by calling equals() on the tuple members
equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple1
Deep equality for tuples by calling equals() on the tuple members
equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple10
Deep equality for tuples by calling equals() on the tuple members
equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple11
Deep equality for tuples by calling equals() on the tuple members
equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple12
Deep equality for tuples by calling equals() on the tuple members
equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple13
Deep equality for tuples by calling equals() on the tuple members
equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple14
Deep equality for tuples by calling equals() on the tuple members
equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple15
Deep equality for tuples by calling equals() on the tuple members
equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple16
Deep equality for tuples by calling equals() on the tuple members
equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple17
Deep equality for tuples by calling equals() on the tuple members
equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple18
Deep equality for tuples by calling equals() on the tuple members
equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple19
Deep equality for tuples by calling equals() on the tuple members
equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple2
Deep equality for tuples by calling equals() on the tuple members
equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple20
Deep equality for tuples by calling equals() on the tuple members
equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple21
Deep equality for tuples by calling equals() on the tuple members
equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple22
Deep equality for tuples by calling equals() on the tuple members
equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple23
Deep equality for tuples by calling equals() on the tuple members
equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple24
Deep equality for tuples by calling equals() on the tuple members
equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple25
Deep equality for tuples by calling equals() on the tuple members
equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple3
Deep equality for tuples by calling equals() on the tuple members
equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple4
Deep equality for tuples by calling equals() on the tuple members
equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple5
Deep equality for tuples by calling equals() on the tuple members
equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple6
Deep equality for tuples by calling equals() on the tuple members
equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple7
Deep equality for tuples by calling equals() on the tuple members
equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple8
Deep equality for tuples by calling equals() on the tuple members
equals(Object) - Method in class org.apache.flink.api.java.tuple.Tuple9
Deep equality for tuples by calling equals() on the tuple members
equals(Object) - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.ListTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.PojoField
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerConfigSnapshot
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
 
equals(Object) - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.ArrayDescriptor
 
equals(Object) - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.BoxedPrimitiveDescriptor
 
equals(Object) - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.CaseClassDescriptor
 
equals(Object) - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.JavaTupleDescriptor
 
equals(Object) - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.PojoDescriptor
 
equals(Object) - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.TraversableDescriptor
 
equals(Object) - Method in class org.apache.flink.api.scala.typeutils.CaseClassTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.scala.typeutils.EitherSerializer
 
equals(Object) - Method in class org.apache.flink.api.scala.typeutils.EitherTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.scala.typeutils.EnumValueSerializer
 
equals(Object) - Method in class org.apache.flink.api.scala.typeutils.EnumValueSerializer.ScalaEnumSerializerConfigSnapshot
 
equals(Object) - Method in class org.apache.flink.api.scala.typeutils.EnumValueTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.scala.typeutils.NothingSerializer
 
equals(Object) - Method in class org.apache.flink.api.scala.typeutils.OptionSerializer
 
equals(Object) - Method in class org.apache.flink.api.scala.typeutils.OptionTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.scala.typeutils.ScalaNothingTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.scala.typeutils.TraversableSerializer
 
equals(Object) - Method in class org.apache.flink.api.scala.typeutils.TraversableTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.scala.typeutils.TrySerializer
 
equals(Object) - Method in class org.apache.flink.api.scala.typeutils.TryTypeInfo
 
equals(Object) - Method in class org.apache.flink.api.scala.typeutils.UnitTypeInfo
 
equals(Object) - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
 
equals(Object) - Method in class org.apache.flink.cep.nfa.DeweyNumber
 
equals(Object) - Method in class org.apache.flink.cep.nfa.NFA
 
equals(Object) - Method in class org.apache.flink.cep.nfa.NFA.NFASerializer
 
equals(Object) - Method in class org.apache.flink.cep.nfa.SharedBuffer
 
equals(Object) - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferEdge
 
equals(Object) - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
 
equals(Object) - Method in class org.apache.flink.cep.nfa.State
 
equals(Object) - Method in class org.apache.flink.cep.nfa.StateTransition
 
equals(Object) - Method in class org.apache.flink.cep.NonDuplicatingTypeSerializer
 
equals(Object) - Method in class org.apache.flink.cep.pattern.Quantifier
 
equals(Object) - Method in class org.apache.flink.configuration.ConfigOption
 
equals(Object) - Method in class org.apache.flink.configuration.Configuration
 
equals(Object) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
equals(Object) - Method in class org.apache.flink.configuration.MemorySize
 
equals(Object) - Method in class org.apache.flink.core.fs.ClosingFSDataInputStream
 
equals(Object) - Method in class org.apache.flink.core.fs.ClosingFSDataOutputStream
 
equals(Object) - Method in class org.apache.flink.core.fs.FileInputSplit
 
equals(Object) - Method in class org.apache.flink.core.fs.Path
 
equals(Object) - Method in class org.apache.flink.core.io.GenericInputSplit
 
equals(Object) - Method in class org.apache.flink.core.io.LocatableInputSplit
 
equals(Object) - Method in class org.apache.flink.graph.asm.dataset.ChecksumHashCode.Checksum
 
equals(Object) - Method in class org.apache.flink.graph.library.clustering.directed.AverageClusteringCoefficient.Result
 
equals(Object) - Method in class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient.Result
 
equals(Object) - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
 
equals(Object) - Method in class org.apache.flink.graph.library.clustering.undirected.AverageClusteringCoefficient.Result
 
equals(Object) - Method in class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient.Result
 
equals(Object) - Method in class org.apache.flink.graph.library.clustering.undirected.TriadicCensus.Result
 
equals(Object) - Method in class org.apache.flink.graph.library.metric.directed.EdgeMetrics.Result
 
equals(Object) - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
 
equals(Object) - Method in class org.apache.flink.graph.library.metric.undirected.EdgeMetrics.Result
 
equals(Object) - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics.Result
 
equals(Object) - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
 
equals(Object) - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
 
equals(Object) - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
 
equals(Object) - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
 
equals(Object) - Method in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
 
equals(Object) - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingDataSet
 
equals(Object) - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingGraph
 
equals(Object) - Static method in class org.apache.flink.mesos.runtime.clusterframework.RegisteredMesosWorkerNode
 
equals(Object) - Method in class org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore.Worker
 
equals(Object) - Method in class org.apache.flink.migration.api.common.state.ListStateDescriptor
Deprecated.
 
equals(Object) - Method in class org.apache.flink.migration.MigrationNamespaceSerializerProxy
Deprecated.
 
equals(Object) - Method in class org.apache.flink.migration.runtime.checkpoint.KeyGroupState
Deprecated.
 
equals(Object) - Method in class org.apache.flink.migration.runtime.checkpoint.savepoint.SavepointV0
 
equals(Object) - Method in class org.apache.flink.migration.runtime.checkpoint.SubtaskState
Deprecated.
 
equals(Object) - Method in class org.apache.flink.migration.runtime.checkpoint.TaskState
Deprecated.
 
equals(Object) - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer
 
equals(Object) - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.StreamRecordSerializer
 
equals(Object) - Method in class org.apache.flink.migration.util.SerializedValue
Deprecated.
 
equals(Object) - Static method in class org.apache.flink.ml.common.Block
 
equals(Object) - Method in class org.apache.flink.ml.common.LabeledVector
 
equals(Object) - Static method in class org.apache.flink.ml.common.WeightVector
 
equals(Object) - Method in class org.apache.flink.ml.math.DenseMatrix
 
equals(Object) - Method in class org.apache.flink.ml.math.DenseVector
 
equals(Object) - Static method in class org.apache.flink.ml.math.distributed.IndexedRow
 
equals(Object) - Method in class org.apache.flink.ml.math.SparseMatrix
 
equals(Object) - Method in class org.apache.flink.ml.math.SparseVector
 
equals(Object) - Static method in class org.apache.flink.ml.optimization.GenericLossFunction
 
equals(Object) - Static method in class org.apache.flink.ml.pipeline.ChainedPredictor
 
equals(Object) - Static method in class org.apache.flink.ml.pipeline.ChainedTransformer
 
equals(Object) - Method in class org.apache.flink.optimizer.costs.Costs
 
equals(Object) - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
 
equals(Object) - Method in class org.apache.flink.optimizer.dataproperties.InterestingProperties
 
equals(Object) - Method in class org.apache.flink.optimizer.dataproperties.LocalProperties
 
equals(Object) - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
 
equals(Object) - Method in class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
 
equals(Object) - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual.GlobalPropertiesPair
 
equals(Object) - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual.LocalPropertiesPair
 
equals(Object) - Static method in class org.apache.flink.runtime.akka.RemoteAddressExtension
 
equals(Object) - Method in class org.apache.flink.runtime.blob.BlobKey
 
equals(Object) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableKey
 
equals(Object) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetaData
 
equals(Object) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
equals(Object) - Method in class org.apache.flink.runtime.checkpoint.CheckpointProperties
 
equals(Object) - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
equals(Object) - Method in class org.apache.flink.runtime.checkpoint.OperatorState
 
equals(Object) - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
 
equals(Object) - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
 
equals(Object) - Method in class org.apache.flink.runtime.checkpoint.TaskState
Deprecated.
 
equals(Object) - Method in class org.apache.flink.runtime.clusterframework.messages.CheckAndAllocateContainers
 
equals(Object) - Method in class org.apache.flink.runtime.clusterframework.messages.GetClusterStatus
 
equals(Object) - Method in class org.apache.flink.runtime.clusterframework.messages.GetClusterStatusResponse
 
equals(Object) - Method in class org.apache.flink.runtime.clusterframework.messages.RegisterInfoMessageListener
 
equals(Object) - Method in class org.apache.flink.runtime.clusterframework.messages.RegisterInfoMessageListenerSuccessful
 
equals(Object) - Method in class org.apache.flink.runtime.clusterframework.messages.SetWorkerPoolSize
 
equals(Object) - Method in class org.apache.flink.runtime.clusterframework.messages.UnRegisterInfoMessageListener
 
equals(Object) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceID
 
equals(Object) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
 
equals(Object) - Method in class org.apache.flink.runtime.clusterframework.types.SlotID
 
equals(Object) - Method in class org.apache.flink.runtime.instance.Slot
Slots must always compare on referential equality.
equals(Object) - Method in class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
 
equals(Object) - Method in class org.apache.flink.runtime.io.network.api.CancelCheckpointMarker
 
equals(Object) - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
 
equals(Object) - Method in class org.apache.flink.runtime.io.network.api.EndOfPartitionEvent
 
equals(Object) - Method in class org.apache.flink.runtime.io.network.api.EndOfSuperstepEvent
 
equals(Object) - Method in class org.apache.flink.runtime.io.network.ConnectionID
 
equals(Object) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionID
 
equals(Object) - Method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
 
equals(Object) - Method in class org.apache.flink.runtime.jobmanager.JobInfo
 
equals(Object) - Method in exception org.apache.flink.runtime.jobmanager.scheduler.NoResourceAvailableException
 
equals(Object) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
equals(Object) - Method in class org.apache.flink.runtime.jobmanager.slots.AllocatedSlot
This always checks based on reference equality.
equals(Object) - Method in class org.apache.flink.runtime.leaderelection.LeaderAddressAndId
 
equals(Object) - Static method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsErroneous
 
equals(Object) - Static method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsFound
 
equals(Object) - Static method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsNotFound
 
equals(Object) - Static method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultStringsFound
 
equals(Object) - Static method in class org.apache.flink.runtime.messages.accumulators.RequestAccumulatorResults
 
equals(Object) - Static method in class org.apache.flink.runtime.messages.accumulators.RequestAccumulatorResultsStringified
 
equals(Object) - Method in class org.apache.flink.runtime.messages.Acknowledge
 
equals(Object) - Method in class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
 
equals(Object) - Method in class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
 
equals(Object) - Method in class org.apache.flink.runtime.messages.checkpoint.NotifyCheckpointComplete
 
equals(Object) - Method in class org.apache.flink.runtime.messages.checkpoint.TriggerCheckpoint
 
equals(Object) - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
 
equals(Object) - Method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
 
equals(Object) - Method in class org.apache.flink.runtime.messages.webmonitor.JobsWithIDsOverview
 
equals(Object) - Method in class org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails
 
equals(Object) - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
 
equals(Object) - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobsOverview
 
equals(Object) - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobsWithIDsOverview
 
equals(Object) - Method in class org.apache.flink.runtime.messages.webmonitor.RequestStatusOverview
 
equals(Object) - Method in class org.apache.flink.runtime.messages.webmonitor.StatusOverview
 
equals(Object) - Method in class org.apache.flink.runtime.query.KvStateLocation
 
equals(Object) - Method in class org.apache.flink.runtime.query.KvStateServerAddress
 
equals(Object) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
equals(Object) - Method in class org.apache.flink.runtime.state.ChainedStateHandle
 
equals(Object) - Method in class org.apache.flink.runtime.state.filesystem.FileStateHandle
 
equals(Object) - Method in class org.apache.flink.runtime.state.HashMapSerializer
 
equals(Object) - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
This method is should only be called in tests! This should never serve as key in a hash map.
equals(Object) - Method in class org.apache.flink.runtime.state.KeyGroupRange
 
equals(Object) - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
 
equals(Object) - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
 
equals(Object) - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
 
equals(Object) - Method in class org.apache.flink.runtime.state.OperatorStateHandle
 
equals(Object) - Method in class org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo
 
equals(Object) - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo
 
equals(Object) - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo.Snapshot
 
equals(Object) - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo
 
equals(Object) - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo.Snapshot
 
equals(Object) - Method in class org.apache.flink.runtime.state.TaskStateHandles
 
equals(Object) - Method in class org.apache.flink.runtime.state.VoidNamespace
 
equals(Object) - Method in class org.apache.flink.runtime.taskexecutor.slot.SlotOffer
 
equals(Object) - Method in class org.apache.flink.runtime.taskexecutor.SlotStatus
 
equals(Object) - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
equals(Object) - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
 
equals(Object) - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
 
equals(Object) - Method in class org.apache.flink.runtime.webmonitor.history.ArchivedJson
 
equals(Object) - Method in class org.apache.flink.storm.util.SplitStreamType
 
equals(Object) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
equals(Object) - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
 
equals(Object) - Method in class org.apache.flink.streaming.api.graph.StreamEdge
 
equals(Object) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
equals(Object) - Method in class org.apache.flink.streaming.api.operators.InternalTimer
 
equals(Object) - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
 
equals(Object) - Static method in class org.apache.flink.streaming.api.scala.OutputTag
 
equals(Object) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
 
equals(Object) - Method in class org.apache.flink.streaming.api.watermark.Watermark
 
equals(Object) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow
 
equals(Object) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
 
equals(Object) - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
 
equals(Object) - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartition
 
equals(Object) - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionLeader
 
equals(Object) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
 
equals(Object) - Method in class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
 
equals(Object) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
equals(Object) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
 
equals(Object) - Method in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
equals(Object) - Static method in exception org.apache.flink.table.api.AmbiguousTableSourceConverterException
 
equals(Object) - Static method in exception org.apache.flink.table.api.CatalogAlreadyExistException
 
equals(Object) - Static method in exception org.apache.flink.table.api.CatalogNotExistException
 
equals(Object) - Static method in class org.apache.flink.table.api.CurrentRange
 
equals(Object) - Static method in class org.apache.flink.table.api.CurrentRow
 
equals(Object) - Static method in exception org.apache.flink.table.api.ExpressionParserException
 
equals(Object) - Static method in exception org.apache.flink.table.api.ExternalCatalogAlreadyExistException
 
equals(Object) - Static method in exception org.apache.flink.table.api.ExternalCatalogNotExistException
 
equals(Object) - Static method in exception org.apache.flink.table.api.NoMatchedTableSourceConverterException
 
equals(Object) - Static method in class org.apache.flink.table.api.OverWindow
 
equals(Object) - Static method in class org.apache.flink.table.api.scala.OverWindowWithOrderBy
 
equals(Object) - Static method in class org.apache.flink.table.api.scala.PartitionedOver
 
equals(Object) - Static method in exception org.apache.flink.table.api.SqlParserException
 
equals(Object) - Static method in exception org.apache.flink.table.api.TableAlreadyExistException
 
equals(Object) - Static method in exception org.apache.flink.table.api.TableException
 
equals(Object) - Static method in exception org.apache.flink.table.api.TableNotExistException
 
equals(Object) - Static method in class org.apache.flink.table.api.UnboundedRange
 
equals(Object) - Static method in class org.apache.flink.table.api.UnboundedRow
 
equals(Object) - Static method in exception org.apache.flink.table.api.UnresolvedException
 
equals(Object) - Static method in exception org.apache.flink.table.api.ValidationException
 
equals(RexNode, RexNode) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
equals(Object) - Static method in class org.apache.flink.table.catalog.ExternalCatalogTable
 
equals(Object) - Static method in class org.apache.flink.table.codegen.GeneratedAggregationsFunction
 
equals(Object) - Static method in class org.apache.flink.table.codegen.GeneratedCollector
 
equals(Object) - Static method in class org.apache.flink.table.codegen.GeneratedExpression
 
equals(Object) - Static method in class org.apache.flink.table.codegen.GeneratedFunction
 
equals(Object) - Static method in class org.apache.flink.table.codegen.GeneratedInput
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Abs
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Acos
 
equals(Object) - Static method in class org.apache.flink.table.expressions.AggFunctionCall
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Alias
 
equals(Object) - Static method in class org.apache.flink.table.expressions.And
 
equals(Object) - Static method in class org.apache.flink.table.expressions.ArrayCardinality
 
equals(Object) - Static method in class org.apache.flink.table.expressions.ArrayConstructor
 
equals(Object) - Static method in class org.apache.flink.table.expressions.ArrayElement
 
equals(Object) - Static method in class org.apache.flink.table.expressions.ArrayElementAt
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Asc
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Asin
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Atan
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Avg
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Call
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Cast
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Ceil
 
equals(Object) - Static method in class org.apache.flink.table.expressions.CharLength
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Cos
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Cot
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Count
 
equals(Object) - Static method in class org.apache.flink.table.expressions.CurrentDate
 
equals(Object) - Static method in class org.apache.flink.table.expressions.CurrentTime
 
equals(Object) - Static method in class org.apache.flink.table.expressions.CurrentTimestamp
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Degrees
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Desc
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Div
 
equals(Object) - Static method in class org.apache.flink.table.expressions.EqualTo
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Exp
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Extract
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Flattening
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Floor
 
equals(Object) - Static method in class org.apache.flink.table.expressions.GetCompositeField
 
equals(Object) - Static method in class org.apache.flink.table.expressions.GreaterThan
 
equals(Object) - Static method in class org.apache.flink.table.expressions.GreaterThanOrEqual
 
equals(Object) - Static method in class org.apache.flink.table.expressions.If
 
equals(Object) - Static method in class org.apache.flink.table.expressions.InitCap
 
equals(Object) - Static method in class org.apache.flink.table.expressions.IsFalse
 
equals(Object) - Static method in class org.apache.flink.table.expressions.IsNotFalse
 
equals(Object) - Static method in class org.apache.flink.table.expressions.IsNotNull
 
equals(Object) - Static method in class org.apache.flink.table.expressions.IsNotTrue
 
equals(Object) - Static method in class org.apache.flink.table.expressions.IsNull
 
equals(Object) - Static method in class org.apache.flink.table.expressions.IsTrue
 
equals(Object) - Static method in class org.apache.flink.table.expressions.LessThan
 
equals(Object) - Static method in class org.apache.flink.table.expressions.LessThanOrEqual
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Like
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Literal
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Ln
 
equals(Object) - Static method in class org.apache.flink.table.expressions.LocalTime
 
equals(Object) - Static method in class org.apache.flink.table.expressions.LocalTimestamp
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Log10
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Lower
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Max
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Min
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Minus
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Mod
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Mul
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Not
 
equals(Object) - Static method in class org.apache.flink.table.expressions.NotEqualTo
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Null
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Or
 
equals(Object) - Static method in class org.apache.flink.table.expressions.OverCall
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Overlay
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Pi
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Plus
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Position
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Power
 
equals(Object) - Static method in class org.apache.flink.table.expressions.ProctimeAttribute
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Quarter
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Radians
 
equals(Object) - Static method in class org.apache.flink.table.expressions.ResolvedFieldReference
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Round
 
equals(Object) - Static method in class org.apache.flink.table.expressions.RowtimeAttribute
 
equals(Object) - Static method in class org.apache.flink.table.expressions.ScalarFunctionCall
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Sign
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Similar
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Sin
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Sqrt
 
equals(Object) - Static method in class org.apache.flink.table.expressions.StddevPop
 
equals(Object) - Static method in class org.apache.flink.table.expressions.StddevSamp
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Substring
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Sum
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Sum0
 
equals(Object) - Static method in class org.apache.flink.table.expressions.SymbolExpression
 
equals(Object) - Static method in class org.apache.flink.table.expressions.TableFunctionCall
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Tan
 
equals(Object) - Static method in class org.apache.flink.table.expressions.TemporalCeil
 
equals(Object) - Static method in class org.apache.flink.table.expressions.TemporalFloor
 
equals(Object) - Static method in class org.apache.flink.table.expressions.TemporalOverlaps
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Trim
 
equals(Object) - Static method in class org.apache.flink.table.expressions.UDAGGExpression
 
equals(Object) - Static method in class org.apache.flink.table.expressions.UnaryMinus
 
equals(Object) - Static method in class org.apache.flink.table.expressions.UnresolvedAlias
 
equals(Object) - Static method in class org.apache.flink.table.expressions.UnresolvedFieldReference
 
equals(Object) - Static method in class org.apache.flink.table.expressions.UnresolvedOverCall
 
equals(Object) - Static method in class org.apache.flink.table.expressions.Upper
 
equals(Object) - Static method in class org.apache.flink.table.expressions.VarPop
 
equals(Object) - Static method in class org.apache.flink.table.expressions.VarSamp
 
equals(Object) - Static method in class org.apache.flink.table.expressions.WindowEnd
 
equals(Object) - Static method in class org.apache.flink.table.expressions.WindowReference
 
equals(Object) - Static method in class org.apache.flink.table.expressions.WindowStart
 
equals(Object) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
equals(Object) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
equals(Object) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
equals(Object) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
equals(RelOptCost) - Method in class org.apache.flink.table.plan.cost.DataSetCost
 
equals(Object) - Static method in class org.apache.flink.table.plan.logical.Aggregate
 
equals(Object) - Static method in class org.apache.flink.table.plan.logical.AliasNode
 
equals(Object) - Static method in class org.apache.flink.table.plan.logical.CatalogNode
 
equals(Object) - Static method in class org.apache.flink.table.plan.logical.Distinct
 
equals(Object) - Static method in class org.apache.flink.table.plan.logical.Filter
 
equals(Object) - Static method in class org.apache.flink.table.plan.logical.Intersect
 
equals(Object) - Static method in class org.apache.flink.table.plan.logical.Join
 
equals(Object) - Static method in class org.apache.flink.table.plan.logical.Limit
 
equals(Object) - Static method in class org.apache.flink.table.plan.logical.LogicalRelNode
 
equals(Object) - Static method in class org.apache.flink.table.plan.logical.LogicalTableFunctionCall
 
equals(Object) - Static method in class org.apache.flink.table.plan.logical.Minus
 
equals(Object) - Static method in class org.apache.flink.table.plan.logical.Project
 
equals(Object) - Static method in class org.apache.flink.table.plan.logical.SessionGroupWindow
 
equals(Object) - Static method in class org.apache.flink.table.plan.logical.SlidingGroupWindow
 
equals(Object) - Static method in class org.apache.flink.table.plan.logical.Sort
 
equals(Object) - Static method in class org.apache.flink.table.plan.logical.TumblingGroupWindow
 
equals(Object) - Static method in class org.apache.flink.table.plan.logical.Union
 
equals(Object) - Static method in class org.apache.flink.table.plan.logical.WindowAggregate
 
equals(Object) - Static method in class org.apache.flink.table.plan.nodes.datastream.AccModeTrait
 
equals(Object) - Static method in class org.apache.flink.table.plan.nodes.datastream.UpdateAsRetractionTrait
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.dataSet.BatchTableSourceScanRule
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.dataSet.BatchTableSourceScanRule
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateRule
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateRule
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateWithNullValuesRule
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateWithNullValuesRule
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetCalcRule
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetCalcRule
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetCorrelateRule
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetCorrelateRule
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetDistinctRule
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetDistinctRule
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetIntersectRule
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetIntersectRule
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetJoinRule
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetJoinRule
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetLogicalWindowAggregateRule
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetLogicalWindowAggregateRule
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetMinusRule
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetMinusRule
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetScanRule
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetScanRule
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetSingleRowJoinRule
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetSingleRowJoinRule
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetSortRule
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetSortRule
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetUnionRule
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetUnionRule
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetValuesRule
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetValuesRule
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetWindowAggregateRule
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetWindowAggregateRule
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamCalcRule
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamCalcRule
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamCorrelateRule
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamCorrelateRule
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupAggregateRule
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupAggregateRule
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupWindowAggregateRule
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupWindowAggregateRule
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamLogicalWindowAggregateRule
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamLogicalWindowAggregateRule
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamOverAggregateRule
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamOverAggregateRule
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamScanRule
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamScanRule
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamUnionRule
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamUnionRule
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamValuesRule
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamValuesRule
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.datastream.StreamTableSourceScanRule
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.datastream.StreamTableSourceScanRule
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.logical.EnumerableToLogicalTableScan
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.logical.EnumerableToLogicalTableScan
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.logical.LogicalUnnestRule
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.logical.LogicalUnnestRule
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.logical.PushFilterIntoTableSourceScanRule
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.logical.PushFilterIntoTableSourceScanRule
 
equals(Object) - Static method in class org.apache.flink.table.plan.rules.logical.PushProjectIntoTableSourceScanRule
 
equals(RelOptRule) - Static method in class org.apache.flink.table.plan.rules.logical.PushProjectIntoTableSourceScanRule
 
equals(Object) - Method in class org.apache.flink.table.plan.schema.ArrayRelDataType
 
equals(Object) - Method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
equals(Object) - Method in class org.apache.flink.table.plan.schema.GenericRelDataType
 
equals(Object) - Method in class org.apache.flink.table.plan.schema.MapRelDataType
 
equals(Object) - Method in class org.apache.flink.table.plan.schema.TimeIndicatorRelDataType
 
equals(Object) - Static method in class org.apache.flink.table.plan.stats.ColumnStats
 
equals(Object) - Static method in class org.apache.flink.table.plan.stats.TableStats
 
equals(Object) - Method in class org.apache.flink.table.runtime.types.CRow
 
equals(Object) - Method in class org.apache.flink.table.runtime.types.CRowSerializer
 
equals(Object) - Method in class org.apache.flink.table.runtime.types.CRowTypeInfo
 
equals(Object) - Method in class org.apache.flink.table.sources.CsvTableSource
 
equals(Object) - Method in class org.apache.flink.table.typeutils.InternalTypeInfo
 
equals(Object) - Static method in class org.apache.flink.table.typeutils.RowIntervalTypeInfo
 
equals(Object) - Static method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
 
equals(Object) - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
 
equals(Object) - Static method in class org.apache.flink.table.validate.ValidationFailure
 
equals(Object) - Method in class org.apache.flink.types.BooleanValue
 
equals(Object) - Method in class org.apache.flink.types.ByteValue
 
equals(Object) - Method in class org.apache.flink.types.CharValue
 
equals(Object) - Method in class org.apache.flink.types.DoubleValue
 
equals(Object) - Method in class org.apache.flink.types.Either.Left
 
equals(Object) - Method in class org.apache.flink.types.Either.Right
 
equals(Object) - Method in class org.apache.flink.types.FloatValue
 
equals(Object) - Method in class org.apache.flink.types.IntValue
 
equals(Object) - Method in interface org.apache.flink.types.Key
Deprecated.
Compares the object on equality with another object.
equals(Object) - Method in class org.apache.flink.types.ListValue
 
equals(Object) - Method in class org.apache.flink.types.LongValue
 
equals(Object) - Method in class org.apache.flink.types.MapValue
 
equals(Object) - Method in class org.apache.flink.types.NullValue
 
equals(Object) - Method in class org.apache.flink.types.Row
 
equals(Object) - Method in class org.apache.flink.types.ShortValue
 
equals(Object) - Method in class org.apache.flink.types.StringValue
 
equals(Object) - Method in class org.apache.flink.util.AbstractID
 
equals(Object) - Method in class org.apache.flink.util.OutputTag
 
equals(Object) - Method in class org.apache.flink.util.ReflectionUtil.FullTypeInfo
 
equals(Object) - Method in class org.apache.flink.util.SerializedValue
 
equals(Object) - Method in class org.apache.flink.util.StringBasedID
 
equalsFields(int[], Value[], Value[]) - Method in class org.apache.flink.types.Record
Checks the values of this record and a given list of values at specified positions for equality.
equalsMatrix(Matrix) - Static method in class org.apache.flink.ml.math.DenseMatrix
 
equalsMatrix(Matrix) - Method in interface org.apache.flink.ml.math.Matrix
 
equalsMatrix(Matrix) - Static method in class org.apache.flink.ml.math.SparseMatrix
 
equalsVector(Vector) - Static method in class org.apache.flink.ml.math.DenseVector
 
equalsVector(Vector) - Static method in class org.apache.flink.ml.math.SparseVector
 
equalsVector(Vector) - Method in interface org.apache.flink.ml.math.Vector
 
equalTo(int...) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate
Continues a CoGroup transformation and defines the Tuple fields of the second co-grouped DataSet that should be used as grouping keys.
Note: Fields can only be selected as grouping keys on Tuple DataSets.
equalTo(String...) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate
Continues a CoGroup transformation and defines the fields of the second co-grouped DataSet that should be used as grouping keys.
equalTo(KeySelector<I2, K>) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate
Continues a CoGroup transformation and defines a KeySelector function for the second co-grouped DataSet.
The KeySelector function is called for each element of the second DataSet and extracts a single key value on which the DataSet is grouped.
equalTo(int...) - Method in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
Continues a Join transformation and defines the Tuple fields of the second join DataSet that should be used as join keys.
Note: Fields can only be selected as join keys on Tuple DataSets.
The resulting JoinFunctionAssigner needs to be finished by providing a JoinFunction by calling JoinFunctionAssigner.with(JoinFunction)
equalTo(String...) - Method in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
Continues a Join transformation and defines the fields of the second join DataSet that should be used as join keys.
The resulting JoinFunctionAssigner needs to be finished by providing a JoinFunction by calling JoinFunctionAssigner.with(JoinFunction)
equalTo(KeySelector<I2, K>) - Method in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
Continues a Join transformation and defines a KeySelector function for the second join DataSet.
The KeySelector function is called for each element of the second DataSet and extracts a single key value on which the DataSet is joined.
equalTo(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets.JoinOperatorSetsPredicate
Continues a Join transformation and defines the Tuple fields of the second join DataSet that should be used as join keys.
Note: Fields can only be selected as join keys on Tuple DataSets.
equalTo(String...) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets.JoinOperatorSetsPredicate
Continues a Join transformation and defines the fields of the second join DataSet that should be used as join keys.
equalTo(KeySelector<I2, K>) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets.JoinOperatorSetsPredicate
Continues a Join transformation and defines a KeySelector function for the second join DataSet.
The KeySelector function is called for each element of the second DataSet and extracts a single key value on which the DataSet is joined.
equalTo(Seq<Object>) - Method in class org.apache.flink.api.scala.HalfUnfinishedKeyPairOperation
Specify the key fields for the right side of the key based operation.
equalTo(String, Seq<String>) - Method in class org.apache.flink.api.scala.HalfUnfinishedKeyPairOperation
Specify the key fields for the right side of the key based operation.
equalTo(Function1<R, K>, TypeInformation<K>) - Method in class org.apache.flink.api.scala.HalfUnfinishedKeyPairOperation
Specify the key selector function for the right side of the key based operation.
equalTo(KeySelector<T2, KEY>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.Where
Specifies a KeySelector for elements from the second input.
equalTo(KeySelector<T2, KEY>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.Where
Specifies a KeySelector for elements from the second input.
equalTo(Function1<T2, KEY>) - Method in class org.apache.flink.streaming.api.scala.CoGroupedStreams.Where
Specifies a KeySelector for elements from the second input.
EqualTo(KeySelector<T2, KEY>) - Constructor for class org.apache.flink.streaming.api.scala.CoGroupedStreams.Where.EqualTo
 
equalTo(Function1<T2, KEY>) - Method in class org.apache.flink.streaming.api.scala.JoinedStreams.Where
Specifies a KeySelector for elements from the second input.
EqualTo(KeySelector<T2, KEY>) - Constructor for class org.apache.flink.streaming.api.scala.JoinedStreams.Where.EqualTo
 
EqualTo - Class in org.apache.flink.table.expressions
 
EqualTo(Expression, Expression) - Constructor for class org.apache.flink.table.expressions.EqualTo
 
equalTo() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
equalTo() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
EqualTo$ - Class in org.apache.flink.table.expressions
 
EqualTo$() - Constructor for class org.apache.flink.table.expressions.EqualTo$
 
equalToReference(T) - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
equalToReference(T) - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
equalToReference(BooleanValue) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
equalToReference(ByteValue) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
equalToReference(CharValue) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
equalToReference(DoubleValue) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
equalToReference(FloatValue) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
equalToReference(IntValue) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
equalToReference(LongValue) - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
equalToReference(NullValue) - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
equalToReference(ShortValue) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
equalToReference(StringValue) - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
equalToReference(T2) - Method in class org.apache.flink.api.common.typeutils.GenericPairComparator
 
equalToReference(T) - Method in class org.apache.flink.api.common.typeutils.SameTypePairComparator
 
equalToReference(T) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Checks, whether the given element is equal to the element that has been set as the comparison reference in this comparator instance.
equalToReference(T2) - Method in class org.apache.flink.api.common.typeutils.TypePairComparator
Checks, whether the given candidate instance is equal to the reference instance, with respect to this comparator's equality definition.
equalToReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
equalToReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
equalToReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
equalToReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
equalToReference(Row) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
 
equalToReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
 
equalToReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
equalToReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
 
equalToReference(T) - Method in class org.apache.flink.api.scala.typeutils.CaseClassComparator
 
equalToReference(Enumeration.Value) - Method in class org.apache.flink.api.scala.typeutils.EnumValueComparator
 
equalToReference(Option<A>) - Method in class org.apache.flink.api.scala.typeutils.OptionTypeComparator
 
equalToReference(IntValueArray) - Method in class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
 
equalToReference(LongValueArray) - Method in class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
 
equalToReference(NullValueArray) - Method in class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
 
equalToReference(StringValueArray) - Method in class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
 
equalToReference(CRow) - Method in class org.apache.flink.table.runtime.types.CRowComparator
 
EquiJoin(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, FlatJoinFunction<I1, I2, OUT>, TypeInformation<OUT>, JoinOperatorBase.JoinHint, String) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
 
EquiJoin(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, FlatJoinFunction<I1, I2, OUT>, JoinFunction<I1, I2, OUT>, TypeInformation<OUT>, JoinOperatorBase.JoinHint, String) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
 
EquiJoin(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, FlatJoinFunction<I1, I2, OUT>, TypeInformation<OUT>, JoinOperatorBase.JoinHint, String, JoinType) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
 
EquiJoin(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, FlatJoinFunction<I1, I2, OUT>, JoinFunction<I1, I2, OUT>, TypeInformation<OUT>, JoinOperatorBase.JoinHint, String, JoinType) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
 
eraseTimestamp() - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
 
eraseTimestamp() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
 
err(String) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
Error - Class in org.apache.flink.mesos.scheduler.messages
Message sent when there is an unrecoverable error in the scheduler or driver.
Error(String) - Constructor for class org.apache.flink.mesos.scheduler.messages.Error
 
error(SchedulerDriver, String) - Method in class org.apache.flink.mesos.scheduler.SchedulerProxy
 
error() - Method in class org.apache.flink.runtime.clusterframework.messages.FatalErrorOccurred
 
error() - Method in class org.apache.flink.runtime.messages.ExecutionGraphMessages.JobStatusChanged
 
errorOccured - Static variable in class org.apache.flink.storm.split.operators.VerifyAndEnrichBolt
 
errorOccured - Static variable in class org.apache.flink.storm.split.SpoutSplitExample.Enrich
 
errorPrinter - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
errors() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.UnsupportedDescriptor
 
ErrorTolerance$() - Constructor for class org.apache.flink.ml.outlier.StochasticOutlierSelection.ErrorTolerance$
 
ESCAPE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Internal operator used to represent the ESCAPE clause of a LIKE or SIMILAR TO expression.
estimateDataTypeSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
estimateDataTypeSize(RelDataType) - Method in interface org.apache.flink.table.plan.nodes.FlinkRelNode
 
estimateDataTypeSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
estimateDataTypeSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
estimateDataTypeSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
estimateDataTypeSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
estimateDataTypeSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
estimateDataTypeSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
estimateDataTypeSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
estimateDataTypeSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
estimateDataTypeSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
estimateDataTypeSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
estimateDataTypeSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
estimateDataTypeSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
estimateDataTypeSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
estimateDataTypeSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
estimatedNumRecords - Variable in class org.apache.flink.optimizer.dag.OptimizerNode
 
estimatedOutputSize - Variable in class org.apache.flink.optimizer.dag.OptimizerNode
 
estimateFalsePositiveProbability(long, int) - Static method in class org.apache.flink.runtime.operators.util.BloomFilter
Compute the false positive probability based on given input entries and bits size.
EstimateProvider - Interface in org.apache.flink.optimizer.dag
Methods for operators / connections that provide estimated about data size and characteristics.
estimateRowCount(RelMetadataQuery) - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
estimateRowCount(RexProgram, double) - Method in interface org.apache.flink.table.plan.nodes.CommonCalc
 
estimateRowCount(RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetCalc
 
estimateRowCount(RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetMinus
 
estimateRowCount(RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetSort
 
estimateRowCount(RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetUnion
 
estimateRowCount(RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamCalc
 
estimateRowCount(RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
estimateRowCount(RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
estimateRowCount(RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
estimateRowCount(RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
estimateRowCount(RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
estimateRowCount(RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
estimateRowCount(RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
estimateRowCount(RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
estimateRowCount(RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
estimateRowCount(RelMetadataQuery) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
estimateRowCount(RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
estimateRowCount(RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
estimateRowCount(RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
estimateRowCount(RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
estimateRowCount(RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
estimateRowSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
estimateRowSize(RelDataType) - Method in interface org.apache.flink.table.plan.nodes.FlinkRelNode
 
estimateRowSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
estimateRowSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
estimateRowSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
estimateRowSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
estimateRowSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
estimateRowSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
estimateRowSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
estimateRowSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
estimateRowSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
estimateRowSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
estimateRowSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
estimateRowSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
estimateRowSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
estimateRowSize(RelDataType) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
Estimator<Self> - Interface in org.apache.flink.ml.pipeline
Base trait for Flink's pipeline operators.
Estimator$ - Class in org.apache.flink.ml.pipeline
 
Estimator$() - Constructor for class org.apache.flink.ml.pipeline.Estimator$
 
euclideanDistance(KMeans.Point) - Method in class org.apache.flink.examples.java.clustering.KMeans.Point
 
euclideanDistance(KMeans.Coordinate) - Method in interface org.apache.flink.examples.scala.clustering.KMeans.Coordinate
 
euclideanDistance(EuclideanGraphWeighing.Point) - Method in class org.apache.flink.graph.examples.EuclideanGraphWeighing.Point
 
EuclideanDistance<DATA> - Class in org.apache.flink.streaming.api.functions.windowing.delta
This delta function calculates the euclidean distance between two given points.
EuclideanDistance() - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.EuclideanDistance
 
EuclideanDistance(Extractor<DATA, double[]>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.EuclideanDistance
 
EuclideanDistanceMetric - Class in org.apache.flink.ml.metrics.distances
This class implements a Euclidean distance metric.
EuclideanDistanceMetric() - Constructor for class org.apache.flink.ml.metrics.distances.EuclideanDistanceMetric
 
EuclideanDistanceMetric$ - Class in org.apache.flink.ml.metrics.distances
 
EuclideanDistanceMetric$() - Constructor for class org.apache.flink.ml.metrics.distances.EuclideanDistanceMetric$
 
EuclideanGraphData - Class in org.apache.flink.graph.examples.data
Provides the default data sets used for the Euclidean Graph example program.
EuclideanGraphWeighing - Class in org.apache.flink.graph.examples
This example shows how to use Gelly's Graph.getTriplets() and Graph.joinWithEdges(DataSet, EdgeJoinFunction) methods.
EuclideanGraphWeighing() - Constructor for class org.apache.flink.graph.examples.EuclideanGraphWeighing
 
EuclideanGraphWeighing.Point - Class in org.apache.flink.graph.examples
A simple two-dimensional point.
eval(boolean[]) - Method in class org.apache.flink.table.plan.util.BooleanExplodeTableFunc
 
eval(byte[]) - Method in class org.apache.flink.table.plan.util.ByteExplodeTableFunc
 
eval(double[]) - Method in class org.apache.flink.table.plan.util.DoubleExplodeTableFunc
 
eval(float[]) - Method in class org.apache.flink.table.plan.util.FloatExplodeTableFunc
 
eval(int[]) - Method in class org.apache.flink.table.plan.util.IntExplodeTableFunc
 
eval(long[]) - Method in class org.apache.flink.table.plan.util.LongExplodeTableFunc
 
eval(Object[]) - Method in class org.apache.flink.table.plan.util.ObjectExplodeTableFunc
 
eval(short[]) - Method in class org.apache.flink.table.plan.util.ShortExplodeTableFunc
 
evalMethod() - Method in class org.apache.flink.table.plan.schema.FlinkTableFunctionImpl
 
evaluate(DataSet<Testing>, ParameterMap, EvaluateDataSetOperation<Self, Testing, PredictionValue>) - Static method in class org.apache.flink.ml.classification.SVM
 
evaluate(DataSet<Testing>, ParameterMap, EvaluateDataSetOperation<Self, Testing, PredictionValue>) - Static method in class org.apache.flink.ml.nn.KNN
 
evaluate(DataSet<Testing>, ParameterMap, EvaluateDataSetOperation<Self, Testing, PredictionValue>) - Static method in class org.apache.flink.ml.pipeline.ChainedPredictor
 
evaluate(DataSet<Testing>, ParameterMap, EvaluateDataSetOperation<Self, Testing, PredictionValue>) - Method in interface org.apache.flink.ml.pipeline.Predictor
Evaluates the testing data by computing the prediction value and returning a pair of true label value and prediction value.
evaluate(DataSet<Testing>, ParameterMap, EvaluateDataSetOperation<Self, Testing, PredictionValue>) - Static method in class org.apache.flink.ml.recommendation.ALS
 
evaluate(DataSet<Testing>, ParameterMap, EvaluateDataSetOperation<Self, Testing, PredictionValue>) - Static method in class org.apache.flink.ml.regression.MultipleLinearRegression
 
evaluate$default$2() - Static method in class org.apache.flink.ml.classification.SVM
 
evaluate$default$2() - Static method in class org.apache.flink.ml.nn.KNN
 
evaluate$default$2() - Static method in class org.apache.flink.ml.pipeline.ChainedPredictor
 
evaluate$default$2() - Static method in class org.apache.flink.ml.recommendation.ALS
 
evaluate$default$2() - Static method in class org.apache.flink.ml.regression.MultipleLinearRegression
 
evaluateDataSet(Instance, ParameterMap, DataSet<Testing>) - Method in interface org.apache.flink.ml.pipeline.EvaluateDataSetOperation
 
EvaluateDataSetOperation<Instance,Testing,Prediction> - Interface in org.apache.flink.ml.pipeline
Type class for the evaluate operation of Predictor.
evaluateWindow(Collector<Result>, TimeWindow, AbstractStreamOperator<Result>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
 
evaluateWindow(Collector<Result>, TimeWindow, AbstractStreamOperator<Result>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AccumulatingKeyedTimePanes
 
evaluateWindow(Collector<Type>, TimeWindow, AbstractStreamOperator<Type>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AggregatingKeyedTimePanes
 
EVEN_STREAM - Static variable in class org.apache.flink.storm.split.operators.RandomSpout
 
Event() - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
Event() - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
Event() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
Event() - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
EventListener<T> - Interface in org.apache.flink.runtime.util.event
 
EventSerializer - Class in org.apache.flink.runtime.io.network.api.serialization
Utility class to serialize and deserialize task events.
EventSerializer() - Constructor for class org.apache.flink.runtime.io.network.api.serialization.EventSerializer
 
EventTimeSessionWindows - Class in org.apache.flink.streaming.api.windowing.assigners
A WindowAssigner that windows elements into sessions based on the timestamp of the elements.
EventTimeSessionWindows(long) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
 
EventTimeTrigger - Class in org.apache.flink.streaming.api.windowing.triggers
A Trigger that fires once the watermark passes the end of the window to which a pane belongs.
eventualOutputs - Variable in class org.apache.flink.runtime.operators.BatchTask
The output writers for the data that this task forwards to the next task.
every(Expression) - Method in class org.apache.flink.table.api.SlideWithSize
Specifies the window's slide as time or row-count interval.
every(String) - Method in class org.apache.flink.table.api.SlideWithSize
Specifies the window's slide as time or row-count interval.
evictAfter(Iterable<TimestampedValue<Object>>, int, W, Evictor.EvictorContext) - Method in class org.apache.flink.streaming.api.windowing.evictors.CountEvictor
 
evictAfter(Iterable<TimestampedValue<T>>, int, W, Evictor.EvictorContext) - Method in class org.apache.flink.streaming.api.windowing.evictors.DeltaEvictor
 
evictAfter(Iterable<TimestampedValue<T>>, int, W, Evictor.EvictorContext) - Method in interface org.apache.flink.streaming.api.windowing.evictors.Evictor
Optionally evicts elements.
evictAfter(Iterable<TimestampedValue<Object>>, int, W, Evictor.EvictorContext) - Method in class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
 
evictBefore(Iterable<TimestampedValue<Object>>, int, W, Evictor.EvictorContext) - Method in class org.apache.flink.streaming.api.windowing.evictors.CountEvictor
 
evictBefore(Iterable<TimestampedValue<T>>, int, W, Evictor.EvictorContext) - Method in class org.apache.flink.streaming.api.windowing.evictors.DeltaEvictor
 
evictBefore(Iterable<TimestampedValue<T>>, int, W, Evictor.EvictorContext) - Method in interface org.apache.flink.streaming.api.windowing.evictors.Evictor
Optionally evicts elements.
evictBefore(Iterable<TimestampedValue<Object>>, int, W, Evictor.EvictorContext) - Method in class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
 
EvictingBoundedList<T> - Class in org.apache.flink.runtime.util
This class implements a list (array based) that is physically bounded in maximum size, but can virtually grow beyond the bounded size.
EvictingBoundedList(int) - Constructor for class org.apache.flink.runtime.util.EvictingBoundedList
 
EvictingBoundedList(EvictingBoundedList<T>) - Constructor for class org.apache.flink.runtime.util.EvictingBoundedList
 
EvictingBoundedList(int, T) - Constructor for class org.apache.flink.runtime.util.EvictingBoundedList
 
EvictingBoundedList.Function<I,O> - Interface in org.apache.flink.runtime.util
A simple unary function that can be used to transform elements via the EvictingBoundedList.map(Function) method.
EvictingWindowOperator<K,IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing
A WindowOperator that also allows an Evictor to be used.
EvictingWindowOperator(WindowAssigner<? super IN, W>, TypeSerializer<W>, KeySelector<IN, K>, TypeSerializer<K>, StateDescriptor<? extends ListState<StreamRecord<IN>>, ?>, InternalWindowFunction<Iterable<IN>, OUT, K, W>, Trigger<? super IN, ? super W>, Evictor<? super IN, ? super W>, long, OutputTag<IN>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
 
evictionSec() - Method in class org.apache.flink.streaming.scala.examples.windowing.TopSpeedWindowing$
 
evictionSec() - Static method in class org.apache.flink.streaming.scala.examples.windowing.TopSpeedWindowing
 
evictor(Evictor<? super T, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Sets the Evictor that should be used to evict elements from a window before emission.
evictor(Evictor<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
Sets the Evictor that should be used to evict elements from a window before emission.
evictor(Evictor<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
Sets the Evictor that should be used to evict elements from a window before emission.
evictor(Evictor<? super T, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Sets the Evictor that should be used to evict elements from a window before emission.
evictor(Evictor<? super T, ? super W>) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Sets the Evictor that should be used to evict elements from a window before emission.
evictor(Evictor<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>) - Method in class org.apache.flink.streaming.api.scala.CoGroupedStreams.Where.EqualTo.WithWindow
Sets the Evictor that should be used to evict elements from a window before emission.
evictor(Evictor<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>) - Method in class org.apache.flink.streaming.api.scala.JoinedStreams.Where.EqualTo.WithWindow
Sets the Evictor that should be used to evict elements from a window before emission.
evictor(Evictor<? super T, ? super W>) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Sets the Evictor that should be used to evict elements from a window before emission.
Evictor<T,W extends Window> - Interface in org.apache.flink.streaming.api.windowing.evictors
An Evictor can remove elements from a pane before/after the evaluation of WindowFunction and after the window evaluation gets triggered by a Trigger
Evictor.EvictorContext - Interface in org.apache.flink.streaming.api.windowing.evictors
A context object that is given to Evictor methods.
EXCEPT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
EXCEPT_ALL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
EXCEPTED_RESULT - Static variable in class org.apache.flink.test.testdata.WebLogAnalysisData
 
exception - Variable in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
An exception that was encountered by the asynchronous request handling thread.
exception - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraSinkBase
 
exceptionally(ApplyFunction<Throwable, ? extends R>) - Method in interface org.apache.flink.runtime.concurrent.Future
Applies the given function to the value of the future if the future has been completed exceptionally.
exceptionally(ApplyFunction<Throwable, ? extends R>) - Method in class org.apache.flink.runtime.concurrent.impl.FlinkFuture
 
exceptionallyAsync(ApplyFunction<Throwable, ? extends R>, Executor) - Method in interface org.apache.flink.runtime.concurrent.Future
Applies the given function to the value of the future if the future has been completed exceptionally.
exceptionallyAsync(ApplyFunction<Throwable, ? extends R>, Executor) - Method in class org.apache.flink.runtime.concurrent.impl.FlinkFuture
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.flink.mesos.util.MesosArtifactServer.VirtualFileServerHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.flink.runtime.webmonitor.files.StaticFileServerHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.flink.runtime.webmonitor.history.HistoryServerStaticFileServerHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class org.apache.flink.runtime.webmonitor.PipelineErrorHandler
 
ExceptionHandler<E extends Throwable> - Interface in org.apache.flink.runtime.operators.sort
Interface to be implemented by classes that handle exceptions.
ExceptionInChainedOperatorException - Exception in org.apache.flink.streaming.runtime.tasks
A special exception that signifies that the cause exception came from a chained operator.
ExceptionInChainedOperatorException(Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.ExceptionInChainedOperatorException
 
ExceptionInChainedOperatorException(String, Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.ExceptionInChainedOperatorException
 
ExceptionInChainedStubException - Exception in org.apache.flink.runtime.operators.chaining
A special exception to indicate that an exception occurred in the nested call of a chained stub.
ExceptionInChainedStubException(String, Exception) - Constructor for exception org.apache.flink.runtime.operators.chaining.ExceptionInChainedStubException
 
ExceptionProxy - Class in org.apache.flink.streaming.connectors.kafka.internals
A proxy that communicates exceptions between threads.
ExceptionProxy(Thread) - Constructor for class org.apache.flink.streaming.connectors.kafka.internals.ExceptionProxy
Creates an exception proxy that interrupts the given thread upon report of an exception.
exceptionUnwrap(Exception) - Static method in exception org.apache.flink.runtime.operators.chaining.ExceptionInChainedStubException
 
ExceptionUtils - Class in org.apache.flink.util
A collection of utility functions for dealing with exceptions and exception workflows.
EXCLAMATION_COUNT - Static variable in class org.apache.flink.storm.exclamation.operators.ExclamationBolt
 
ExclamationBolt - Class in org.apache.flink.storm.exclamation.operators
 
ExclamationBolt() - Constructor for class org.apache.flink.storm.exclamation.operators.ExclamationBolt
 
ExclamationLocal - Class in org.apache.flink.storm.exclamation
Implements the "Exclamation" program that attaches five exclamation mark to every line of a text files in a streaming fashion.
ExclamationLocal() - Constructor for class org.apache.flink.storm.exclamation.ExclamationLocal
 
ExclamationTopology - Class in org.apache.flink.storm.exclamation
Implements the "Exclamation" program that attaches two exclamation marks to every line of a text files in a streaming fashion.
ExclamationTopology() - Constructor for class org.apache.flink.storm.exclamation.ExclamationTopology
 
ExclamationWithBolt - Class in org.apache.flink.storm.exclamation
Implements the "Exclamation" program that attaches 3+x exclamation marks to every line of a text files in a streaming fashion.
ExclamationWithBolt() - Constructor for class org.apache.flink.storm.exclamation.ExclamationWithBolt
 
ExclamationWithSpout - Class in org.apache.flink.storm.exclamation
Implements the "Exclamation" program that attaches six exclamation marks to every line of a text files in a streaming fashion.
ExclamationWithSpout() - Constructor for class org.apache.flink.storm.exclamation.ExclamationWithSpout
 
excludeFromReset(int) - Method in class org.apache.flink.runtime.operators.BatchTask
 
execEnv() - Method in class org.apache.flink.table.api.BatchTableEnvironment
 
execEnv() - Method in class org.apache.flink.table.api.StreamTableEnvironment
 
executable - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
executable - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
 
executablesEquals(Method) - Method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils.LambdaExecutable
 
executablesEquals(Constructor<?>) - Method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils.LambdaExecutable
 
execute(Plan) - Method in class org.apache.flink.api.common.operators.CollectionExecutor
 
execute(String) - Method in class org.apache.flink.api.java.CollectionEnvironment
 
execute() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Triggers the program execution.
execute(String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Triggers the program execution.
execute(String) - Method in class org.apache.flink.api.java.LocalEnvironment
 
execute(String) - Method in class org.apache.flink.api.java.RemoteEnvironment
 
execute(AbstractInsnNode, Interpreter) - Method in class org.apache.flink.api.java.sca.ModifiedASMFrame
 
execute() - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Triggers the program execution.
execute(String) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Triggers the program execution.
execute(Program, String...) - Static method in class org.apache.flink.client.LocalExecutor
Executes the given program.
execute(Plan) - Static method in class org.apache.flink.client.LocalExecutor
Executes the given dataflow plan.
execute(String) - Method in class org.apache.flink.client.program.ContextEnvironment
 
execute(String) - Method in class org.apache.flink.client.program.DetachedEnvironment
 
execute(String) - Method in class org.apache.flink.client.program.OptimizerPlanEnvironment
 
execute(String) - Method in class org.apache.flink.client.program.PreviewPlanEnvironment
 
execute(Runnable) - Method in class org.apache.flink.core.testutils.ManuallyTriggeredDirectExecutor
 
execute() - Method in class org.apache.flink.graph.AbstractGraphAnalytic
 
execute(String) - Method in class org.apache.flink.graph.AbstractGraphAnalytic
 
execute() - Method in class org.apache.flink.graph.asm.dataset.AbstractDataSetAnalytic
 
execute(String) - Method in class org.apache.flink.graph.asm.dataset.AbstractDataSetAnalytic
 
execute() - Method in interface org.apache.flink.graph.asm.dataset.DataSetAnalytic
Execute the program and return the result.
execute(String) - Method in interface org.apache.flink.graph.asm.dataset.DataSetAnalytic
Execute the program and return the result.
execute() - Method in interface org.apache.flink.graph.GraphAnalytic
Execute the program and return the result.
execute(String) - Method in interface org.apache.flink.graph.GraphAnalytic
Execute the program and return the result.
execute(Runnable) - Method in class org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter
 
execute(Runnable) - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
execute(Callable<T>) - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
execute(Runnable) - Method in interface org.apache.flink.runtime.rpc.RpcService
Execute the given runnable in the executor of the RPC service.
execute(Callable<T>) - Method in interface org.apache.flink.runtime.rpc.RpcService
Execute the given callable and return its result as a Future.
execute() - Method in class org.apache.flink.storm.api.FlinkTopology
Directly executes the Storm topology based on the current context (local when in IDE and remote when executed through ./bin/flink).
execute(Tuple) - Method in class org.apache.flink.storm.exclamation.operators.ExclamationBolt
 
execute(Tuple) - Method in class org.apache.flink.storm.split.operators.VerifyAndEnrichBolt
 
execute(Tuple) - Method in class org.apache.flink.storm.util.AbstractBoltSink
 
execute(Tuple) - Method in class org.apache.flink.storm.wordcount.operators.BoltCounter
 
execute(Tuple) - Method in class org.apache.flink.storm.wordcount.operators.BoltCounterByName
 
execute(Tuple) - Method in class org.apache.flink.storm.wordcount.operators.BoltTokenizer
 
execute(Tuple) - Method in class org.apache.flink.storm.wordcount.operators.BoltTokenizerByName
 
execute(String) - Method in class org.apache.flink.streaming.api.environment.Flip6LocalStreamEnvironment
Executes the JobGraph of the on a mini cluster of CLusterUtil with a user specified name.
execute(String) - Method in class org.apache.flink.streaming.api.environment.LocalStreamEnvironment
Executes the JobGraph of the on a mini cluster of CLusterUtil with a user specified name.
execute(String) - Method in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
 
execute(String) - Method in class org.apache.flink.streaming.api.environment.StreamContextEnvironment
 
execute() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Triggers the program execution.
execute(String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Triggers the program execution.
execute() - Method in class org.apache.flink.streaming.api.environment.StreamPlanEnvironment
 
execute(String) - Method in class org.apache.flink.streaming.api.environment.StreamPlanEnvironment
 
execute() - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Triggers the program execution.
execute(String) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Triggers the program execution.
execute(String) - Method in class org.apache.flink.streaming.util.TestStreamEnvironment
 
execute() - Method in class org.apache.flink.test.util.CollectionTestEnvironment
 
execute(String) - Method in class org.apache.flink.test.util.CollectionTestEnvironment
 
execute(String) - Method in class org.apache.flink.test.util.TestEnvironment
 
executeOnCollections(List<T>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
 
executeOnCollections(List<IN1>, List<IN2>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
executeOnCollections(List<IN1>, List<IN2>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
 
executeOnCollections(List<IN1>, List<IN2>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.CrossOperatorBase
 
executeOnCollections(List<ST>, List<WT>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
 
executeOnCollections(List<T>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.FilterOperatorBase
 
executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.FlatMapOperatorBase
 
executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.GroupCombineOperatorBase
 
executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
 
executeOnCollections(List<IN1>, List<IN2>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.InnerJoinOperatorBase
 
executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.MapOperatorBase
 
executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.MapPartitionOperatorBase
 
executeOnCollections(List<IN1>, List<IN2>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.OuterJoinOperatorBase
 
executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
executeOnCollections(List<T>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.ReduceOperatorBase
 
executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.base.SortPartitionOperatorBase
 
executeOnCollections(List<IN1>, List<IN2>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.DualInputOperator
 
executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
 
executeOnCollections(RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
 
executeOnCollections(List<IN>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
 
executeOnCollections(List<T>, List<T>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.api.common.operators.Union
 
executeOnCollections(List<OUT>, List<OUT>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.optimizer.util.NoOpBinaryUdfOp
 
executeOnCollections(List<OUT>, RuntimeContext, ExecutionConfig) - Method in class org.apache.flink.optimizer.util.NoOpUnaryUdfOp
 
executePlan(Plan) - Method in class org.apache.flink.api.common.PlanExecutor
Execute the given program.
executePlan(Plan) - Method in class org.apache.flink.client.LocalExecutor
Executes the given program on a local runtime and waits for the job to finish.
executePlan(Plan) - Method in class org.apache.flink.client.RemoteExecutor
 
executePlanWithJars(JobWithJars) - Method in class org.apache.flink.client.RemoteExecutor
 
executeProgram(PackagedProgram, ClusterClient, int) - Method in class org.apache.flink.client.CliFrontend
 
executeRemotely(StreamGraph, List<URL>) - Method in class org.apache.flink.api.java.ScalaShellRemoteStreamEnvironment
Executes the remote job.
executeRemotely(StreamGraph, List<URL>) - Method in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
Executes the remote job.
Execution - Class in org.apache.flink.runtime.executiongraph
A single execution of a vertex.
Execution(Executor, ExecutionVertex, int, long, long, Time) - Constructor for class org.apache.flink.runtime.executiongraph.Execution
Creates a new Execution attempt.
EXECUTION_ENVIRONMENT_NAME() - Method in class org.apache.flink.ml.common.FlinkMLTools$
 
EXECUTION_ENVIRONMENT_NAME() - Static method in class org.apache.flink.ml.common.FlinkMLTools
 
EXECUTION_FAILOVER_STRATEGY - Static variable in class org.apache.flink.configuration.JobManagerOptions
The maximum number of prior execution attempts kept in history.
EXECUTION_RETRIES_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
The configuration value will be replaced by ConfigConstants.RESTART_STRATEGY_FIXED_DELAY_ATTEMPTS and the corresponding FixedDelayRestartStrategy.
EXECUTION_RETRY_DELAY_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
The configuration value will be replaced by ConfigConstants.RESTART_STRATEGY_FIXED_DELAY_DELAY and the corresponding FixedDelayRestartStrategy.
ExecutionAndSlot - Class in org.apache.flink.runtime.executiongraph
A pair of an Execution together with a slot future.
ExecutionAndSlot(Execution, Future<SimpleSlot>) - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionAndSlot
 
executionAttempt - Variable in class org.apache.flink.runtime.executiongraph.ExecutionAndSlot
 
executionAttempt() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RequestNextInputSplit
 
ExecutionAttemptID - Class in org.apache.flink.runtime.executiongraph
Unique identifier for the attempt to execute a tasks.
ExecutionAttemptID() - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionAttemptID
 
ExecutionAttemptID(long, long) - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionAttemptID
 
ExecutionConfig - Class in org.apache.flink.api.common
A config to define the behavior of the program execution.
ExecutionConfig() - Constructor for class org.apache.flink.api.common.ExecutionConfig
 
executionConfig - Variable in class org.apache.flink.api.common.Plan
Config object for runtime execution parameters.
executionConfig - Variable in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
executionConfig() - Method in class org.apache.flink.streaming.api.scala.DataStream
Returns the execution config.
ExecutionConfig.GlobalJobParameters - Class in org.apache.flink.api.common
Abstract class for a custom user configuration object registered at the execution config.
ExecutionConfig.SerializableSerializer<T extends com.esotericsoftware.kryo.Serializer<?> & Serializable> - Class in org.apache.flink.api.common
 
executionContext() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
ExecutionEdge - Class in org.apache.flink.runtime.executiongraph
 
ExecutionEdge(IntermediateResultPartition, ExecutionVertex, int) - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionEdge
 
ExecutionEnvironment - Class in org.apache.flink.api.java
The ExecutionEnvironment is the context in which a program is executed.
ExecutionEnvironment() - Constructor for class org.apache.flink.api.java.ExecutionEnvironment
Creates a new Execution Environment.
ExecutionEnvironment - Class in org.apache.flink.api.scala
The ExecutionEnvironment is the context in which a program is executed.
ExecutionEnvironment(ExecutionEnvironment) - Constructor for class org.apache.flink.api.scala.ExecutionEnvironment
 
executionEnvironment() - Method in class org.apache.flink.streaming.api.scala.DataStream
Returns the StreamExecutionEnvironment associated with this data stream
ExecutionEnvironment$ - Class in org.apache.flink.api.scala
 
ExecutionEnvironment$() - Constructor for class org.apache.flink.api.scala.ExecutionEnvironment$
 
ExecutionEnvironmentFactory - Interface in org.apache.flink.api.java
Factory class for execution environments.
ExecutionGraph - Class in org.apache.flink.runtime.executiongraph
The execution graph is the central data structure that coordinates the distributed execution of a data flow.
ExecutionGraph(ScheduledExecutorService, Executor, JobID, String, Configuration, SerializedValue<ExecutionConfig>, Time, RestartStrategy, FailoverStrategy.Factory, List<BlobKey>, List<URL>, SlotProvider, ClassLoader) - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
executionGraph() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.JobFound
 
ExecutionGraphBuilder - Class in org.apache.flink.runtime.executiongraph
Utility class to encapsulate the logic of building an ExecutionGraph from a JobGraph.
ExecutionGraphException - Exception in org.apache.flink.runtime.executiongraph
Base class for exceptions occurring in the ExecutionGraph.
ExecutionGraphException(String) - Constructor for exception org.apache.flink.runtime.executiongraph.ExecutionGraphException
 
ExecutionGraphException(String, Throwable) - Constructor for exception org.apache.flink.runtime.executiongraph.ExecutionGraphException
 
ExecutionGraphException(Throwable) - Constructor for exception org.apache.flink.runtime.executiongraph.ExecutionGraphException
 
ExecutionGraphException - Exception in org.apache.flink.runtime.jobmaster
Exceptions thrown by operations on the ExecutionGraph by the JobMaster.
ExecutionGraphException(String) - Constructor for exception org.apache.flink.runtime.jobmaster.ExecutionGraphException
 
ExecutionGraphException(String, Throwable) - Constructor for exception org.apache.flink.runtime.jobmaster.ExecutionGraphException
 
ExecutionGraphException(Throwable) - Constructor for exception org.apache.flink.runtime.jobmaster.ExecutionGraphException
 
ExecutionGraphHolder - Class in org.apache.flink.runtime.webmonitor
Gateway to obtaining an ExecutionGraph from a source, like JobManager or Archive.
ExecutionGraphHolder() - Constructor for class org.apache.flink.runtime.webmonitor.ExecutionGraphHolder
 
ExecutionGraphHolder(FiniteDuration) - Constructor for class org.apache.flink.runtime.webmonitor.ExecutionGraphHolder
 
ExecutionGraphMessages - Class in org.apache.flink.runtime.messages
This object contains the execution graph specific messages.
ExecutionGraphMessages() - Constructor for class org.apache.flink.runtime.messages.ExecutionGraphMessages
 
ExecutionGraphMessages$ - Class in org.apache.flink.runtime.messages
This object contains the execution graph specific messages.
ExecutionGraphMessages$() - Constructor for class org.apache.flink.runtime.messages.ExecutionGraphMessages$
 
ExecutionGraphMessages.ExecutionStateChanged - Class in org.apache.flink.runtime.messages
Denotes the execution state change of an ExecutionVertex
ExecutionGraphMessages.ExecutionStateChanged$ - Class in org.apache.flink.runtime.messages
 
ExecutionGraphMessages.JobStatusChanged - Class in org.apache.flink.runtime.messages
Denotes the job state change of a job.
ExecutionGraphMessages.JobStatusChanged$ - Class in org.apache.flink.runtime.messages
 
ExecutionGraphRestartCallback - Class in org.apache.flink.runtime.executiongraph.restart
A RestartCallback that abstracts restart calls on an ExecutionGraph.
ExecutionGraphRestartCallback(ExecutionGraph, long) - Constructor for class org.apache.flink.runtime.executiongraph.restart.ExecutionGraphRestartCallback
Creates a new ExecutionGraphRestartCallback.
ExecutionGraphUtils - Class in org.apache.flink.runtime.executiongraph
Utilities for dealing with the execution graphs and scheduling.
executionID() - Method in class org.apache.flink.runtime.messages.ExecutionGraphMessages.ExecutionStateChanged
 
executionId() - Method in class org.apache.flink.runtime.messages.StackTraceSampleMessages.SampleTaskStackTrace
 
executionId() - Method in class org.apache.flink.runtime.messages.StackTraceSampleMessages.TriggerStackTraceSample
 
executionID() - Method in class org.apache.flink.runtime.messages.TaskMessages.FailIntermediateResultPartitions
 
executionID() - Method in class org.apache.flink.runtime.messages.TaskMessages.FailTask
 
executionID() - Method in class org.apache.flink.runtime.messages.TaskMessages.TaskInFinalState
 
executionID() - Method in class org.apache.flink.runtime.messages.TaskMessages.UpdatePartitionInfo
 
executionID() - Method in class org.apache.flink.runtime.messages.TaskMessages.UpdateTaskMultiplePartitionInfos
 
executionID() - Method in class org.apache.flink.runtime.messages.TaskMessages.UpdateTaskSinglePartitionInfo
 
executionId() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
ExecutionJobVertex - Class in org.apache.flink.runtime.executiongraph
An ExecutionJobVertex is part of the ExecutionGraph, and the peer to the JobVertex.
ExecutionJobVertex(ExecutionGraph, JobVertex, int, Time, long, long) - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
ExecutionMode - Enum in org.apache.flink.api.common
The execution mode specifies how a batch program is executed in terms of data exchange: pipelining or batched.
executionMode() - Method in class org.apache.flink.api.scala.FlinkShell.Config
 
ExecutionMode$() - Constructor for class org.apache.flink.api.scala.FlinkShell.ExecutionMode$
 
executionModes() - Static method in class org.apache.flink.test.util.MultipleProgramsTestBase
 
ExecutionState - Enum in org.apache.flink.runtime.execution
An enumeration of all states that a task can be in during its execution.
ExecutionStateChanged(JobID, JobVertexID, String, int, int, ExecutionAttemptID, ExecutionState, long, String) - Constructor for class org.apache.flink.runtime.messages.ExecutionGraphMessages.ExecutionStateChanged
 
ExecutionStateChanged$() - Constructor for class org.apache.flink.runtime.messages.ExecutionGraphMessages.ExecutionStateChanged$
 
executionStatusChanged(JobID, JobVertexID, String, int, int, ExecutionAttemptID, ExecutionState, long, String) - Method in interface org.apache.flink.runtime.executiongraph.ExecutionStatusListener
Called whenever the execution status of a task changes.
executionStatusChanged(JobID, JobVertexID, String, int, int, ExecutionAttemptID, ExecutionState, long, String) - Method in class org.apache.flink.runtime.executiongraph.StatusListenerMessenger
 
ExecutionStatusListener - Interface in org.apache.flink.runtime.executiongraph
Interface for observers that monitor the status of individual task executions.
ExecutionVertex - Class in org.apache.flink.runtime.executiongraph
The ExecutionVertex is a parallel subtask of the execution.
ExecutionVertex(ExecutionJobVertex, int, IntermediateResult[], Time, long, long, int) - Constructor for class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
executor - Variable in class org.apache.flink.api.java.RemoteEnvironment
The remote executor lazily created upon first use
executor - Variable in class org.apache.flink.test.util.AbstractTestBase
The mini cluster that runs the test programs
executorId() - Method in class org.apache.flink.mesos.scheduler.messages.ExecutorLost
 
executorId() - Method in class org.apache.flink.mesos.scheduler.messages.FrameworkMessage
 
ExecutorLost - Class in org.apache.flink.mesos.scheduler.messages
Message sent when an executor has exited/terminated.
ExecutorLost(Protos.ExecutorID, Protos.SlaveID, int) - Constructor for class org.apache.flink.mesos.scheduler.messages.ExecutorLost
 
executorLost(SchedulerDriver, Protos.ExecutorID, Protos.SlaveID, int) - Method in class org.apache.flink.mesos.scheduler.SchedulerProxy
 
Executors - Class in org.apache.flink.runtime.concurrent
Collection of Executor implementations
Executors() - Constructor for class org.apache.flink.runtime.concurrent.Executors
 
executorService - Variable in class org.apache.flink.runtime.jobmaster.JobManagerServices
 
ExecutorThreadFactory - Class in org.apache.flink.runtime.util
A thread factory intended for use by critical thread pools.
ExecutorThreadFactory() - Constructor for class org.apache.flink.runtime.util.ExecutorThreadFactory
Creates a new thread factory using the default thread pool name ('flink-executor-pool') and the default uncaught exception handler (log exception and kill process).
ExecutorThreadFactory(String) - Constructor for class org.apache.flink.runtime.util.ExecutorThreadFactory
Creates a new thread factory using the given thread pool name and the default uncaught exception handler (log exception and kill process).
ExecutorThreadFactory(String, Thread.UncaughtExceptionHandler) - Constructor for class org.apache.flink.runtime.util.ExecutorThreadFactory
Creates a new thread factory using the given thread pool name and the given uncaught exception handler.
EXISTS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
exists(Path) - Method in class org.apache.flink.core.fs.FileSystem
Check if exists.
exists(Path) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
exists(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Returns the version of the node if it exists or -1 if it doesn't.
existsActiveSlot(JobID, AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Check whether there exists an active slot for the given job and allocation id.
EXIT_CODE_FATAL_ERROR - Static variable in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
The exit code with which the process is stopped in case of a fatal error
EXIT_ON_FATAL_AKKA_ERROR - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Whether the quarantine monitor for task managers shall be started.
exitMainThread() - Method in class org.apache.flink.runtime.rpc.MainThreadValidatorUtil
 
EXP - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
exp() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Calculates the Euler's number raised to the given power.
EXP() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
EXP() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
Exp - Class in org.apache.flink.table.expressions
 
Exp(Expression) - Constructor for class org.apache.flink.table.expressions.Exp
 
Exp$ - Class in org.apache.flink.table.expressions
 
Exp$() - Constructor for class org.apache.flink.table.expressions.Exp$
 
expandProjectList(Seq<Expression>, LogicalNode, TableEnvironment) - Method in class org.apache.flink.table.plan.ProjectionTranslator$
Expands an UnresolvedFieldReference("*") to parent's full project list.
expandProjectList(Seq<Expression>, LogicalNode, TableEnvironment) - Static method in class org.apache.flink.table.plan.ProjectionTranslator
Expands an UnresolvedFieldReference("*") to parent's full project list.
expandView(RelDataType, String, List<String>, List<String>) - Method in class org.apache.flink.table.calcite.FlinkPlannerImpl.ViewExpanderImpl
 
EXPECTED - Static variable in class org.apache.flink.streaming.examples.windowing.util.SessionWindowingData
 
EXPECTED_EDGES_ABSENT_VALUES - Static variable in class org.apache.flink.graph.examples.data.SummarizationData
Format: "possible-source-id[,possible-source-id];possible-target-id[,possible-target-id];group-value,group-count"
EXPECTED_EDGES_WITH_VALUES - Static variable in class org.apache.flink.graph.examples.data.SummarizationData
Format: "possible-source-id[,possible-source-id];possible-target-id[,possible-target-id];group-value,group-count"
EXPECTED_VERTICES - Static variable in class org.apache.flink.graph.examples.data.SummarizationData
The resulting vertex id can be any id of the vertices summarized by the single vertex.
expectedEntries - Variable in class org.apache.flink.runtime.operators.util.BloomFilter
 
expectedModVersion() - Method in exception org.apache.flink.runtime.executiongraph.GlobalModVersionMismatch
 
expectedTypes() - Method in class org.apache.flink.table.expressions.Exp
 
expectedTypes() - Method in interface org.apache.flink.table.expressions.InputTypeSpec
Input type specification for each child.
expectedTypes() - Method in class org.apache.flink.table.expressions.Ln
 
expectedTypes() - Method in class org.apache.flink.table.expressions.Log10
 
expectedTypes() - Method in class org.apache.flink.table.expressions.Overlay
 
expectedTypes() - Method in class org.apache.flink.table.expressions.Position
 
expectedTypes() - Method in class org.apache.flink.table.expressions.Power
 
expectedTypes() - Method in class org.apache.flink.table.expressions.Quarter
 
expectedTypes() - Method in class org.apache.flink.table.expressions.Sqrt
 
expectedTypes() - Method in class org.apache.flink.table.expressions.Substring
 
expectedTypes() - Method in class org.apache.flink.table.expressions.Upper
 
explain(Table, boolean) - Method in class org.apache.flink.table.api.BatchTableEnvironment
Returns the AST of the specified Table API and SQL queries and the execution plan to compute the result of the given Table.
explain(Table) - Method in class org.apache.flink.table.api.BatchTableEnvironment
Returns the AST of the specified Table API and SQL queries and the execution plan to compute the result of the given Table.
explain(Table) - Method in class org.apache.flink.table.api.StreamTableEnvironment
Returns the AST of the specified Table API and SQL queries and the execution plan to compute the result of the given Table.
explain(RelWriter) - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
explain(RelWriter) - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
explain(RelWriter) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
explain(RelWriter) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
explain(RelWriter) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
explain(RelWriter) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
explain(RelWriter) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
explain(RelWriter) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
explain(RelWriter) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
explain(RelWriter) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
explain(RelWriter) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
explain(RelWriter) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
explain(RelWriter) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
explain(RelWriter) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
explain(RelWriter) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
explain(RelWriter) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
explainSource() - Method in class org.apache.flink.addons.hbase.HBaseTableSource
 
explainSource() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSource
 
explainSource() - Static method in class org.apache.flink.table.sources.CsvTableSource
 
explainSource() - Method in interface org.apache.flink.table.sources.TableSource
Describes the table source
explainTerms(RelWriter) - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
explainTerms(RelWriter) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetAggregate
 
explainTerms(RelWriter) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetCalc
 
explainTerms(RelWriter) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetCorrelate
 
explainTerms(RelWriter) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetDistinct
 
explainTerms(RelWriter) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetIntersect
 
explainTerms(RelWriter) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetJoin
 
explainTerms(RelWriter) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetMinus
 
explainTerms(RelWriter) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetSingleRowJoin
 
explainTerms(RelWriter) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetSort
 
explainTerms(RelWriter) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetUnion
 
explainTerms(RelWriter) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetValues
 
explainTerms(RelWriter) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetWindowAggregate
 
explainTerms(RelWriter) - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamCalc
 
explainTerms(RelWriter) - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamCorrelate
 
explainTerms(RelWriter) - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupAggregate
 
explainTerms(RelWriter) - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
explainTerms(RelWriter) - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamOverAggregate
 
explainTerms(RelWriter) - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamUnion
 
explainTerms(RelWriter) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
explainTerms(RelWriter) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
explainTerms(RelWriter) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
explainTerms(RelWriter) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
explainTerms(RelWriter) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
explainTerms(RelWriter) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
explainTerms(RelWriter) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
explainTerms(RelWriter) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
explainTerms(RelWriter) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
explainTerms(RelWriter) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
explainTerms(RelWriter) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
explainTerms(RelWriter) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
explainTerms(RelWriter) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
explainTerms(RelWriter) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
explainTerms(RelWriter) - Method in class org.apache.flink.table.plan.nodes.PhysicalTableSourceScan
 
EXPLICIT_TABLE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Keyword which allows an identifier to be explicitly flagged as a table.
ExplodeFunctionUtil - Class in org.apache.flink.table.plan.util
 
ExplodeFunctionUtil() - Constructor for class org.apache.flink.table.plan.util.ExplodeFunctionUtil
 
ExplodeFunctionUtil$ - Class in org.apache.flink.table.plan.util
 
ExplodeFunctionUtil$() - Constructor for class org.apache.flink.table.plan.util.ExplodeFunctionUtil$
 
explodeTableFuncFromType(TypeInformation<?>) - Method in class org.apache.flink.table.plan.util.ExplodeFunctionUtil$
 
explodeTableFuncFromType(TypeInformation<?>) - Static method in class org.apache.flink.table.plan.util.ExplodeFunctionUtil
 
expr() - Method in class org.apache.flink.table.api.scala.ImplicitExpressionConversions.LiteralBooleanExpression
 
expr() - Method in class org.apache.flink.table.api.scala.ImplicitExpressionConversions.LiteralByteExpression
 
expr() - Method in class org.apache.flink.table.api.scala.ImplicitExpressionConversions.LiteralDoubleExpression
 
expr() - Method in class org.apache.flink.table.api.scala.ImplicitExpressionConversions.LiteralFloatExpression
 
expr() - Method in class org.apache.flink.table.api.scala.ImplicitExpressionConversions.LiteralIntExpression
 
expr() - Method in class org.apache.flink.table.api.scala.ImplicitExpressionConversions.LiteralJavaDecimalExpression
 
expr() - Method in class org.apache.flink.table.api.scala.ImplicitExpressionConversions.LiteralLongExpression
 
expr() - Method in class org.apache.flink.table.api.scala.ImplicitExpressionConversions.LiteralScalaDecimalExpression
 
expr() - Method in class org.apache.flink.table.api.scala.ImplicitExpressionConversions.LiteralShortExpression
 
expr() - Method in class org.apache.flink.table.api.scala.ImplicitExpressionConversions.LiteralSqlDateExpression
 
expr() - Method in class org.apache.flink.table.api.scala.ImplicitExpressionConversions.LiteralSqlTimeExpression
 
expr() - Method in class org.apache.flink.table.api.scala.ImplicitExpressionConversions.LiteralSqlTimestampExpression
 
expr() - Method in class org.apache.flink.table.api.scala.ImplicitExpressionConversions.LiteralStringExpression
 
expr() - Method in class org.apache.flink.table.api.scala.ImplicitExpressionConversions.UnresolvedFieldExpression
 
expr() - Method in class org.apache.flink.table.api.scala.ImplicitExpressionConversions.WithOperations
 
expr() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
 
expr() - Method in class org.apache.flink.table.expressions.ProctimeAttribute
 
expr() - Method in class org.apache.flink.table.expressions.RowtimeAttribute
 
Expression - Class in org.apache.flink.table.expressions
 
Expression() - Constructor for class org.apache.flink.table.expressions.Expression
 
expression() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
expression() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
expression() - Static method in class org.apache.flink.table.expressions.ProctimeAttribute
 
expression() - Static method in class org.apache.flink.table.expressions.RowtimeAttribute
 
expression() - Method in class org.apache.flink.table.expressions.TimeAttribute
 
ExpressionKeys(TypeInformation<T>) - Constructor for class org.apache.flink.api.common.operators.Keys.ExpressionKeys
ExpressionKeys that is defined by the full data type.
ExpressionKeys(int, TypeInformation<T>) - Constructor for class org.apache.flink.api.common.operators.Keys.ExpressionKeys
Create int-based (non-nested) field position keys on a tuple type.
ExpressionKeys(int[], TypeInformation<T>) - Constructor for class org.apache.flink.api.common.operators.Keys.ExpressionKeys
Create int-based (non-nested) field position keys on a tuple type.
ExpressionKeys(int[], TypeInformation<T>, boolean) - Constructor for class org.apache.flink.api.common.operators.Keys.ExpressionKeys
Create int-based (non-nested) field position keys on a tuple type.
ExpressionKeys(String, TypeInformation<T>) - Constructor for class org.apache.flink.api.common.operators.Keys.ExpressionKeys
Create String-based (nested) field expression keys on a composite type.
ExpressionKeys(String[], TypeInformation<T>) - Constructor for class org.apache.flink.api.common.operators.Keys.ExpressionKeys
Create String-based (nested) field expression keys on a composite type.
expressionList() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
expressionList() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
ExpressionParser - Class in org.apache.flink.table.expressions
 
ExpressionParser() - Constructor for class org.apache.flink.table.expressions.ExpressionParser
 
ExpressionParser$ - Class in org.apache.flink.table.expressions
 
ExpressionParser$() - Constructor for class org.apache.flink.table.expressions.ExpressionParser$
 
ExpressionParser.Keyword - Class in org.apache.flink.table.expressions
 
ExpressionParser.Keyword$ - Class in org.apache.flink.table.expressions
 
ExpressionParserException - Exception in org.apache.flink.table.api
Exception for all errors occurring during expression parsing.
ExpressionParserException(String) - Constructor for exception org.apache.flink.table.api.ExpressionParserException
 
ExpressionParserException$ - Class in org.apache.flink.table.api
 
ExpressionParserException$() - Constructor for class org.apache.flink.table.api.ExpressionParserException$
 
expressionPostOrderTransform(PartialFunction<Expression, Expression>) - Static method in class org.apache.flink.table.plan.logical.Aggregate
 
expressionPostOrderTransform(PartialFunction<Expression, Expression>) - Static method in class org.apache.flink.table.plan.logical.AliasNode
 
expressionPostOrderTransform(PartialFunction<Expression, Expression>) - Static method in class org.apache.flink.table.plan.logical.CatalogNode
 
expressionPostOrderTransform(PartialFunction<Expression, Expression>) - Static method in class org.apache.flink.table.plan.logical.Distinct
 
expressionPostOrderTransform(PartialFunction<Expression, Expression>) - Static method in class org.apache.flink.table.plan.logical.Filter
 
expressionPostOrderTransform(PartialFunction<Expression, Expression>) - Static method in class org.apache.flink.table.plan.logical.Intersect
 
expressionPostOrderTransform(PartialFunction<Expression, Expression>) - Static method in class org.apache.flink.table.plan.logical.Join
 
expressionPostOrderTransform(PartialFunction<Expression, Expression>) - Static method in class org.apache.flink.table.plan.logical.Limit
 
expressionPostOrderTransform(PartialFunction<Expression, Expression>) - Method in class org.apache.flink.table.plan.logical.LogicalNode
Runs postOrderTransform with rule on all expressions present in this logical node.
expressionPostOrderTransform(PartialFunction<Expression, Expression>) - Static method in class org.apache.flink.table.plan.logical.LogicalRelNode
 
expressionPostOrderTransform(PartialFunction<Expression, Expression>) - Static method in class org.apache.flink.table.plan.logical.LogicalTableFunctionCall
 
expressionPostOrderTransform(PartialFunction<Expression, Expression>) - Static method in class org.apache.flink.table.plan.logical.Minus
 
expressionPostOrderTransform(PartialFunction<Expression, Expression>) - Static method in class org.apache.flink.table.plan.logical.Project
 
expressionPostOrderTransform(PartialFunction<Expression, Expression>) - Static method in class org.apache.flink.table.plan.logical.Sort
 
expressionPostOrderTransform(PartialFunction<Expression, Expression>) - Static method in class org.apache.flink.table.plan.logical.Union
 
expressionPostOrderTransform(PartialFunction<Expression, Expression>) - Static method in class org.apache.flink.table.plan.logical.WindowAggregate
 
ExpressionReducer - Class in org.apache.flink.table.codegen
Evaluates constant expressions using Flink's CodeGenerator.
ExpressionReducer(TableConfig) - Constructor for class org.apache.flink.table.codegen.ExpressionReducer
 
ExpressionUtils - Class in org.apache.flink.table.expressions
 
ExpressionUtils() - Constructor for class org.apache.flink.table.expressions.ExpressionUtils
 
ExpressionUtils$ - Class in org.apache.flink.table.expressions
 
ExpressionUtils$() - Constructor for class org.apache.flink.table.expressions.ExpressionUtils$
 
extdPrice() - Method in class org.apache.flink.examples.scala.relational.TPCHQuery3.Lineitem
 
extdPrice() - Method in class org.apache.flink.table.examples.scala.TPCHQuery3Table.Lineitem
 
EXTEND - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
EXTEND operator.
ExternalCatalog - Interface in org.apache.flink.table.catalog
An ExternalCatalog is the connector between an external database catalog and Flink's Table API.
ExternalCatalogAlreadyExistException - Exception in org.apache.flink.table.api
Exception for adding an already existent external catalog
ExternalCatalogAlreadyExistException(String, Throwable) - Constructor for exception org.apache.flink.table.api.ExternalCatalogAlreadyExistException
 
ExternalCatalogAlreadyExistException(String) - Constructor for exception org.apache.flink.table.api.ExternalCatalogAlreadyExistException
 
ExternalCatalogAlreadyExistException$ - Class in org.apache.flink.table.api
 
ExternalCatalogAlreadyExistException$() - Constructor for class org.apache.flink.table.api.ExternalCatalogAlreadyExistException$
 
ExternalCatalogNotExistException - Exception in org.apache.flink.table.api
Exception for operation on a nonexistent external catalog
ExternalCatalogNotExistException(String, Throwable) - Constructor for exception org.apache.flink.table.api.ExternalCatalogNotExistException
 
ExternalCatalogNotExistException(String) - Constructor for exception org.apache.flink.table.api.ExternalCatalogNotExistException
 
ExternalCatalogNotExistException$ - Class in org.apache.flink.table.api
 
ExternalCatalogNotExistException$() - Constructor for class org.apache.flink.table.api.ExternalCatalogNotExistException$
 
ExternalCatalogSchema - Class in org.apache.flink.table.catalog
This class is responsible to connect an external catalog to Calcite's catalog.
ExternalCatalogSchema(String, ExternalCatalog) - Constructor for class org.apache.flink.table.catalog.ExternalCatalogSchema
 
ExternalCatalogSchema$ - Class in org.apache.flink.table.catalog
 
ExternalCatalogSchema$() - Constructor for class org.apache.flink.table.catalog.ExternalCatalogSchema$
 
ExternalCatalogTable - Class in org.apache.flink.table.catalog
Defines a table in an ExternalCatalog.
ExternalCatalogTable(String, TableSchema, Map<String, String>, TableStats, String, Long, Long) - Constructor for class org.apache.flink.table.catalog.ExternalCatalogTable
 
ExternalCatalogTable$ - Class in org.apache.flink.table.catalog
 
ExternalCatalogTable$() - Constructor for class org.apache.flink.table.catalog.ExternalCatalogTable$
 
externalizeCheckpoints() - Method in class org.apache.flink.runtime.jobgraph.tasks.ExternalizedCheckpointSettings
Returns true if checkpoints should be externalized.
externalizeCheckpoints(boolean) - Static method in class org.apache.flink.runtime.jobgraph.tasks.ExternalizedCheckpointSettings
 
ExternalizedCheckpointSettings - Class in org.apache.flink.runtime.jobgraph.tasks
Grouped settings for externalized checkpoints.
externalJars() - Method in class org.apache.flink.api.scala.FlinkILoop
 
externalJars() - Method in class org.apache.flink.api.scala.FlinkShell.Config
 
ExternallyInducedSource<T,CD> - Interface in org.apache.flink.streaming.api.checkpoint
Sources that implement this interface do not trigger checkpoints when receiving a trigger message from the checkpoint coordinator, but when their input data/events indicate that a checkpoint should be triggered.
ExternallyInducedSource.CheckpointTrigger - Interface in org.apache.flink.streaming.api.checkpoint
Through the CheckpointTrigger, the source function notifies the Flink source operator when to trigger the checkpoint.
ExternalTableSourceUtil - Class in org.apache.flink.table.catalog
The utility class is used to convert ExternalCatalogTable to TableSourceTable.
ExternalTableSourceUtil() - Constructor for class org.apache.flink.table.catalog.ExternalTableSourceUtil
 
ExternalTableSourceUtil$ - Class in org.apache.flink.table.catalog
The utility class is used to convert ExternalCatalogTable to TableSourceTable.
ExternalTableSourceUtil$() - Constructor for class org.apache.flink.table.catalog.ExternalTableSourceUtil$
 
EXTRACT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The SQL EXTRACT operator.
extract - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
extract - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
 
extract(Tuple) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ArrayFromTuple
 
extract(FROM) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.ConcatenatedExtract
 
extract(FROM) - Method in interface org.apache.flink.streaming.api.functions.windowing.delta.extractor.Extractor
Extracts/Converts the given input to an object of the output type.
extract(Object) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromArray
 
extract(Tuple) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromTuple
 
extract(Object) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldsFromArray
 
extract(Tuple) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldsFromTuple
 
extract(TableSymbols.TableSymbolValue) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Extracts parts of a time point or time interval.
EXTRACT() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
EXTRACT() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
Extract - Class in org.apache.flink.table.expressions
 
Extract(Expression, Expression) - Constructor for class org.apache.flink.table.expressions.Extract
 
Extract$ - Class in org.apache.flink.table.expressions
 
Extract$() - Constructor for class org.apache.flink.table.expressions.Extract$
 
EXTRACT_DATE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Internal operator that extracts time periods (year, month, date) from a date in internal format (number of days since epoch).
extractAggregationsAndProperties(Seq<Expression>, TableEnvironment) - Method in class org.apache.flink.table.plan.ProjectionTranslator$
Extracts and deduplicates all aggregation and window property expressions (zero, one, or more) from the given expressions.
extractAggregationsAndProperties(Seq<Expression>, TableEnvironment) - Static method in class org.apache.flink.table.plan.ProjectionTranslator
Extracts and deduplicates all aggregation and window property expressions (zero, one, or more) from the given expressions.
extractAscendingTimestamp(T) - Method in class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
Extracts the timestamp from the given element.
extractClass(scala.reflect.macros.Context.universe) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
extractConjunctiveConditions(RexProgram, RexBuilder, FunctionCatalog) - Method in class org.apache.flink.table.plan.util.RexProgramExtractor$
Extract condition from RexProgram and convert it into independent CNF expressions.
extractConjunctiveConditions(RexProgram, RexBuilder, FunctionCatalog) - Static method in class org.apache.flink.table.plan.util.RexProgramExtractor
Extract condition from RexProgram and convert it into independent CNF expressions.
extractContainedLibraries(URL) - Static method in class org.apache.flink.client.program.PackagedProgram
Takes all JAR files that are contained in this program's JAR file and extracts them to the system's temp directory.
extractFailureCauseFromBulkItemResponse(BulkItemResponse) - Method in class org.apache.flink.streaming.connectors.elasticsearch.Elasticsearch1ApiCallBridge
 
extractFailureCauseFromBulkItemResponse(BulkItemResponse) - Method in interface org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchApiCallBridge
Extracts the cause of failure of a bulk item action.
extractFailureCauseFromBulkItemResponse(BulkItemResponse) - Method in class org.apache.flink.streaming.connectors.elasticsearch2.Elasticsearch2ApiCallBridge
 
extractFailureCauseFromBulkItemResponse(BulkItemResponse) - Method in class org.apache.flink.streaming.connectors.elasticsearch5.Elasticsearch5ApiCallBridge
 
extractFieldReferences(Seq<Expression>) - Method in class org.apache.flink.table.plan.ProjectionTranslator$
Extract all field references from the given expressions.
extractFieldReferences(Seq<Expression>) - Static method in class org.apache.flink.table.plan.ProjectionTranslator
Extract all field references from the given expressions.
extractFieldTypes(int[], TypeInformation<?>) - Static method in class org.apache.flink.streaming.api.datastream.StreamProjection
 
extractFileExtension(String) - Static method in class org.apache.flink.api.common.io.FileInputFormat
Returns the extension of a file name (!= a path).
extractFromSystem(long) - Static method in class org.apache.flink.runtime.instance.HardwareDescription
 
ExtractionAwareDeltaFunction<DATA,TO> - Class in org.apache.flink.streaming.api.functions.windowing.delta
Extend this abstract class to implement a delta function which is aware of extracting the data on which the delta is calculated from a more complex data structure.
ExtractionAwareDeltaFunction(Extractor<DATA, TO>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.ExtractionAwareDeltaFunction
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Extracts the key fields from a record.
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.scala.typeutils.CaseClassComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.scala.typeutils.EnumValueComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.api.scala.typeutils.OptionTypeComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
 
extractKeys(Object, Object[], int) - Method in class org.apache.flink.table.runtime.types.CRowComparator
 
ExtractMismatchSongIds() - Constructor for class org.apache.flink.graph.examples.MusicProfiles.ExtractMismatchSongIds
 
extractOneInputUdf(scala.reflect.macros.Context.universe) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
Extractor<FROM,TO> - Interface in org.apache.flink.streaming.api.functions.windowing.delta.extractor
Extractors allow to extract/convert one type to another.
extractPatterns(K, V, long, int, DeweyNumber) - Method in class org.apache.flink.cep.nfa.SharedBuffer
Returns all elements from the previous relation starting at the given value with the given key and timestamp.
extractRefInputFields(RexProgram) - Method in class org.apache.flink.table.plan.util.RexProgramExtractor$
Extracts the indices of input fields which accessed by the RexProgram.
extractRefInputFields(RexProgram) - Static method in class org.apache.flink.table.plan.util.RexProgramExtractor
Extracts the indices of input fields which accessed by the RexProgram.
extractRefNestedInputFields(RexProgram, int[]) - Method in class org.apache.flink.table.plan.util.RexProgramExtractor$
Extracts the name of nested input fields accessed by the RexProgram and returns the prefix of the accesses.
extractRefNestedInputFields(RexProgram, int[]) - Static method in class org.apache.flink.table.plan.util.RexProgramExtractor
Extracts the name of nested input fields accessed by the RexProgram and returns the prefix of the accesses.
extractSemanticAnnotations(Class<?>) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
 
extractSemanticAnnotationsFromUdf(Class<?>) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
 
extractSemanticAnnotationsFromUdf(Class<?>) - Method in class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
 
extractSemanticAnnotationsFromUdf(Class<?>) - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
 
extractSemanticAnnotationsFromUdf(Class<?>) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
 
extractTimestamp(T, long) - Method in class org.apache.flink.streaming.api.functions.IngestionTimeExtractor
 
extractTimestamp(T, long) - Method in interface org.apache.flink.streaming.api.functions.TimestampAssigner
Assigns a timestamp to an element, in milliseconds since the Epoch.
extractTimestamp(T, long) - Method in interface org.apache.flink.streaming.api.functions.TimestampExtractor
Deprecated.
Extracts a timestamp from an element.
extractTimestamp(T, long) - Method in class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
 
extractTimestamp(T) - Method in class org.apache.flink.streaming.api.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor
Extracts the timestamp from the given element.
extractTimestamp(T, long) - Method in class org.apache.flink.streaming.api.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor
 
extractTimestamp(Integer, long) - Method in class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.LinearTimestamp
 
ExtractTimestampsOperator<T> - Class in org.apache.flink.streaming.runtime.operators
ExtractTimestampsOperator(TimestampExtractor<T>) - Constructor for class org.apache.flink.streaming.runtime.operators.ExtractTimestampsOperator
Deprecated.
 
extractTwoInputUdf(scala.reflect.macros.Context.universe) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
extractTypeArgument(Type, int) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils
This method extracts the n-th type argument from the given type.
extractTypeFromLambda(TypeExtractionUtils.LambdaExecutable, int[], int, int) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils
Extracts type from given index from lambda.
extractWatermark(T, long) - Method in interface org.apache.flink.streaming.api.functions.TimestampExtractor
Deprecated.
Asks the extractor if it wants to emit a watermark now that it has seen the given element.
extraNames() - Method in class org.apache.flink.table.expressions.Alias
 
extraSelectItems(SqlToRelConverter.Blackboard, SqlSelect, List<RexNode>, List<String>, Collection<String>, List<SqlMonotonicity>) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Adds extra select items.
eye(int, int) - Method in class org.apache.flink.ml.math.DenseMatrix$
 
eye(int, int) - Static method in class org.apache.flink.ml.math.DenseMatrix
 
eye(int) - Method in class org.apache.flink.ml.math.DenseVector$
 
eye(int) - Static method in class org.apache.flink.ml.math.DenseVector
 

F

f0 - Variable in class org.apache.flink.api.java.tuple.Tuple1
Field 0 of the tuple.
f0 - Variable in class org.apache.flink.api.java.tuple.Tuple10
Field 0 of the tuple.
f0 - Variable in class org.apache.flink.api.java.tuple.Tuple11
Field 0 of the tuple.
f0 - Variable in class org.apache.flink.api.java.tuple.Tuple12
Field 0 of the tuple.
f0 - Variable in class org.apache.flink.api.java.tuple.Tuple13
Field 0 of the tuple.
f0 - Variable in class org.apache.flink.api.java.tuple.Tuple14
Field 0 of the tuple.
f0 - Variable in class org.apache.flink.api.java.tuple.Tuple15
Field 0 of the tuple.
f0 - Variable in class org.apache.flink.api.java.tuple.Tuple16
Field 0 of the tuple.
f0 - Variable in class org.apache.flink.api.java.tuple.Tuple17
Field 0 of the tuple.
f0 - Variable in class org.apache.flink.api.java.tuple.Tuple18
Field 0 of the tuple.
f0 - Variable in class org.apache.flink.api.java.tuple.Tuple19
Field 0 of the tuple.
f0 - Variable in class org.apache.flink.api.java.tuple.Tuple2
Field 0 of the tuple.
f0 - Variable in class org.apache.flink.api.java.tuple.Tuple20
Field 0 of the tuple.
f0 - Variable in class org.apache.flink.api.java.tuple.Tuple21
Field 0 of the tuple.
f0 - Variable in class org.apache.flink.api.java.tuple.Tuple22
Field 0 of the tuple.
f0 - Variable in class org.apache.flink.api.java.tuple.Tuple23
Field 0 of the tuple.
f0 - Variable in class org.apache.flink.api.java.tuple.Tuple24
Field 0 of the tuple.
f0 - Variable in class org.apache.flink.api.java.tuple.Tuple25
Field 0 of the tuple.
f0 - Variable in class org.apache.flink.api.java.tuple.Tuple3
Field 0 of the tuple.
f0 - Variable in class org.apache.flink.api.java.tuple.Tuple4
Field 0 of the tuple.
f0 - Variable in class org.apache.flink.api.java.tuple.Tuple5
Field 0 of the tuple.
f0 - Variable in class org.apache.flink.api.java.tuple.Tuple6
Field 0 of the tuple.
f0 - Variable in class org.apache.flink.api.java.tuple.Tuple7
Field 0 of the tuple.
f0 - Variable in class org.apache.flink.api.java.tuple.Tuple8
Field 0 of the tuple.
f0 - Variable in class org.apache.flink.api.java.tuple.Tuple9
Field 0 of the tuple.
f1 - Variable in class org.apache.flink.api.java.tuple.Tuple10
Field 1 of the tuple.
f1 - Variable in class org.apache.flink.api.java.tuple.Tuple11
Field 1 of the tuple.
f1 - Variable in class org.apache.flink.api.java.tuple.Tuple12
Field 1 of the tuple.
f1 - Variable in class org.apache.flink.api.java.tuple.Tuple13
Field 1 of the tuple.
f1 - Variable in class org.apache.flink.api.java.tuple.Tuple14
Field 1 of the tuple.
f1 - Variable in class org.apache.flink.api.java.tuple.Tuple15
Field 1 of the tuple.
f1 - Variable in class org.apache.flink.api.java.tuple.Tuple16
Field 1 of the tuple.
f1 - Variable in class org.apache.flink.api.java.tuple.Tuple17
Field 1 of the tuple.
f1 - Variable in class org.apache.flink.api.java.tuple.Tuple18
Field 1 of the tuple.
f1 - Variable in class org.apache.flink.api.java.tuple.Tuple19
Field 1 of the tuple.
f1 - Variable in class org.apache.flink.api.java.tuple.Tuple2
Field 1 of the tuple.
f1 - Variable in class org.apache.flink.api.java.tuple.Tuple20
Field 1 of the tuple.
f1 - Variable in class org.apache.flink.api.java.tuple.Tuple21
Field 1 of the tuple.
f1 - Variable in class org.apache.flink.api.java.tuple.Tuple22
Field 1 of the tuple.
f1 - Variable in class org.apache.flink.api.java.tuple.Tuple23
Field 1 of the tuple.
f1 - Variable in class org.apache.flink.api.java.tuple.Tuple24
Field 1 of the tuple.
f1 - Variable in class org.apache.flink.api.java.tuple.Tuple25
Field 1 of the tuple.
f1 - Variable in class org.apache.flink.api.java.tuple.Tuple3
Field 1 of the tuple.
f1 - Variable in class org.apache.flink.api.java.tuple.Tuple4
Field 1 of the tuple.
f1 - Variable in class org.apache.flink.api.java.tuple.Tuple5
Field 1 of the tuple.
f1 - Variable in class org.apache.flink.api.java.tuple.Tuple6
Field 1 of the tuple.
f1 - Variable in class org.apache.flink.api.java.tuple.Tuple7
Field 1 of the tuple.
f1 - Variable in class org.apache.flink.api.java.tuple.Tuple8
Field 1 of the tuple.
f1 - Variable in class org.apache.flink.api.java.tuple.Tuple9
Field 1 of the tuple.
f10 - Variable in class org.apache.flink.api.java.tuple.Tuple11
Field 10 of the tuple.
f10 - Variable in class org.apache.flink.api.java.tuple.Tuple12
Field 10 of the tuple.
f10 - Variable in class org.apache.flink.api.java.tuple.Tuple13
Field 10 of the tuple.
f10 - Variable in class org.apache.flink.api.java.tuple.Tuple14
Field 10 of the tuple.
f10 - Variable in class org.apache.flink.api.java.tuple.Tuple15
Field 10 of the tuple.
f10 - Variable in class org.apache.flink.api.java.tuple.Tuple16
Field 10 of the tuple.
f10 - Variable in class org.apache.flink.api.java.tuple.Tuple17
Field 10 of the tuple.
f10 - Variable in class org.apache.flink.api.java.tuple.Tuple18
Field 10 of the tuple.
f10 - Variable in class org.apache.flink.api.java.tuple.Tuple19
Field 10 of the tuple.
f10 - Variable in class org.apache.flink.api.java.tuple.Tuple20
Field 10 of the tuple.
f10 - Variable in class org.apache.flink.api.java.tuple.Tuple21
Field 10 of the tuple.
f10 - Variable in class org.apache.flink.api.java.tuple.Tuple22
Field 10 of the tuple.
f10 - Variable in class org.apache.flink.api.java.tuple.Tuple23
Field 10 of the tuple.
f10 - Variable in class org.apache.flink.api.java.tuple.Tuple24
Field 10 of the tuple.
f10 - Variable in class org.apache.flink.api.java.tuple.Tuple25
Field 10 of the tuple.
f11 - Variable in class org.apache.flink.api.java.tuple.Tuple12
Field 11 of the tuple.
f11 - Variable in class org.apache.flink.api.java.tuple.Tuple13
Field 11 of the tuple.
f11 - Variable in class org.apache.flink.api.java.tuple.Tuple14
Field 11 of the tuple.
f11 - Variable in class org.apache.flink.api.java.tuple.Tuple15
Field 11 of the tuple.
f11 - Variable in class org.apache.flink.api.java.tuple.Tuple16
Field 11 of the tuple.
f11 - Variable in class org.apache.flink.api.java.tuple.Tuple17
Field 11 of the tuple.
f11 - Variable in class org.apache.flink.api.java.tuple.Tuple18
Field 11 of the tuple.
f11 - Variable in class org.apache.flink.api.java.tuple.Tuple19
Field 11 of the tuple.
f11 - Variable in class org.apache.flink.api.java.tuple.Tuple20
Field 11 of the tuple.
f11 - Variable in class org.apache.flink.api.java.tuple.Tuple21
Field 11 of the tuple.
f11 - Variable in class org.apache.flink.api.java.tuple.Tuple22
Field 11 of the tuple.
f11 - Variable in class org.apache.flink.api.java.tuple.Tuple23
Field 11 of the tuple.
f11 - Variable in class org.apache.flink.api.java.tuple.Tuple24
Field 11 of the tuple.
f11 - Variable in class org.apache.flink.api.java.tuple.Tuple25
Field 11 of the tuple.
f12 - Variable in class org.apache.flink.api.java.tuple.Tuple13
Field 12 of the tuple.
f12 - Variable in class org.apache.flink.api.java.tuple.Tuple14
Field 12 of the tuple.
f12 - Variable in class org.apache.flink.api.java.tuple.Tuple15
Field 12 of the tuple.
f12 - Variable in class org.apache.flink.api.java.tuple.Tuple16
Field 12 of the tuple.
f12 - Variable in class org.apache.flink.api.java.tuple.Tuple17
Field 12 of the tuple.
f12 - Variable in class org.apache.flink.api.java.tuple.Tuple18
Field 12 of the tuple.
f12 - Variable in class org.apache.flink.api.java.tuple.Tuple19
Field 12 of the tuple.
f12 - Variable in class org.apache.flink.api.java.tuple.Tuple20
Field 12 of the tuple.
f12 - Variable in class org.apache.flink.api.java.tuple.Tuple21
Field 12 of the tuple.
f12 - Variable in class org.apache.flink.api.java.tuple.Tuple22
Field 12 of the tuple.
f12 - Variable in class org.apache.flink.api.java.tuple.Tuple23
Field 12 of the tuple.
f12 - Variable in class org.apache.flink.api.java.tuple.Tuple24
Field 12 of the tuple.
f12 - Variable in class org.apache.flink.api.java.tuple.Tuple25
Field 12 of the tuple.
f13 - Variable in class org.apache.flink.api.java.tuple.Tuple14
Field 13 of the tuple.
f13 - Variable in class org.apache.flink.api.java.tuple.Tuple15
Field 13 of the tuple.
f13 - Variable in class org.apache.flink.api.java.tuple.Tuple16
Field 13 of the tuple.
f13 - Variable in class org.apache.flink.api.java.tuple.Tuple17
Field 13 of the tuple.
f13 - Variable in class org.apache.flink.api.java.tuple.Tuple18
Field 13 of the tuple.
f13 - Variable in class org.apache.flink.api.java.tuple.Tuple19
Field 13 of the tuple.
f13 - Variable in class org.apache.flink.api.java.tuple.Tuple20
Field 13 of the tuple.
f13 - Variable in class org.apache.flink.api.java.tuple.Tuple21
Field 13 of the tuple.
f13 - Variable in class org.apache.flink.api.java.tuple.Tuple22
Field 13 of the tuple.
f13 - Variable in class org.apache.flink.api.java.tuple.Tuple23
Field 13 of the tuple.
f13 - Variable in class org.apache.flink.api.java.tuple.Tuple24
Field 13 of the tuple.
f13 - Variable in class org.apache.flink.api.java.tuple.Tuple25
Field 13 of the tuple.
f14 - Variable in class org.apache.flink.api.java.tuple.Tuple15
Field 14 of the tuple.
f14 - Variable in class org.apache.flink.api.java.tuple.Tuple16
Field 14 of the tuple.
f14 - Variable in class org.apache.flink.api.java.tuple.Tuple17
Field 14 of the tuple.
f14 - Variable in class org.apache.flink.api.java.tuple.Tuple18
Field 14 of the tuple.
f14 - Variable in class org.apache.flink.api.java.tuple.Tuple19
Field 14 of the tuple.
f14 - Variable in class org.apache.flink.api.java.tuple.Tuple20
Field 14 of the tuple.
f14 - Variable in class org.apache.flink.api.java.tuple.Tuple21
Field 14 of the tuple.
f14 - Variable in class org.apache.flink.api.java.tuple.Tuple22
Field 14 of the tuple.
f14 - Variable in class org.apache.flink.api.java.tuple.Tuple23
Field 14 of the tuple.
f14 - Variable in class org.apache.flink.api.java.tuple.Tuple24
Field 14 of the tuple.
f14 - Variable in class org.apache.flink.api.java.tuple.Tuple25
Field 14 of the tuple.
f15 - Variable in class org.apache.flink.api.java.tuple.Tuple16
Field 15 of the tuple.
f15 - Variable in class org.apache.flink.api.java.tuple.Tuple17
Field 15 of the tuple.
f15 - Variable in class org.apache.flink.api.java.tuple.Tuple18
Field 15 of the tuple.
f15 - Variable in class org.apache.flink.api.java.tuple.Tuple19
Field 15 of the tuple.
f15 - Variable in class org.apache.flink.api.java.tuple.Tuple20
Field 15 of the tuple.
f15 - Variable in class org.apache.flink.api.java.tuple.Tuple21
Field 15 of the tuple.
f15 - Variable in class org.apache.flink.api.java.tuple.Tuple22
Field 15 of the tuple.
f15 - Variable in class org.apache.flink.api.java.tuple.Tuple23
Field 15 of the tuple.
f15 - Variable in class org.apache.flink.api.java.tuple.Tuple24
Field 15 of the tuple.
f15 - Variable in class org.apache.flink.api.java.tuple.Tuple25
Field 15 of the tuple.
f16 - Variable in class org.apache.flink.api.java.tuple.Tuple17
Field 16 of the tuple.
f16 - Variable in class org.apache.flink.api.java.tuple.Tuple18
Field 16 of the tuple.
f16 - Variable in class org.apache.flink.api.java.tuple.Tuple19
Field 16 of the tuple.
f16 - Variable in class org.apache.flink.api.java.tuple.Tuple20
Field 16 of the tuple.
f16 - Variable in class org.apache.flink.api.java.tuple.Tuple21
Field 16 of the tuple.
f16 - Variable in class org.apache.flink.api.java.tuple.Tuple22
Field 16 of the tuple.
f16 - Variable in class org.apache.flink.api.java.tuple.Tuple23
Field 16 of the tuple.
f16 - Variable in class org.apache.flink.api.java.tuple.Tuple24
Field 16 of the tuple.
f16 - Variable in class org.apache.flink.api.java.tuple.Tuple25
Field 16 of the tuple.
f17 - Variable in class org.apache.flink.api.java.tuple.Tuple18
Field 17 of the tuple.
f17 - Variable in class org.apache.flink.api.java.tuple.Tuple19
Field 17 of the tuple.
f17 - Variable in class org.apache.flink.api.java.tuple.Tuple20
Field 17 of the tuple.
f17 - Variable in class org.apache.flink.api.java.tuple.Tuple21
Field 17 of the tuple.
f17 - Variable in class org.apache.flink.api.java.tuple.Tuple22
Field 17 of the tuple.
f17 - Variable in class org.apache.flink.api.java.tuple.Tuple23
Field 17 of the tuple.
f17 - Variable in class org.apache.flink.api.java.tuple.Tuple24
Field 17 of the tuple.
f17 - Variable in class org.apache.flink.api.java.tuple.Tuple25
Field 17 of the tuple.
f18 - Variable in class org.apache.flink.api.java.tuple.Tuple19
Field 18 of the tuple.
f18 - Variable in class org.apache.flink.api.java.tuple.Tuple20
Field 18 of the tuple.
f18 - Variable in class org.apache.flink.api.java.tuple.Tuple21
Field 18 of the tuple.
f18 - Variable in class org.apache.flink.api.java.tuple.Tuple22
Field 18 of the tuple.
f18 - Variable in class org.apache.flink.api.java.tuple.Tuple23
Field 18 of the tuple.
f18 - Variable in class org.apache.flink.api.java.tuple.Tuple24
Field 18 of the tuple.
f18 - Variable in class org.apache.flink.api.java.tuple.Tuple25
Field 18 of the tuple.
f19 - Variable in class org.apache.flink.api.java.tuple.Tuple20
Field 19 of the tuple.
f19 - Variable in class org.apache.flink.api.java.tuple.Tuple21
Field 19 of the tuple.
f19 - Variable in class org.apache.flink.api.java.tuple.Tuple22
Field 19 of the tuple.
f19 - Variable in class org.apache.flink.api.java.tuple.Tuple23
Field 19 of the tuple.
f19 - Variable in class org.apache.flink.api.java.tuple.Tuple24
Field 19 of the tuple.
f19 - Variable in class org.apache.flink.api.java.tuple.Tuple25
Field 19 of the tuple.
f2 - Variable in class org.apache.flink.api.java.tuple.Tuple10
Field 2 of the tuple.
f2 - Variable in class org.apache.flink.api.java.tuple.Tuple11
Field 2 of the tuple.
f2 - Variable in class org.apache.flink.api.java.tuple.Tuple12
Field 2 of the tuple.
f2 - Variable in class org.apache.flink.api.java.tuple.Tuple13
Field 2 of the tuple.
f2 - Variable in class org.apache.flink.api.java.tuple.Tuple14
Field 2 of the tuple.
f2 - Variable in class org.apache.flink.api.java.tuple.Tuple15
Field 2 of the tuple.
f2 - Variable in class org.apache.flink.api.java.tuple.Tuple16
Field 2 of the tuple.
f2 - Variable in class org.apache.flink.api.java.tuple.Tuple17
Field 2 of the tuple.
f2 - Variable in class org.apache.flink.api.java.tuple.Tuple18
Field 2 of the tuple.
f2 - Variable in class org.apache.flink.api.java.tuple.Tuple19
Field 2 of the tuple.
f2 - Variable in class org.apache.flink.api.java.tuple.Tuple20
Field 2 of the tuple.
f2 - Variable in class org.apache.flink.api.java.tuple.Tuple21
Field 2 of the tuple.
f2 - Variable in class org.apache.flink.api.java.tuple.Tuple22
Field 2 of the tuple.
f2 - Variable in class org.apache.flink.api.java.tuple.Tuple23
Field 2 of the tuple.
f2 - Variable in class org.apache.flink.api.java.tuple.Tuple24
Field 2 of the tuple.
f2 - Variable in class org.apache.flink.api.java.tuple.Tuple25
Field 2 of the tuple.
f2 - Variable in class org.apache.flink.api.java.tuple.Tuple3
Field 2 of the tuple.
f2 - Variable in class org.apache.flink.api.java.tuple.Tuple4
Field 2 of the tuple.
f2 - Variable in class org.apache.flink.api.java.tuple.Tuple5
Field 2 of the tuple.
f2 - Variable in class org.apache.flink.api.java.tuple.Tuple6
Field 2 of the tuple.
f2 - Variable in class org.apache.flink.api.java.tuple.Tuple7
Field 2 of the tuple.
f2 - Variable in class org.apache.flink.api.java.tuple.Tuple8
Field 2 of the tuple.
f2 - Variable in class org.apache.flink.api.java.tuple.Tuple9
Field 2 of the tuple.
f20 - Variable in class org.apache.flink.api.java.tuple.Tuple21
Field 20 of the tuple.
f20 - Variable in class org.apache.flink.api.java.tuple.Tuple22
Field 20 of the tuple.
f20 - Variable in class org.apache.flink.api.java.tuple.Tuple23
Field 20 of the tuple.
f20 - Variable in class org.apache.flink.api.java.tuple.Tuple24
Field 20 of the tuple.
f20 - Variable in class org.apache.flink.api.java.tuple.Tuple25
Field 20 of the tuple.
f21 - Variable in class org.apache.flink.api.java.tuple.Tuple22
Field 21 of the tuple.
f21 - Variable in class org.apache.flink.api.java.tuple.Tuple23
Field 21 of the tuple.
f21 - Variable in class org.apache.flink.api.java.tuple.Tuple24
Field 21 of the tuple.
f21 - Variable in class org.apache.flink.api.java.tuple.Tuple25
Field 21 of the tuple.
f22 - Variable in class org.apache.flink.api.java.tuple.Tuple23
Field 22 of the tuple.
f22 - Variable in class org.apache.flink.api.java.tuple.Tuple24
Field 22 of the tuple.
f22 - Variable in class org.apache.flink.api.java.tuple.Tuple25
Field 22 of the tuple.
f23 - Variable in class org.apache.flink.api.java.tuple.Tuple24
Field 23 of the tuple.
f23 - Variable in class org.apache.flink.api.java.tuple.Tuple25
Field 23 of the tuple.
f24 - Variable in class org.apache.flink.api.java.tuple.Tuple25
Field 24 of the tuple.
f3 - Variable in class org.apache.flink.api.java.tuple.Tuple10
Field 3 of the tuple.
f3 - Variable in class org.apache.flink.api.java.tuple.Tuple11
Field 3 of the tuple.
f3 - Variable in class org.apache.flink.api.java.tuple.Tuple12
Field 3 of the tuple.
f3 - Variable in class org.apache.flink.api.java.tuple.Tuple13
Field 3 of the tuple.
f3 - Variable in class org.apache.flink.api.java.tuple.Tuple14
Field 3 of the tuple.
f3 - Variable in class org.apache.flink.api.java.tuple.Tuple15
Field 3 of the tuple.
f3 - Variable in class org.apache.flink.api.java.tuple.Tuple16
Field 3 of the tuple.
f3 - Variable in class org.apache.flink.api.java.tuple.Tuple17
Field 3 of the tuple.
f3 - Variable in class org.apache.flink.api.java.tuple.Tuple18
Field 3 of the tuple.
f3 - Variable in class org.apache.flink.api.java.tuple.Tuple19
Field 3 of the tuple.
f3 - Variable in class org.apache.flink.api.java.tuple.Tuple20
Field 3 of the tuple.
f3 - Variable in class org.apache.flink.api.java.tuple.Tuple21
Field 3 of the tuple.
f3 - Variable in class org.apache.flink.api.java.tuple.Tuple22
Field 3 of the tuple.
f3 - Variable in class org.apache.flink.api.java.tuple.Tuple23
Field 3 of the tuple.
f3 - Variable in class org.apache.flink.api.java.tuple.Tuple24
Field 3 of the tuple.
f3 - Variable in class org.apache.flink.api.java.tuple.Tuple25
Field 3 of the tuple.
f3 - Variable in class org.apache.flink.api.java.tuple.Tuple4
Field 3 of the tuple.
f3 - Variable in class org.apache.flink.api.java.tuple.Tuple5
Field 3 of the tuple.
f3 - Variable in class org.apache.flink.api.java.tuple.Tuple6
Field 3 of the tuple.
f3 - Variable in class org.apache.flink.api.java.tuple.Tuple7
Field 3 of the tuple.
f3 - Variable in class org.apache.flink.api.java.tuple.Tuple8
Field 3 of the tuple.
f3 - Variable in class org.apache.flink.api.java.tuple.Tuple9
Field 3 of the tuple.
f4 - Variable in class org.apache.flink.api.java.tuple.Tuple10
Field 4 of the tuple.
f4 - Variable in class org.apache.flink.api.java.tuple.Tuple11
Field 4 of the tuple.
f4 - Variable in class org.apache.flink.api.java.tuple.Tuple12
Field 4 of the tuple.
f4 - Variable in class org.apache.flink.api.java.tuple.Tuple13
Field 4 of the tuple.
f4 - Variable in class org.apache.flink.api.java.tuple.Tuple14
Field 4 of the tuple.
f4 - Variable in class org.apache.flink.api.java.tuple.Tuple15
Field 4 of the tuple.
f4 - Variable in class org.apache.flink.api.java.tuple.Tuple16
Field 4 of the tuple.
f4 - Variable in class org.apache.flink.api.java.tuple.Tuple17
Field 4 of the tuple.
f4 - Variable in class org.apache.flink.api.java.tuple.Tuple18
Field 4 of the tuple.
f4 - Variable in class org.apache.flink.api.java.tuple.Tuple19
Field 4 of the tuple.
f4 - Variable in class org.apache.flink.api.java.tuple.Tuple20
Field 4 of the tuple.
f4 - Variable in class org.apache.flink.api.java.tuple.Tuple21
Field 4 of the tuple.
f4 - Variable in class org.apache.flink.api.java.tuple.Tuple22
Field 4 of the tuple.
f4 - Variable in class org.apache.flink.api.java.tuple.Tuple23
Field 4 of the tuple.
f4 - Variable in class org.apache.flink.api.java.tuple.Tuple24
Field 4 of the tuple.
f4 - Variable in class org.apache.flink.api.java.tuple.Tuple25
Field 4 of the tuple.
f4 - Variable in class org.apache.flink.api.java.tuple.Tuple5
Field 4 of the tuple.
f4 - Variable in class org.apache.flink.api.java.tuple.Tuple6
Field 4 of the tuple.
f4 - Variable in class org.apache.flink.api.java.tuple.Tuple7
Field 4 of the tuple.
f4 - Variable in class org.apache.flink.api.java.tuple.Tuple8
Field 4 of the tuple.
f4 - Variable in class org.apache.flink.api.java.tuple.Tuple9
Field 4 of the tuple.
f5 - Variable in class org.apache.flink.api.java.tuple.Tuple10
Field 5 of the tuple.
f5 - Variable in class org.apache.flink.api.java.tuple.Tuple11
Field 5 of the tuple.
f5 - Variable in class org.apache.flink.api.java.tuple.Tuple12
Field 5 of the tuple.
f5 - Variable in class org.apache.flink.api.java.tuple.Tuple13
Field 5 of the tuple.
f5 - Variable in class org.apache.flink.api.java.tuple.Tuple14
Field 5 of the tuple.
f5 - Variable in class org.apache.flink.api.java.tuple.Tuple15
Field 5 of the tuple.
f5 - Variable in class org.apache.flink.api.java.tuple.Tuple16
Field 5 of the tuple.
f5 - Variable in class org.apache.flink.api.java.tuple.Tuple17
Field 5 of the tuple.
f5 - Variable in class org.apache.flink.api.java.tuple.Tuple18
Field 5 of the tuple.
f5 - Variable in class org.apache.flink.api.java.tuple.Tuple19
Field 5 of the tuple.
f5 - Variable in class org.apache.flink.api.java.tuple.Tuple20
Field 5 of the tuple.
f5 - Variable in class org.apache.flink.api.java.tuple.Tuple21
Field 5 of the tuple.
f5 - Variable in class org.apache.flink.api.java.tuple.Tuple22
Field 5 of the tuple.
f5 - Variable in class org.apache.flink.api.java.tuple.Tuple23
Field 5 of the tuple.
f5 - Variable in class org.apache.flink.api.java.tuple.Tuple24
Field 5 of the tuple.
f5 - Variable in class org.apache.flink.api.java.tuple.Tuple25
Field 5 of the tuple.
f5 - Variable in class org.apache.flink.api.java.tuple.Tuple6
Field 5 of the tuple.
f5 - Variable in class org.apache.flink.api.java.tuple.Tuple7
Field 5 of the tuple.
f5 - Variable in class org.apache.flink.api.java.tuple.Tuple8
Field 5 of the tuple.
f5 - Variable in class org.apache.flink.api.java.tuple.Tuple9
Field 5 of the tuple.
f6 - Variable in class org.apache.flink.api.java.tuple.Tuple10
Field 6 of the tuple.
f6 - Variable in class org.apache.flink.api.java.tuple.Tuple11
Field 6 of the tuple.
f6 - Variable in class org.apache.flink.api.java.tuple.Tuple12
Field 6 of the tuple.
f6 - Variable in class org.apache.flink.api.java.tuple.Tuple13
Field 6 of the tuple.
f6 - Variable in class org.apache.flink.api.java.tuple.Tuple14
Field 6 of the tuple.
f6 - Variable in class org.apache.flink.api.java.tuple.Tuple15
Field 6 of the tuple.
f6 - Variable in class org.apache.flink.api.java.tuple.Tuple16
Field 6 of the tuple.
f6 - Variable in class org.apache.flink.api.java.tuple.Tuple17
Field 6 of the tuple.
f6 - Variable in class org.apache.flink.api.java.tuple.Tuple18
Field 6 of the tuple.
f6 - Variable in class org.apache.flink.api.java.tuple.Tuple19
Field 6 of the tuple.
f6 - Variable in class org.apache.flink.api.java.tuple.Tuple20
Field 6 of the tuple.
f6 - Variable in class org.apache.flink.api.java.tuple.Tuple21
Field 6 of the tuple.
f6 - Variable in class org.apache.flink.api.java.tuple.Tuple22
Field 6 of the tuple.
f6 - Variable in class org.apache.flink.api.java.tuple.Tuple23
Field 6 of the tuple.
f6 - Variable in class org.apache.flink.api.java.tuple.Tuple24
Field 6 of the tuple.
f6 - Variable in class org.apache.flink.api.java.tuple.Tuple25
Field 6 of the tuple.
f6 - Variable in class org.apache.flink.api.java.tuple.Tuple7
Field 6 of the tuple.
f6 - Variable in class org.apache.flink.api.java.tuple.Tuple8
Field 6 of the tuple.
f6 - Variable in class org.apache.flink.api.java.tuple.Tuple9
Field 6 of the tuple.
f7 - Variable in class org.apache.flink.api.java.tuple.Tuple10
Field 7 of the tuple.
f7 - Variable in class org.apache.flink.api.java.tuple.Tuple11
Field 7 of the tuple.
f7 - Variable in class org.apache.flink.api.java.tuple.Tuple12
Field 7 of the tuple.
f7 - Variable in class org.apache.flink.api.java.tuple.Tuple13
Field 7 of the tuple.
f7 - Variable in class org.apache.flink.api.java.tuple.Tuple14
Field 7 of the tuple.
f7 - Variable in class org.apache.flink.api.java.tuple.Tuple15
Field 7 of the tuple.
f7 - Variable in class org.apache.flink.api.java.tuple.Tuple16
Field 7 of the tuple.
f7 - Variable in class org.apache.flink.api.java.tuple.Tuple17
Field 7 of the tuple.
f7 - Variable in class org.apache.flink.api.java.tuple.Tuple18
Field 7 of the tuple.
f7 - Variable in class org.apache.flink.api.java.tuple.Tuple19
Field 7 of the tuple.
f7 - Variable in class org.apache.flink.api.java.tuple.Tuple20
Field 7 of the tuple.
f7 - Variable in class org.apache.flink.api.java.tuple.Tuple21
Field 7 of the tuple.
f7 - Variable in class org.apache.flink.api.java.tuple.Tuple22
Field 7 of the tuple.
f7 - Variable in class org.apache.flink.api.java.tuple.Tuple23
Field 7 of the tuple.
f7 - Variable in class org.apache.flink.api.java.tuple.Tuple24
Field 7 of the tuple.
f7 - Variable in class org.apache.flink.api.java.tuple.Tuple25
Field 7 of the tuple.
f7 - Variable in class org.apache.flink.api.java.tuple.Tuple8
Field 7 of the tuple.
f7 - Variable in class org.apache.flink.api.java.tuple.Tuple9
Field 7 of the tuple.
f8 - Variable in class org.apache.flink.api.java.tuple.Tuple10
Field 8 of the tuple.
f8 - Variable in class org.apache.flink.api.java.tuple.Tuple11
Field 8 of the tuple.
f8 - Variable in class org.apache.flink.api.java.tuple.Tuple12
Field 8 of the tuple.
f8 - Variable in class org.apache.flink.api.java.tuple.Tuple13
Field 8 of the tuple.
f8 - Variable in class org.apache.flink.api.java.tuple.Tuple14
Field 8 of the tuple.
f8 - Variable in class org.apache.flink.api.java.tuple.Tuple15
Field 8 of the tuple.
f8 - Variable in class org.apache.flink.api.java.tuple.Tuple16
Field 8 of the tuple.
f8 - Variable in class org.apache.flink.api.java.tuple.Tuple17
Field 8 of the tuple.
f8 - Variable in class org.apache.flink.api.java.tuple.Tuple18
Field 8 of the tuple.
f8 - Variable in class org.apache.flink.api.java.tuple.Tuple19
Field 8 of the tuple.
f8 - Variable in class org.apache.flink.api.java.tuple.Tuple20
Field 8 of the tuple.
f8 - Variable in class org.apache.flink.api.java.tuple.Tuple21
Field 8 of the tuple.
f8 - Variable in class org.apache.flink.api.java.tuple.Tuple22
Field 8 of the tuple.
f8 - Variable in class org.apache.flink.api.java.tuple.Tuple23
Field 8 of the tuple.
f8 - Variable in class org.apache.flink.api.java.tuple.Tuple24
Field 8 of the tuple.
f8 - Variable in class org.apache.flink.api.java.tuple.Tuple25
Field 8 of the tuple.
f8 - Variable in class org.apache.flink.api.java.tuple.Tuple9
Field 8 of the tuple.
f9 - Variable in class org.apache.flink.api.java.tuple.Tuple10
Field 9 of the tuple.
f9 - Variable in class org.apache.flink.api.java.tuple.Tuple11
Field 9 of the tuple.
f9 - Variable in class org.apache.flink.api.java.tuple.Tuple12
Field 9 of the tuple.
f9 - Variable in class org.apache.flink.api.java.tuple.Tuple13
Field 9 of the tuple.
f9 - Variable in class org.apache.flink.api.java.tuple.Tuple14
Field 9 of the tuple.
f9 - Variable in class org.apache.flink.api.java.tuple.Tuple15
Field 9 of the tuple.
f9 - Variable in class org.apache.flink.api.java.tuple.Tuple16
Field 9 of the tuple.
f9 - Variable in class org.apache.flink.api.java.tuple.Tuple17
Field 9 of the tuple.
f9 - Variable in class org.apache.flink.api.java.tuple.Tuple18
Field 9 of the tuple.
f9 - Variable in class org.apache.flink.api.java.tuple.Tuple19
Field 9 of the tuple.
f9 - Variable in class org.apache.flink.api.java.tuple.Tuple20
Field 9 of the tuple.
f9 - Variable in class org.apache.flink.api.java.tuple.Tuple21
Field 9 of the tuple.
f9 - Variable in class org.apache.flink.api.java.tuple.Tuple22
Field 9 of the tuple.
f9 - Variable in class org.apache.flink.api.java.tuple.Tuple23
Field 9 of the tuple.
f9 - Variable in class org.apache.flink.api.java.tuple.Tuple24
Field 9 of the tuple.
f9 - Variable in class org.apache.flink.api.java.tuple.Tuple25
Field 9 of the tuple.
Factorization(DataSet<ALS.Factors>, DataSet<ALS.Factors>) - Constructor for class org.apache.flink.ml.recommendation.ALS.Factorization
 
Factorization$() - Constructor for class org.apache.flink.ml.recommendation.ALS.Factorization$
 
Factors(long, double[]) - Constructor for class org.apache.flink.ml.recommendation.ALS.Factors
 
factors() - Method in class org.apache.flink.ml.recommendation.ALS.Factors
 
Factors$() - Constructor for class org.apache.flink.ml.recommendation.ALS.Factors$
 
factorsOption() - Method in class org.apache.flink.ml.recommendation.ALS
 
FACTORY - Static variable in class org.apache.flink.core.memory.HeapMemorySegment
 
FACTORY - Static variable in class org.apache.flink.core.memory.HybridMemorySegment
 
Factory() - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartAllStrategy.Factory
 
Factory() - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy.Factory
 
Factory() - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy.Factory
 
FACTORY() - Method in class org.apache.flink.table.plan.cost.DataSetCost$
 
FACTORY() - Static method in class org.apache.flink.table.plan.cost.DataSetCost
 
FactoryTypeDescriptor(int, scala.reflect.macros.Context.universe, scala.reflect.macros.Context.universe, Seq<TypeDescriptors<C>.UDTDescriptor>) - Constructor for class org.apache.flink.api.scala.codegen.TypeDescriptors.FactoryTypeDescriptor
 
fail(Throwable) - Method in class org.apache.flink.runtime.executiongraph.Execution
This method fails the vertex due to an external condition.
fail(Throwable) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
fail(Throwable) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
fail(Object) - Method in class org.apache.flink.storm.util.AbstractLineSpout
 
fail(Object) - Method in class org.apache.flink.storm.util.NullTerminatingSpout
 
failAllocation(AllocationID, Exception) - Method in class org.apache.flink.runtime.instance.SlotPool
Fail the specified allocation and release the corresponding slot if we have one.
failAllocation(AllocationID, Exception) - Method in interface org.apache.flink.runtime.instance.SlotPoolGateway
 
FailedCheckpointStats - Class in org.apache.flink.runtime.checkpoint
Statistics for a failed checkpoint.
failExternally(Throwable) - Method in interface org.apache.flink.runtime.execution.Environment
Marks task execution failed for an external reason (a reason other than the task code itself throwing an exception).
failExternally(Throwable) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
failExternally(Throwable) - Method in class org.apache.flink.runtime.taskmanager.Task
Marks task execution failed for an external reason (a reason other than the task code itself throwing an exception).
failExternally(Throwable) - Method in interface org.apache.flink.runtime.taskmanager.TaskActions
Fail the owning task with the given throwable.
failGlobal(Throwable) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Fails the execution graph globally.
FailingHandler() - Constructor for class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.FailingHandler
 
FailIntermediateResultPartitions(ExecutionAttemptID) - Constructor for class org.apache.flink.runtime.messages.TaskMessages.FailIntermediateResultPartitions
 
FailIntermediateResultPartitions$() - Constructor for class org.apache.flink.runtime.messages.TaskMessages.FailIntermediateResultPartitions$
 
failOperator(Throwable) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
failOperator(Throwable) - Method in interface org.apache.flink.streaming.api.operators.async.OperatorActions
Fail the respective stream operator with the given throwable.
FailoverRegion - Class in org.apache.flink.runtime.executiongraph.failover
FailoverRegion manages the failover of a minimal pipeline connected sub graph.
FailoverRegion(ExecutionGraph, Executor, List<ExecutionVertex>) - Constructor for class org.apache.flink.runtime.executiongraph.failover.FailoverRegion
 
FailoverStrategy - Class in org.apache.flink.runtime.executiongraph.failover
A FailoverStrategy describes how the job computation recovers from task failures.
FailoverStrategy() - Constructor for class org.apache.flink.runtime.executiongraph.failover.FailoverStrategy
 
FailoverStrategy.Factory - Interface in org.apache.flink.runtime.executiongraph.failover
This factory is a necessary indirection when creating the FailoverStrategy to that we can have both the FailoverStrategy final in the ExecutionGraph, and the ExecutionGraph final in the FailOverStrategy.
FailoverStrategyLoader - Class in org.apache.flink.runtime.executiongraph.failover
A utility class to load failover strategies from the configuration.
FailoverStrategyLoader() - Constructor for class org.apache.flink.runtime.executiongraph.failover.FailoverStrategyLoader
 
failPartition(ExecutionAttemptID) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
failPartition(ExecutionAttemptID) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Fail all intermediate result partitions of the given task.
failPartition(ExecutionAttemptID) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
failPartition(ExecutionAttemptID) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
failPartition(ExecutionAttemptID) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Fail all intermediate result partitions of the given task.
failSlot(ResourceID, AllocationID, UUID, Exception) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
failSlot(ResourceID, AllocationID, UUID, Exception) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
Fail the slot with the given allocation id and cause.
FailTask(ExecutionAttemptID, Throwable) - Constructor for class org.apache.flink.runtime.messages.TaskMessages.FailTask
 
failTask(ExecutionAttemptID, Throwable) - Method in class org.apache.flink.runtime.taskmanager.ActorGatewayTaskManagerActions
 
failTask(ExecutionAttemptID, Throwable) - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerActions
Tells the task manager to fail the given task.
FailTask$() - Constructor for class org.apache.flink.runtime.messages.TaskMessages.FailTask$
 
failure(String) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
failureRateRestart(int, Time, Time) - Static method in class org.apache.flink.api.common.restartstrategy.RestartStrategies
Generates a FailureRateRestartStrategyConfiguration.
FailureRateRestartStrategy - Class in org.apache.flink.runtime.executiongraph.restart
Restart strategy which tries to restart the given ExecutionGraph when failure rate exceeded with a fixed time delay in between.
FailureRateRestartStrategy(int, Time, Time) - Constructor for class org.apache.flink.runtime.executiongraph.restart.FailureRateRestartStrategy
 
FailureRateRestartStrategy.FailureRateRestartStrategyFactory - Class in org.apache.flink.runtime.executiongraph.restart
 
FailureRateRestartStrategyConfiguration(int, Time, Time) - Constructor for class org.apache.flink.api.common.restartstrategy.RestartStrategies.FailureRateRestartStrategyConfiguration
 
FailureRateRestartStrategyFactory(int, Time, Time) - Constructor for class org.apache.flink.runtime.executiongraph.restart.FailureRateRestartStrategy.FailureRateRestartStrategyFactory
 
failValidation(String) - Static method in class org.apache.flink.table.plan.logical.Aggregate
 
failValidation(String) - Static method in class org.apache.flink.table.plan.logical.AliasNode
 
failValidation(String) - Static method in class org.apache.flink.table.plan.logical.CatalogNode
 
failValidation(String) - Static method in class org.apache.flink.table.plan.logical.Distinct
 
failValidation(String) - Static method in class org.apache.flink.table.plan.logical.Filter
 
failValidation(String) - Static method in class org.apache.flink.table.plan.logical.Intersect
 
failValidation(String) - Static method in class org.apache.flink.table.plan.logical.Join
 
failValidation(String) - Static method in class org.apache.flink.table.plan.logical.Limit
 
failValidation(String) - Method in class org.apache.flink.table.plan.logical.LogicalNode
 
failValidation(String) - Static method in class org.apache.flink.table.plan.logical.LogicalRelNode
 
failValidation(String) - Static method in class org.apache.flink.table.plan.logical.LogicalTableFunctionCall
 
failValidation(String) - Static method in class org.apache.flink.table.plan.logical.Minus
 
failValidation(String) - Static method in class org.apache.flink.table.plan.logical.Project
 
failValidation(String) - Static method in class org.apache.flink.table.plan.logical.Sort
 
failValidation(String) - Static method in class org.apache.flink.table.plan.logical.Union
 
failValidation(String) - Static method in class org.apache.flink.table.plan.logical.WindowAggregate
 
fallbackEvaluateOperation(TypeTags.TypeTag<Self>, TypeTags.TypeTag<Testing>) - Method in class org.apache.flink.ml.pipeline.Estimator$
 
fallbackFitOperation(TypeTags.TypeTag<Self>, TypeTags.TypeTag<Training>) - Method in class org.apache.flink.ml.pipeline.Estimator$
Fallback FitOperation type class implementation which is used if no other FitOperation with the right input types could be found in the scope of the implementing class.
FallbackLibraryCacheManager - Class in org.apache.flink.runtime.execution.librarycache
 
FallbackLibraryCacheManager() - Constructor for class org.apache.flink.runtime.execution.librarycache.FallbackLibraryCacheManager
 
fallbackPredictOperation(TypeTags.TypeTag<Self>, TypeTags.TypeTag<Testing>) - Method in class org.apache.flink.ml.pipeline.Estimator$
Fallback PredictDataSetOperation if a Predictor is called with a not supported input data type.
fallBackRestart() - Static method in class org.apache.flink.api.common.restartstrategy.RestartStrategies
 
FallbackRestartStrategyConfiguration() - Constructor for class org.apache.flink.api.common.restartstrategy.RestartStrategies.FallbackRestartStrategyConfiguration
 
fallbackTransformOperation(TypeTags.TypeTag<Self>, TypeTags.TypeTag<IN>) - Method in class org.apache.flink.ml.pipeline.Estimator$
Fallback TransformDataSetOperation for Transformer which do not support the input or output type with which they are called.
FALSE() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
FALSE() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
FALSE - Static variable in class org.apache.flink.types.BooleanValue
 
falseFunction() - Static method in class org.apache.flink.cep.pattern.conditions.BooleanConditions
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.api.CurrentRange
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.api.CurrentRow
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.api.UnboundedRange
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.api.UnboundedRow
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Abs
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Acos
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.AggFunctionCall
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Alias
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.And
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.ArrayCardinality
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.ArrayConstructor
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.ArrayElement
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.ArrayElementAt
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Asc
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Asin
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Atan
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Avg
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Call
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Cast
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Ceil
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.CharLength
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Cos
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Cot
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Count
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.CurrentDate
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.CurrentTime
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.CurrentTimestamp
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Degrees
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Desc
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Div
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.EqualTo
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Exp
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Extract
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Flattening
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Floor
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.GetCompositeField
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.GreaterThan
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.GreaterThanOrEqual
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.If
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.InitCap
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.IsFalse
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.IsNotFalse
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.IsNotNull
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.IsNotTrue
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.IsNull
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.IsTrue
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.LessThan
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.LessThanOrEqual
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Like
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Literal
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Ln
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.LocalTime
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.LocalTimestamp
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Log10
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Lower
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Max
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Min
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Minus
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Mod
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Mul
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Not
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.NotEqualTo
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Null
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Or
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.OverCall
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Overlay
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Pi
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Plus
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Position
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Power
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.ProctimeAttribute
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Quarter
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Radians
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.ResolvedFieldReference
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Round
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.RowtimeAttribute
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.ScalarFunctionCall
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Sign
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Similar
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Sin
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Sqrt
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.StddevPop
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.StddevSamp
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Substring
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Sum
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Sum0
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.SymbolExpression
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.TableFunctionCall
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Tan
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.TemporalCeil
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.TemporalFloor
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.TemporalOverlaps
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Trim
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.UnaryMinus
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.UnresolvedAlias
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.UnresolvedFieldReference
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.UnresolvedOverCall
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.Upper
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.VarPop
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.VarSamp
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.WindowEnd
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.WindowReference
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.expressions.WindowStart
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.plan.logical.Aggregate
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.plan.logical.AliasNode
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.plan.logical.CatalogNode
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.plan.logical.Distinct
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.plan.logical.Filter
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.plan.logical.Intersect
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.plan.logical.Join
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.plan.logical.Limit
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.plan.logical.LogicalRelNode
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.plan.logical.LogicalTableFunctionCall
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.plan.logical.Minus
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.plan.logical.Project
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.plan.logical.Sort
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.plan.logical.Union
 
fastEquals(TreeNode<?>) - Static method in class org.apache.flink.table.plan.logical.WindowAggregate
 
fastEquals(TreeNode<?>) - Method in class org.apache.flink.table.plan.TreeNode
Tests for equality by first testing for reference equality.
fatalError(String, Throwable) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
 
fatalError(String, Throwable) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Notifies the resource master of a fatal error.
fatalError(String, Throwable) - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
 
FatalError(String, Throwable) - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages.FatalError
 
fatalError(String, Throwable) - Method in class org.apache.flink.yarn.YarnFlinkResourceManager
 
FatalError$() - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages.FatalError$
 
FatalErrorHandler - Interface in org.apache.flink.runtime.rpc
 
FatalErrorOccurred - Class in org.apache.flink.runtime.clusterframework.messages
Message sent to the Flink's resource manager in case of a fatal error that cannot be recovered in the running process.
FatalErrorOccurred(String, Throwable) - Constructor for class org.apache.flink.runtime.clusterframework.messages.FatalErrorOccurred
 
FatalExitExceptionHandler - Class in org.apache.flink.runtime.util
Handler for uncaught exceptions that will log the exception and kill the process afterwards.
FatalExitExceptionHandler() - Constructor for class org.apache.flink.runtime.util.FatalExitExceptionHandler
 
FeedbackTransformation<T> - Class in org.apache.flink.streaming.api.transformations
This represents a feedback point in a topology.
FeedbackTransformation(StreamTransformation<T>, Long) - Constructor for class org.apache.flink.streaming.api.transformations.FeedbackTransformation
Creates a new FeedbackTransformation from the given input.
fetch() - Method in class org.apache.flink.table.plan.logical.Limit
 
fetchConnectionInfo(FlinkShell.Config) - Method in class org.apache.flink.api.scala.FlinkShell$
 
fetchConnectionInfo(FlinkShell.Config) - Static method in class org.apache.flink.api.scala.FlinkShell
 
fetchDeployedYarnClusterInfo() - Method in class org.apache.flink.api.scala.FlinkShell$
 
fetchDeployedYarnClusterInfo() - Static method in class org.apache.flink.api.scala.FlinkShell
 
fetched - Variable in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
fetched - Variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
fetchNext() - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
fetchNext() - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
field - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
field(String) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
field(int, int, String) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
field(int) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
field(int, int, int) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
field(String, String) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
field(int, String, String) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
field(RexNode, String) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
field() - Method in class org.apache.flink.table.codegen.CodeGenUtils.ObjectFieldAccessor
 
field() - Method in class org.apache.flink.table.codegen.CodeGenUtils.ObjectPrivateFieldAccessor
 
field(String, TypeInformation<?>) - Method in class org.apache.flink.table.sources.CsvTableSource.Builder
Adds a field with the field name and the type information.
FieldAccessFinder - Class in org.apache.flink.api.scala
 
FieldAccessFinder(Map<Class<?>, Set<String>>) - Constructor for class org.apache.flink.api.scala.FieldAccessFinder
 
FieldAccessor<T,F> - Class in org.apache.flink.streaming.util.typeutils
These classes encapsulate the logic of accessing a field specified by the user as either an index or a field expression string.
FieldAccessor() - Constructor for class org.apache.flink.streaming.util.typeutils.FieldAccessor
 
FieldAccessor() - Constructor for class org.apache.flink.table.codegen.CodeGenUtils.FieldAccessor
 
FieldAccessorFactory - Class in org.apache.flink.streaming.util.typeutils
Static factories for the FieldAccessor utilities.
FieldAccessorFactory() - Constructor for class org.apache.flink.streaming.util.typeutils.FieldAccessorFactory
 
fieldAccessorFor(CompositeType<?>, int) - Method in class org.apache.flink.table.codegen.CodeGenUtils$
 
fieldAccessorFor(CompositeType<?>, int) - Static method in class org.apache.flink.table.codegen.CodeGenUtils
 
fieldDelimiter - Variable in class org.apache.flink.api.java.io.CsvReader
 
fieldDelimiter(char) - Method in class org.apache.flink.api.java.io.CsvReader
Deprecated.
fieldDelimiter(String) - Method in class org.apache.flink.api.java.io.CsvReader
Configures the delimiter that separates the fields within a row.
fieldDelimiter - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
fieldDelimiter(String) - Method in class org.apache.flink.table.sources.CsvTableSource.Builder
Sets the field delimiter, "," by default.
fieldDelimiterEdges(String) - Method in class org.apache.flink.graph.GraphCsvReader
Configures the Delimiter that separates fields in a row for the CSV reader used to read the edges (',') is used by default.
fieldDelimiterVertices(String) - Method in class org.apache.flink.graph.GraphCsvReader
Configures the Delimiter that separates fields in a row for the CSV reader used to read the vertices (',') is used by default.
FieldDescriptor(String, scala.reflect.macros.Context.universe, scala.reflect.macros.Context.universe, scala.reflect.macros.Context.universe, TypeDescriptors<C>.UDTDescriptor) - Constructor for class org.apache.flink.api.scala.codegen.TypeDescriptors.FieldDescriptor
 
FieldFromArray<OUT> - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
Extracts a single field out of an array.
FieldFromArray() - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromArray
Extracts the first field (id 0) from the array.
FieldFromArray(int) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromArray
Extracts the field with the given id from the array.
FieldFromTuple<OUT> - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
Extracts a single field out of a tuple.
FieldFromTuple(int) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldFromTuple
Extracts the field with the given id from the tuple.
fieldIncluded - Variable in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
fieldIndex(String) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
fieldIndexes() - Method in class org.apache.flink.table.plan.schema.DataSetTable
 
fieldIndexes() - Method in class org.apache.flink.table.plan.schema.DataStreamTable
 
fieldIndexes() - Method in class org.apache.flink.table.plan.schema.FlinkTable
 
fieldIndexes() - Method in class org.apache.flink.table.plan.schema.FlinkTableFunctionImpl
 
fieldIndexes() - Static method in class org.apache.flink.table.plan.schema.StreamTableSourceTable
 
fieldIndexes() - Static method in class org.apache.flink.table.plan.schema.TableSourceTable
 
FieldList - Class in org.apache.flink.api.common.operators.util
Immutable ordered list of fields IDs.
FieldList() - Constructor for class org.apache.flink.api.common.operators.util.FieldList
 
FieldList(int) - Constructor for class org.apache.flink.api.common.operators.util.FieldList
 
FieldList(Integer) - Constructor for class org.apache.flink.api.common.operators.util.FieldList
 
FieldList(int...) - Constructor for class org.apache.flink.api.common.operators.util.FieldList
 
fieldNames - Variable in class org.apache.flink.api.java.typeutils.RowTypeInfo
 
fieldNames - Variable in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
fieldNames() - Method in class org.apache.flink.api.scala.typeutils.CaseClassTypeInfo
 
fieldNames - Variable in class org.apache.flink.hcatalog.HCatInputFormatBase
 
fieldNames - Variable in class org.apache.flink.streaming.connectors.kafka.KafkaTableSink
 
fieldNames() - Method in class org.apache.flink.table.plan.logical.LogicalTableFunctionCall
 
fieldNames() - Method in class org.apache.flink.table.plan.schema.DataSetTable
 
fieldNames() - Method in class org.apache.flink.table.plan.schema.DataStreamTable
 
fieldNames() - Method in class org.apache.flink.table.plan.schema.FlinkTable
 
fieldNames() - Method in class org.apache.flink.table.plan.schema.FlinkTableFunctionImpl
 
fieldNames() - Static method in class org.apache.flink.table.plan.schema.StreamTableSourceTable
 
fieldNames() - Static method in class org.apache.flink.table.plan.schema.TableSourceTable
 
fieldNames() - Method in interface org.apache.flink.table.sinks.TableSinkBase
 
FieldParser<T> - Class in org.apache.flink.types.parser
A FieldParser is used parse a field from a sequence of bytes.
FieldParser() - Constructor for class org.apache.flink.types.parser.FieldParser
 
FieldParser.ParseErrorState - Enum in org.apache.flink.types.parser
An enumeration of different types of errors that may occur.
fieldReference() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
fieldReference() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
fields - Variable in class org.apache.flink.api.java.operators.ProjectOperator
 
fields() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.JavaTupleDescriptor
 
fields() - Method in class org.apache.flink.api.scala.typeutils.CaseClassSerializer
 
fields() - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
fields(int, int) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
fields(RelCollation) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
fields(List<? extends Number>) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
fields(Iterable<String>) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
fields(Mappings.TargetMapping) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
FieldSerializer - Class in org.apache.flink.api.java.typeutils.runtime
This class is for the serialization of java.lang.reflect.Field, which doesn't implement Serializable, therefore readObject/writeObject need to be implemented in classes where there is a field of type java.lang.reflect.Field.
FieldSerializer() - Constructor for class org.apache.flink.api.java.typeutils.runtime.FieldSerializer
 
fieldSerializers - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
FieldSet - Class in org.apache.flink.api.common.operators.util
Immutable unordered collection of fields IDs.
FieldSet() - Constructor for class org.apache.flink.api.common.operators.util.FieldSet
Creates a new empty set of fields.
FieldSet(Integer) - Constructor for class org.apache.flink.api.common.operators.util.FieldSet
Creates a set with one field.
FieldSet(int...) - Constructor for class org.apache.flink.api.common.operators.util.FieldSet
Creates a set with the given fields.
FieldSet(int[], boolean) - Constructor for class org.apache.flink.api.common.operators.util.FieldSet
Creates a set with the given fields.
FieldSet(Collection<Integer>) - Constructor for class org.apache.flink.api.common.operators.util.FieldSet
 
FieldsFromArray<OUT> - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
Extracts multiple fields from an array and puts them into a new array of the specified type.
FieldsFromArray(Class<OUT>, int...) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldsFromArray
Extracts multiple fields from an array and puts them in the given order into a new array of the specified type.
FieldsFromTuple - Class in org.apache.flink.streaming.api.functions.windowing.delta.extractor
Extracts one or more fields of the type Double from a tuple and puts them into a new double[].
FieldsFromTuple(int...) - Constructor for class org.apache.flink.streaming.api.functions.windowing.delta.extractor.FieldsFromTuple
Extracts one or more fields of the the type Double from a tuple and puts them into a new double[] (in the specified order).
fieldType - Variable in class org.apache.flink.streaming.util.typeutils.FieldAccessor
 
fieldTypes - Variable in class org.apache.flink.streaming.connectors.kafka.KafkaTableSink
 
fieldTypes() - Static method in class org.apache.flink.table.plan.schema.DataSetTable
 
fieldTypes() - Static method in class org.apache.flink.table.plan.schema.DataStreamTable
 
fieldTypes() - Method in class org.apache.flink.table.plan.schema.FlinkTable
 
fieldTypes() - Method in class org.apache.flink.table.plan.schema.FlinkTableFunctionImpl
 
fieldTypes() - Static method in class org.apache.flink.table.plan.schema.StreamTableSourceTable
 
fieldTypes() - Static method in class org.apache.flink.table.plan.schema.TableSourceTable
 
fieldTypes() - Method in interface org.apache.flink.table.sinks.TableSinkBase
 
FieldVisitorImpl(int) - Constructor for class org.apache.flink.runtime.util.DependencyVisitor.FieldVisitorImpl
 
FILE_PARAMETER_KEY - Static variable in class org.apache.flink.api.common.io.FileOutputFormat
The key under which the name of the target path is stored in the configuration.
FileBaseStatistics(long, long, float) - Constructor for class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
Creates a new statistics object.
fileCache() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
FileCache - Class in org.apache.flink.runtime.filecache
The FileCache is used to create the local files for the registered cache files when a task is deployed.
FileCache(String[]) - Constructor for class org.apache.flink.runtime.filecache.FileCache
 
fileCache() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
Handler for distributed files cached by this TaskManager
fileCache() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
fileChannel - Variable in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
A file channel for NIO access to the file.
FileChannelInputView - Class in org.apache.flink.runtime.io.disk
A DataInputView that is backed by a BlockChannelReader, making it effectively a data input stream.
FileChannelInputView(BlockChannelReader<MemorySegment>, MemoryManager, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.io.disk.FileChannelInputView
 
FileChannelOutputView - Class in org.apache.flink.runtime.io.disk
A DataOutputView that is backed by a BlockChannelWriter, making it effectively a data output stream.
FileChannelOutputView(BlockChannelWriter<MemorySegment>, MemoryManager, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.io.disk.FileChannelOutputView
 
FileCopyTask - Class in org.apache.flink.examples.java.distcp
A Java POJO that represents a task for copying a single file
FileCopyTask(Path, String) - Constructor for class org.apache.flink.examples.java.distcp.FileCopyTask
 
FileCopyTaskInputFormat - Class in org.apache.flink.examples.java.distcp
An implementation of an input format that dynamically assigns FileCopyTask to the mappers that have finished previously assigned tasks
FileCopyTaskInputFormat(List<FileCopyTask>) - Constructor for class org.apache.flink.examples.java.distcp.FileCopyTaskInputFormat
 
FileCopyTaskInputSplit - Class in org.apache.flink.examples.java.distcp
Implementation of InputSplit for copying files
FileCopyTaskInputSplit(FileCopyTask, int) - Constructor for class org.apache.flink.examples.java.distcp.FileCopyTaskInputSplit
 
FileInputFormat<OT> - Class in org.apache.flink.api.common.io
The base class for RichInputFormats that read from files.
FileInputFormat() - Constructor for class org.apache.flink.api.common.io.FileInputFormat
 
FileInputFormat(Path) - Constructor for class org.apache.flink.api.common.io.FileInputFormat
 
FileInputFormat.FileBaseStatistics - Class in org.apache.flink.api.common.io
Encapsulation of the basic statistics the optimizer obtains about a file.
FileInputFormat.InputSplitOpenThread - Class in org.apache.flink.api.common.io
Obtains a DataInputStream in an thread that is not interrupted.
FileInputSplit - Class in org.apache.flink.core.fs
A file input split provides information on a particular part of a file, possibly hosted on a distributed file system and replicated among several hosts.
FileInputSplit(int, Path, long, long, String[]) - Constructor for class org.apache.flink.core.fs.FileInputSplit
Constructs a split with host information.
FileIOChannel - Interface in org.apache.flink.runtime.io.disk.iomanager
A Channel represents a collection of files that belong logically to the same resource.
FileIOChannel.Enumerator - Class in org.apache.flink.runtime.io.disk.iomanager
An enumerator for channels that logically belong together.
FileIOChannel.ID - Class in org.apache.flink.runtime.io.disk.iomanager
An ID identifying an underlying file channel.
fileModTime - Variable in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
 
FileMonitoringFunction - Class in org.apache.flink.streaming.api.functions.source
Deprecated.
Internal class deprecated in favour of ContinuousFileMonitoringFunction.
FileMonitoringFunction(String, long, FileMonitoringFunction.WatchType) - Constructor for class org.apache.flink.streaming.api.functions.source.FileMonitoringFunction
Deprecated.
 
FileMonitoringFunction.WatchType - Enum in org.apache.flink.streaming.api.functions.source
Deprecated.
The watch type of the FileMonitoringFunction.
FileOutputFormat<IT> - Class in org.apache.flink.api.common.io
The abstract base class for all Rich output formats that are file based.
FileOutputFormat() - Constructor for class org.apache.flink.api.common.io.FileOutputFormat
 
FileOutputFormat(Path) - Constructor for class org.apache.flink.api.common.io.FileOutputFormat
 
FileOutputFormat.OutputDirectoryMode - Enum in org.apache.flink.api.common.io
Behavior for creating output directories.
filePath - Variable in class org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
 
filePath - Variable in class org.apache.flink.api.common.io.FileInputFormat
The path to the file that contains the input.
FilePathFilter - Class in org.apache.flink.api.common.io
The FilePathFilter.filterPath(Path) method is responsible for deciding if a path is eligible for further processing or not.
FilePathFilter() - Constructor for class org.apache.flink.api.common.io.FilePathFilter
 
FilePathFilter.DefaultFilter - Class in org.apache.flink.api.common.io
The default file path filtering method and is used if no other such function is provided.
FileProcessingMode - Enum in org.apache.flink.streaming.api.functions.source
The mode in which the ContinuousFileMonitoringFunction operates.
FileReadFunction - Class in org.apache.flink.streaming.api.functions.source
Deprecated.
Internal class deprecated in favour of ContinuousFileMonitoringFunction.
FileReadFunction() - Constructor for class org.apache.flink.streaming.api.functions.source.FileReadFunction
Deprecated.
 
FILES_COPIED_CNT_NAME - Static variable in class org.apache.flink.examples.java.distcp.DistCp
 
FileSegment - Class in org.apache.flink.runtime.io.disk.iomanager
 
FileSegment(FileChannel, long, int, boolean) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.FileSegment
 
FileSerializableStateHandle<T extends Serializable> - Class in org.apache.flink.migration.runtime.state.filesystem
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
FileSerializableStateHandle(Path) - Constructor for class org.apache.flink.migration.runtime.state.filesystem.FileSerializableStateHandle
Deprecated.
Creates a new FileSerializableStateHandle pointing to state at the given file path.
fileSize - Variable in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
 
FileSpout - Class in org.apache.flink.storm.util
Implements a Spout that reads data from a given local file.
FileSpout() - Constructor for class org.apache.flink.storm.util.FileSpout
 
FileSpout(String) - Constructor for class org.apache.flink.storm.util.FileSpout
 
FileStateHandle - Class in org.apache.flink.runtime.state.filesystem
StreamStateHandle for state that was written to a file stream.
FileStateHandle(Path, long) - Constructor for class org.apache.flink.runtime.state.filesystem.FileStateHandle
Creates a new file state for the given file path.
FileStatus - Interface in org.apache.flink.core.fs
Interface that represents the client side information for a file independent of the file system.
FileStreamStateHandle - Class in org.apache.flink.migration.runtime.state.filesystem
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
FileStreamStateHandle(Path) - Constructor for class org.apache.flink.migration.runtime.state.filesystem.FileStreamStateHandle
Deprecated.
Creates a new FileStreamStateHandle pointing to state at the given file path.
FileSystem - Class in org.apache.flink.core.fs
Abstract base class of all file systems used by Flink.
FileSystem() - Constructor for class org.apache.flink.core.fs.FileSystem
 
FileSystem.WriteMode - Enum in org.apache.flink.core.fs
The possible write modes.
FILESYSTEM_DEFAULT_OVERWRITE_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Key to specify whether the file systems should simply overwrite existing files.
FILESYSTEM_OUTPUT_ALWAYS_CREATE_DIRECTORY_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Key to specify whether the file systems should always create a directory for the output, even with a parallelism of one.
FILESYSTEM_SCHEME - Static variable in class org.apache.flink.configuration.ConfigConstants
Key to specify the default filesystem to be used by a job.
FileSystemBlobStore - Class in org.apache.flink.runtime.blob
Blob store backed by FileSystem.
FileSystemBlobStore(FileSystem, String) - Constructor for class org.apache.flink.runtime.blob.FileSystemBlobStore
 
FileSystemKind - Enum in org.apache.flink.core.fs
An enumeration defining the kind and characteristics of a FileSystem.
FileSystemSafetyNet - Class in org.apache.flink.core.fs
The FileSystemSafetyNet can be used to guard a thread against FileSystem stream resource leaks.
FileSystemSafetyNet() - Constructor for class org.apache.flink.core.fs.FileSystemSafetyNet
 
FileSystemStateStorageHelper<T extends Serializable> - Class in org.apache.flink.runtime.zookeeper.filesystem
RetrievableStateStorageHelper implementation which stores the state in the given filesystem path.
FileSystemStateStorageHelper(String, String) - Constructor for class org.apache.flink.runtime.zookeeper.filesystem.FileSystemStateStorageHelper
 
FileSystemStateStorageHelper(Path, String) - Constructor for class org.apache.flink.runtime.zookeeper.filesystem.FileSystemStateStorageHelper
 
FileUtils - Class in org.apache.flink.util
This is a utility class to deal files and directories.
fillInStackTrace() - Static method in exception org.apache.flink.table.api.AmbiguousTableSourceConverterException
 
fillInStackTrace() - Static method in exception org.apache.flink.table.api.CatalogAlreadyExistException
 
fillInStackTrace() - Static method in exception org.apache.flink.table.api.CatalogNotExistException
 
fillInStackTrace() - Static method in exception org.apache.flink.table.api.ExpressionParserException
 
fillInStackTrace() - Static method in exception org.apache.flink.table.api.ExternalCatalogAlreadyExistException
 
fillInStackTrace() - Static method in exception org.apache.flink.table.api.ExternalCatalogNotExistException
 
fillInStackTrace() - Static method in exception org.apache.flink.table.api.NoMatchedTableSourceConverterException
 
fillInStackTrace() - Static method in exception org.apache.flink.table.api.SqlParserException
 
fillInStackTrace() - Static method in exception org.apache.flink.table.api.TableAlreadyExistException
 
fillInStackTrace() - Static method in exception org.apache.flink.table.api.TableException
 
fillInStackTrace() - Static method in exception org.apache.flink.table.api.TableNotExistException
 
fillInStackTrace() - Static method in exception org.apache.flink.table.api.UnresolvedException
 
fillInStackTrace() - Static method in exception org.apache.flink.table.api.ValidationException
 
fillInType(TypeInformation<T>) - Method in class org.apache.flink.api.java.DataSet
Tries to fill in the type information.
fillRecord(OUT, Object[]) - Method in class org.apache.flink.api.java.io.CsvInputFormat
 
fillRecord(OUT, Object[]) - Method in class org.apache.flink.api.java.io.PojoCsvInputFormat
 
fillRecord(Row, Object[]) - Method in class org.apache.flink.api.java.io.RowCsvInputFormat
 
fillRecord(OUT, Object[]) - Method in class org.apache.flink.api.java.io.TupleCsvInputFormat
 
FILTER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
FILTER operator filters which rows are included in an aggregate function.
filter(T) - Method in interface org.apache.flink.api.common.functions.FilterFunction
The filter function that evaluates the predicate.
filter(T) - Method in class org.apache.flink.api.common.functions.RichFilterFunction
 
filter(FilterFunction<T>) - Method in class org.apache.flink.api.java.DataSet
Applies a Filter transformation on a DataSet.
The transformation calls a RichFilterFunction for each element of the DataSet and retains only those element for which the function returns true.
filter(FilterFunction<T>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
filter(Function1<T, Object>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
filter(FilterFunction<T>) - Method in class org.apache.flink.api.scala.DataSet
Creates a new DataSet that contains only the elements satisfying the given filter predicate.
filter(Function1<T, Object>) - Method in class org.apache.flink.api.scala.DataSet
Creates a new DataSet that contains only the elements satisfying the given filter predicate.
filter(T) - Method in class org.apache.flink.cep.pattern.AndFilterFunction
Deprecated.
 
filter(T, IterativeCondition.Context<T>) - Method in class org.apache.flink.cep.pattern.conditions.AndCondition
 
filter(T, IterativeCondition.Context<T>) - Method in class org.apache.flink.cep.pattern.conditions.IterativeCondition
The filter function that evaluates the predicate.
filter(T, IterativeCondition.Context<T>) - Method in class org.apache.flink.cep.pattern.conditions.NotCondition
 
filter(T, IterativeCondition.Context<T>) - Method in class org.apache.flink.cep.pattern.conditions.OrCondition
 
filter(T, IterativeCondition.Context<T>) - Method in class org.apache.flink.cep.pattern.conditions.SimpleCondition
 
filter(T) - Method in class org.apache.flink.cep.pattern.conditions.SubtypeCondition
 
filter(T) - Method in class org.apache.flink.cep.pattern.OrFilterFunction
Deprecated.
 
filter(T) - Method in class org.apache.flink.cep.pattern.SubtypeFilterFunction
Deprecated.
 
filter(Tuple2<Tuple2<Long, Double>, Tuple2<Long, Double>>) - Method in class org.apache.flink.examples.java.graph.PageRank.EpsilonFilter
 
filter(EmptyFieldsCountAccumulator.StringTriple) - Method in class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator.EmptyFieldFilter
 
filter(Tuple3<Integer, String, Integer>) - Method in class org.apache.flink.examples.java.relational.WebLogAnalysis.FilterByRank
Filters for records of the rank relation where the rank is greater than the given threshold.
filter(Tuple2<String, String>) - Method in class org.apache.flink.examples.java.relational.WebLogAnalysis.FilterDocByKeyWords
Filters for documents that contain all of the given keywords and projects the records on the URL field.
filter(Tuple2<String, String>) - Method in class org.apache.flink.examples.java.relational.WebLogAnalysis.FilterVisitsByDate
Filters for records of the visits relation where the year of visit is equal to a specified value.
filter(Tuple2<String, String>) - Method in class org.apache.flink.graph.examples.MusicProfiles.FilterSongNodes
 
filter(FilterFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Applies a Filter transformation on a DataStream.
filter(FilterFunction<T>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Creates a new DataStream that contains only the elements satisfying the given filter predicate.
filter(Function1<T, Object>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Creates a new DataStream that contains only the elements satisfying the given filter predicate.
filter(Expression) - Method in class org.apache.flink.table.api.Table
Filters out elements that don't pass the filter predicate.
filter(String) - Method in class org.apache.flink.table.api.Table
Filters out elements that don't pass the filter predicate.
filter(RexNode[]) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
filter(Iterable<? extends RexNode>) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
Filter - Class in org.apache.flink.table.plan.logical
 
Filter(Expression, LogicalNode) - Constructor for class org.apache.flink.table.plan.logical.Filter
 
filter(T) - Method in class org.apache.flink.table.runtime.LimitFilterFunction
 
Filter$ - Class in org.apache.flink.table.plan.logical
 
Filter$() - Constructor for class org.apache.flink.table.plan.logical.Filter$
 
FilterableTableSource<T> - Interface in org.apache.flink.table.sources
Adds support for filtering push-down to a TableSource.
filterByCodeAnnotations(OptimizerNode, int) - Method in class org.apache.flink.optimizer.dataproperties.InterestingProperties
 
FilterByRank() - Constructor for class org.apache.flink.examples.java.relational.WebLogAnalysis.FilterByRank
 
filterBySemanticProperties(SemanticProperties, int) - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
Filters these GlobalProperties by the fields that are forwarded to the output as described by the SemanticProperties.
filterBySemanticProperties(SemanticProperties, int) - Method in class org.apache.flink.optimizer.dataproperties.LocalProperties
Filters these LocalProperties by the fields that are forwarded to the output as described by the SemanticProperties.
filterBySemanticProperties(SemanticProperties, int) - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
Filters these properties by what can be preserved by the given SemanticProperties when propagated down to the given input.
filterBySemanticProperties(SemanticProperties, int) - Method in class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
Filters these properties by what can be preserved by the given SemanticProperties when propagated down to the given input.
filterCharacters(String) - Method in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
 
filterCharacters(String) - Method in interface org.apache.flink.metrics.CharacterFilter
Filter the given string and generate a resulting string from it.
filterCharacters(String) - Method in class org.apache.flink.metrics.statsd.StatsDReporter
 
FilterDescriptor - Class in org.apache.flink.optimizer.operators
 
FilterDescriptor() - Constructor for class org.apache.flink.optimizer.operators.FilterDescriptor
 
FilterDocByKeyWords() - Constructor for class org.apache.flink.examples.java.relational.WebLogAnalysis.FilterDocByKeyWords
 
FilterFunction<T> - Interface in org.apache.flink.api.common.functions
A filter function is a predicate applied individually to each record.
FilterNode - Class in org.apache.flink.optimizer.dag
The optimizer's internal representation of a Filter operator node.
FilterNode(FilterOperatorBase<?, ?>) - Constructor for class org.apache.flink.optimizer.dag.FilterNode
 
filterOnEdges(FilterFunction<Edge<K, EV>>) - Method in class org.apache.flink.graph.Graph
Apply a filtering function to the graph and return a sub-graph that satisfies the predicates only for the edges.
filterOnEdges(FilterFunction<Edge<K, EV>>) - Method in class org.apache.flink.graph.scala.Graph
Apply a filtering function to the graph and return a sub-graph that satisfies the predicates only for the edges.
filterOnEdges(Function1<Edge<K, EV>, Object>) - Method in class org.apache.flink.graph.scala.Graph
Apply a filtering function to the graph and return a sub-graph that satisfies the predicates only for the edges.
filterOnVertices(FilterFunction<Vertex<K, VV>>) - Method in class org.apache.flink.graph.Graph
Apply a filtering function to the graph and return a sub-graph that satisfies the predicates only for the vertices.
filterOnVertices(FilterFunction<Vertex<K, VV>>) - Method in class org.apache.flink.graph.scala.Graph
Apply a filtering function to the graph and return a sub-graph that satisfies the predicates only for the vertices.
filterOnVertices(Function1<Vertex<K, VV>, Object>) - Method in class org.apache.flink.graph.scala.Graph
Apply a filtering function to the graph and return a sub-graph that satisfies the predicates only for the vertices.
FilterOperator<T> - Class in org.apache.flink.api.java.operators
This operator represents the application of a "filter" function on a data set, and the result data set produced by the function.
FilterOperator(DataSet<T>, FilterFunction<T>, String) - Constructor for class org.apache.flink.api.java.operators.FilterOperator
 
FilterOperatorBase<T,FT extends FlatMapFunction<T,T>> - Class in org.apache.flink.api.common.operators.base
 
FilterOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<T, T>, String) - Constructor for class org.apache.flink.api.common.operators.base.FilterOperatorBase
 
FilterOperatorBase(FT, UnaryOperatorInformation<T, T>, String) - Constructor for class org.apache.flink.api.common.operators.base.FilterOperatorBase
 
FilterOperatorBase(Class<? extends FT>, UnaryOperatorInformation<T, T>, String) - Constructor for class org.apache.flink.api.common.operators.base.FilterOperatorBase
 
FilterOutMismatches() - Constructor for class org.apache.flink.graph.examples.MusicProfiles.FilterOutMismatches
 
filterPath(Path) - Method in class org.apache.flink.api.common.io.FilePathFilter.DefaultFilter
 
filterPath(Path) - Method in class org.apache.flink.api.common.io.FilePathFilter
Returns true if the filePath given is to be ignored when processing a directory, e.g.
filterPath(Path) - Method in class org.apache.flink.api.common.io.GlobFilePathFilter
 
filters() - Method in class org.apache.flink.mesos.scheduler.messages.AcceptOffers
 
FilterSongNodes() - Constructor for class org.apache.flink.graph.examples.MusicProfiles.FilterSongNodes
 
FilterVisitsByDate() - Constructor for class org.apache.flink.examples.java.relational.WebLogAnalysis.FilterVisitsByDate
 
filterWith(Function1<T, Object>) - Method in class org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions.OnDataSet
Applies a predicate fun to each item of the data set, keeping only those for which the predicate holds
filterWith(Function1<T, Object>) - Method in class org.apache.flink.streaming.api.scala.extensions.impl.acceptPartialFunctions.OnDataStream
Applies a predicate fun to each item of the stream, keeping only those for which the predicate holds
filterWithState(Function2<T, Option<S>, Tuple2<Object, Option<S>>>, TypeInformation<S>) - Method in class org.apache.flink.streaming.api.scala.KeyedStream
Creates a new DataStream that contains only the elements satisfying the given stateful filter predicate.
FINAL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
FINAL function to be used within MATCH_RECOGNIZE.
finalize() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
The finalize method shuts down the timer.
finalize() - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
 
finalizeBuildPhase(IOManager, FileIOChannel.Enumerator, LinkedBlockingQueue<MemorySegment>) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
 
finalizeCheckpointExternalized() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
finalizeCheckpointNonExternalized() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
finalizeCluster() - Method in class org.apache.flink.client.program.ClusterClient
Request the cluster to shut down or disconnect.
finalizeCluster() - Method in class org.apache.flink.client.program.StandaloneClusterClient
 
finalizeCluster() - Method in class org.apache.flink.yarn.YarnClusterClient
Shuts down or disconnects from the YARN cluster.
finalizeCluster() - Method in class org.apache.flink.yarn.YarnClusterClientV2
 
finalizeGlobal(int) - Method in interface org.apache.flink.api.common.io.FinalizeOnMaster
The method is invoked on the master (JobManager) after all (parallel) instances of an OutputFormat finished.
finalizeGlobal(int) - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
 
finalizeGlobal(int) - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
 
FinalizeOnMaster - Interface in org.apache.flink.api.common.io
This interface may be implemented by OutputFormats to have the master finalize them globally.
finalizeOnMaster(ClassLoader) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
A hook that can be overwritten by sub classes to implement logic that is called by the master after the job completed.
finalizeOnMaster(ClassLoader) - Method in class org.apache.flink.runtime.jobgraph.OutputFormatVertex
 
finalizeProbePhase(List<MemorySegment>, List<HashPartition<BT, PT>>, boolean) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
 
finalizeProbePhase(List<MemorySegment>, List<HashPartition<BT, PT>>, boolean) - Method in class org.apache.flink.runtime.operators.hash.ReOpenableHashPartition
 
FinalSemiAsyncSnapshot() - Constructor for class org.apache.flink.migration.contrib.streaming.state.RocksDBStateBackend.FinalSemiAsyncSnapshot
Deprecated.
 
finalStatus() - Method in class org.apache.flink.runtime.clusterframework.messages.StopCluster
 
find(Configuration) - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorUtils.LogFileLocation
Finds the Flink log directory using log.file Java property that is set during startup.
find(CharSequence) - Method in class org.apache.flink.types.StringValue
Finds any occurrence of the str character sequence in this StringValue.
find(CharSequence, int) - Method in class org.apache.flink.types.StringValue
Finds any occurrence of the str character sequence in this StringValue.
findConnectingAddress(InetSocketAddress, long, long) - Static method in class org.apache.flink.runtime.net.ConnectionUtils
Finds the local network address from which this machine can connect to the target address.
findConnectingAddress(FiniteDuration) - Method in class org.apache.flink.runtime.net.ConnectionUtils.LeaderConnectingAddressListener
 
findConnectingAddress(FiniteDuration, FiniteDuration) - Method in class org.apache.flink.runtime.net.ConnectionUtils.LeaderConnectingAddressListener
 
findConnectingAddress(LeaderRetrievalService, Time) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
 
findConnectingAddress(LeaderRetrievalService, FiniteDuration) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
 
findMatchingRequest(ResourceProfile) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Finds a matching slot request for a given resource profile.
findMatchingSlot(ResourceProfile) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Finds a matching slot for a given resource profile.
findMethodNode(String, Method) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
 
findMethodNode(String, String, String) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
 
findVertexByID(JobVertexID) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Searches for a vertex with a matching ID and returns it.
finish() - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat.JDBCInputFormatBuilder
 
finish() - Method in class org.apache.flink.api.java.io.jdbc.JDBCOutputFormat.JDBCOutputFormatBuilder
Finalizes the configuration and checks validity.
finish(Keys<L>, Keys<R>) - Method in class org.apache.flink.api.scala.UnfinishedCoGroupOperation
 
finish(Keys<L>, Keys<R>) - Method in class org.apache.flink.api.scala.UnfinishedJoinOperationBase
 
finish(Keys<L>, Keys<R>) - Method in class org.apache.flink.api.scala.UnfinishedKeyPairOperation
 
finish() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
Finishes the result partition.
finish() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
finishPlanMode() - Method in class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
 
finishWriteAndSortKeys(List<MemorySegment>) - Method in class org.apache.flink.runtime.operators.sort.LargeRecordHandler
 
FiniteFileSpout - Class in org.apache.flink.storm.util
Implements a Spout that reads data from a given local file.
FiniteFileSpout() - Constructor for class org.apache.flink.storm.util.FiniteFileSpout
 
FiniteFileSpout(String) - Constructor for class org.apache.flink.storm.util.FiniteFileSpout
 
FiniteInMemorySpout - Class in org.apache.flink.storm.util
Implements a Spout that reads String[] data stored in memory.
FiniteInMemorySpout(String[]) - Constructor for class org.apache.flink.storm.util.FiniteInMemorySpout
 
FiniteNewDataSource() - Constructor for class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.FiniteNewDataSource
 
FiniteSpout - Interface in org.apache.flink.storm.util
This interface represents a spout that emits a finite number of records.
FiniteTrainingDataSource() - Constructor for class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.FiniteTrainingDataSource
 
FIRST - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
FIRST function to be used within MATCH_RECOGNIZE.
first(int) - Method in class org.apache.flink.api.java.DataSet
Returns a new set containing the first n elements in this DataSet.
first(int) - Method in class org.apache.flink.api.java.operators.SortedGrouping
Returns a new set containing the first n elements in this grouped and sorted DataSet.
first(int) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Returns a new set containing the first n elements in this grouped DataSet.
first(int) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
first(int) - Method in class org.apache.flink.api.scala.DataSet
Creates a new DataSet containing the first n elements of this DataSet.
first(int) - Method in class org.apache.flink.api.scala.GroupedDataSet
Creates a new DataSet containing the first n elements of each group of this DataSet.
FIRST_VALUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
FIRST_VALUE aggregate function.
firstBoltId - Static variable in class org.apache.flink.storm.exclamation.ExclamationTopology
 
firstDam() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
 
FirstFieldKeyExtractor() - Constructor for class org.apache.flink.streaming.examples.windowing.GroupedProcessingTimeWindowExample.FirstFieldKeyExtractor
 
firstOrSuppressed(T, T) - Static method in class org.apache.flink.util.ExceptionUtils
Adds a new exception as a suppressed exception to a prior exception, or returns the new exception, if no prior exception exists.
FirstReducer<T> - Class in org.apache.flink.api.java.functions
 
FirstReducer(int) - Constructor for class org.apache.flink.api.java.functions.FirstReducer
 
fit(DataSet<Training>, ParameterMap, FitOperation<Self, Training>) - Static method in class org.apache.flink.ml.classification.SVM
 
fit(DataSet<Training>, ParameterMap, FitOperation<Self, Training>) - Static method in class org.apache.flink.ml.nn.KNN
 
fit(DataSet<Training>, ParameterMap, FitOperation<Self, Training>) - Static method in class org.apache.flink.ml.outlier.StochasticOutlierSelection
 
fit(DataSet<Training>, ParameterMap, FitOperation<Self, Training>) - Static method in class org.apache.flink.ml.pipeline.ChainedPredictor
 
fit(DataSet<Training>, ParameterMap, FitOperation<Self, Training>) - Static method in class org.apache.flink.ml.pipeline.ChainedTransformer
 
fit(DataSet<Training>, ParameterMap, FitOperation<Self, Training>) - Method in interface org.apache.flink.ml.pipeline.Estimator
Fits the estimator to the given input data.
fit(Self, ParameterMap, DataSet<Training>) - Method in interface org.apache.flink.ml.pipeline.FitOperation
 
fit(DataSet<Training>, ParameterMap, FitOperation<Self, Training>) - Static method in class org.apache.flink.ml.preprocessing.MinMaxScaler
 
fit(DataSet<Training>, ParameterMap, FitOperation<Self, Training>) - Static method in class org.apache.flink.ml.preprocessing.PolynomialFeatures
 
fit(DataSet<Training>, ParameterMap, FitOperation<Self, Training>) - Static method in class org.apache.flink.ml.preprocessing.StandardScaler
 
fit(DataSet<Training>, ParameterMap, FitOperation<Self, Training>) - Static method in class org.apache.flink.ml.recommendation.ALS
 
fit(DataSet<Training>, ParameterMap, FitOperation<Self, Training>) - Static method in class org.apache.flink.ml.regression.MultipleLinearRegression
 
fit$default$2() - Static method in class org.apache.flink.ml.classification.SVM
 
fit$default$2() - Static method in class org.apache.flink.ml.nn.KNN
 
fit$default$2() - Static method in class org.apache.flink.ml.outlier.StochasticOutlierSelection
 
fit$default$2() - Static method in class org.apache.flink.ml.pipeline.ChainedPredictor
 
fit$default$2() - Static method in class org.apache.flink.ml.pipeline.ChainedTransformer
 
fit$default$2() - Static method in class org.apache.flink.ml.preprocessing.MinMaxScaler
 
fit$default$2() - Static method in class org.apache.flink.ml.preprocessing.PolynomialFeatures
 
fit$default$2() - Static method in class org.apache.flink.ml.preprocessing.StandardScaler
 
fit$default$2() - Static method in class org.apache.flink.ml.recommendation.ALS
 
fit$default$2() - Static method in class org.apache.flink.ml.regression.MultipleLinearRegression
 
fitALS() - Method in class org.apache.flink.ml.recommendation.ALS$
Calculates the matrix factorization for the given ratings.
fitALS() - Static method in class org.apache.flink.ml.recommendation.ALS
Calculates the matrix factorization for the given ratings.
fitALSInt() - Method in class org.apache.flink.ml.recommendation.ALS$
 
fitALSInt() - Static method in class org.apache.flink.ml.recommendation.ALS
 
fitKNN(TypeInformation<T>) - Method in class org.apache.flink.ml.nn.KNN$
FitOperation which trains a KNN based on the given training data set.
fitKNN(TypeInformation<T>) - Static method in class org.apache.flink.ml.nn.KNN
FitOperation which trains a KNN based on the given training data set.
fitLabeledVectorMinMaxScaler() - Method in class org.apache.flink.ml.preprocessing.MinMaxScaler$
Trains the MinMaxScaler by learning the minimum and maximum of the features of the training data which is of type LabeledVector.
fitLabeledVectorMinMaxScaler() - Static method in class org.apache.flink.ml.preprocessing.MinMaxScaler
Trains the MinMaxScaler by learning the minimum and maximum of the features of the training data which is of type LabeledVector.
fitLabeledVectorStandardScaler() - Method in class org.apache.flink.ml.preprocessing.StandardScaler$
Trains the StandardScaler by learning the mean and standard deviation of the training data which is of type LabeledVector.
fitLabeledVectorStandardScaler() - Static method in class org.apache.flink.ml.preprocessing.StandardScaler
Trains the StandardScaler by learning the mean and standard deviation of the training data which is of type LabeledVector.
fitLabelVectorTupleStandardScaler(BreezeVectorConverter<T>, TypeInformation<T>, ClassTag<T>) - Method in class org.apache.flink.ml.preprocessing.StandardScaler$
Trains the StandardScaler by learning the mean and standard deviation of the training data which is of type (Vector, Double).
fitLabelVectorTupleStandardScaler(BreezeVectorConverter<T>, TypeInformation<T>, ClassTag<T>) - Static method in class org.apache.flink.ml.preprocessing.StandardScaler
Trains the StandardScaler by learning the mean and standard deviation of the training data which is of type (Vector, Double).
fitMLR() - Method in class org.apache.flink.ml.regression.MultipleLinearRegression$
Trains the linear model to fit the training data.
fitMLR() - Static method in class org.apache.flink.ml.regression.MultipleLinearRegression
Trains the linear model to fit the training data.
fitNoOp() - Method in class org.apache.flink.ml.preprocessing.PolynomialFeatures$
The PolynomialFeatures transformer does not need a fitting phase.
fitNoOp() - Static method in class org.apache.flink.ml.preprocessing.PolynomialFeatures
The PolynomialFeatures transformer does not need a fitting phase.
FitOperation<Self,Training> - Interface in org.apache.flink.ml.pipeline
Type class for the fit operation of an Estimator.
fitSVM() - Method in class org.apache.flink.ml.classification.SVM$
FitOperation which trains a SVM with soft-margin based on the given training data set.
fitSVM() - Static method in class org.apache.flink.ml.classification.SVM
FitOperation which trains a SVM with soft-margin based on the given training data set.
fitVectorMinMaxScaler() - Method in class org.apache.flink.ml.preprocessing.MinMaxScaler$
Trains the MinMaxScaler by learning the minimum and maximum of each feature of the training data.
fitVectorMinMaxScaler() - Static method in class org.apache.flink.ml.preprocessing.MinMaxScaler
Trains the MinMaxScaler by learning the minimum and maximum of each feature of the training data.
fitVectorStandardScaler() - Method in class org.apache.flink.ml.preprocessing.StandardScaler$
Trains the StandardScaler by learning the mean and standard deviation of the training data.
fitVectorStandardScaler() - Static method in class org.apache.flink.ml.preprocessing.StandardScaler
Trains the StandardScaler by learning the mean and standard deviation of the training data.
fixedDelayRestart(int, long) - Static method in class org.apache.flink.api.common.restartstrategy.RestartStrategies
Generates a FixedDelayRestartStrategyConfiguration.
fixedDelayRestart(int, Time) - Static method in class org.apache.flink.api.common.restartstrategy.RestartStrategies
Generates a FixedDelayRestartStrategyConfiguration.
FixedDelayRestartStrategy - Class in org.apache.flink.runtime.executiongraph.restart
Restart strategy which tries to restart the given ExecutionGraph a fixed number of times with a fixed time delay in between.
FixedDelayRestartStrategy(int, long) - Constructor for class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
 
FixedDelayRestartStrategy.FixedDelayRestartStrategyFactory - Class in org.apache.flink.runtime.executiongraph.restart
 
FixedDelayRestartStrategyFactory(int, long) - Constructor for class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy.FixedDelayRestartStrategyFactory
 
FixedLengthRecordSorter<T> - Class in org.apache.flink.runtime.operators.sort
 
FixedLengthRecordSorter(TypeSerializer<T>, TypeComparator<T>, List<MemorySegment>) - Constructor for class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
FLAG_LAST_BLOCK - Static variable in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
The flag marking a block as the last block.
FlatFieldDescriptor(int, TypeInformation<?>) - Constructor for class org.apache.flink.api.common.typeutils.CompositeType.FlatFieldDescriptor
 
FlatJoinFunction<IN1,IN2,OUT> - Interface in org.apache.flink.api.common.functions
Interface for Join functions.
FlatJoinRunner<IN1,IN2,OUT> - Class in org.apache.flink.table.runtime
 
FlatJoinRunner(String, String, TypeInformation<OUT>) - Constructor for class org.apache.flink.table.runtime.FlatJoinRunner
 
flatMap(T, Collector<O>) - Method in interface org.apache.flink.api.common.functions.FlatMapFunction
The core method of the FlatMapFunction.
flatMap(IN, Collector<OUT>) - Method in class org.apache.flink.api.common.functions.RichFlatMapFunction
 
flatMap(X, Collector<X>) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionMapper
 
flatMap(FlatMapFunction<T, R>) - Method in class org.apache.flink.api.java.DataSet
Applies a FlatMap transformation on a DataSet.
The transformation calls a RichFlatMapFunction for each element of the DataSet.
flatMap(IN) - Method in class org.apache.flink.api.java.functions.FlatMapIterator
The core method of the function.
flatMap(IN, Collector<OUT>) - Method in class org.apache.flink.api.java.functions.FlatMapIterator
Delegates calls to the FlatMapIterator.flatMap(Object) method.
flatMap(T, Collector<T>) - Method in class org.apache.flink.api.java.operators.translation.PlanFilterOperator.FlatMapFilter
 
flatMap(FlatMapFunction<T, R>, TypeInformation<R>, ClassTag<R>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
flatMap(Function2<T, Collector<R>, BoxedUnit>, TypeInformation<R>, ClassTag<R>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
flatMap(Function1<T, TraversableOnce<R>>, TypeInformation<R>, ClassTag<R>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
flatMap(FlatMapFunction<T, R>, TypeInformation<R>, ClassTag<R>) - Method in class org.apache.flink.api.scala.DataSet
Creates a new DataSet by applying the given function to every element and flattening the results.
flatMap(Function2<T, Collector<R>, BoxedUnit>, TypeInformation<R>, ClassTag<R>) - Method in class org.apache.flink.api.scala.DataSet
Creates a new DataSet by applying the given function to every element and flattening the results.
flatMap(Function1<T, TraversableOnce<R>>, TypeInformation<R>, ClassTag<R>) - Method in class org.apache.flink.api.scala.DataSet
Creates a new DataSet by applying the given function to every element and flattening the results.
flatMap(Tuple2<Long, Long>, Collector<Tuple2<Long, Long>>) - Method in class org.apache.flink.examples.java.graph.ConnectedComponents.UndirectEdge
 
flatMap(Tuple2<Tuple2<Long, Double>, Tuple2<Long, Long[]>>, Collector<Tuple2<Long, Double>>) - Method in class org.apache.flink.examples.java.graph.PageRank.JoinVertexWithEdgesMatch
 
flatMap(String, Collector<Tuple2<String, Integer>>) - Method in class org.apache.flink.examples.java.wordcount.WordCount.Tokenizer
 
flatMap(String, Collector<WordCountPojo.Word>) - Method in class org.apache.flink.examples.java.wordcount.WordCountPojo.Tokenizer
 
flatMap(Tuple2<KEYIN, VALUEIN>, Collector<Tuple2<KEYOUT, VALUEOUT>>) - Method in class org.apache.flink.hadoopcompatibility.mapred.HadoopMapFunction
 
flatMap(String, Collector<Tuple2<String, Integer>>) - Method in class org.apache.flink.storm.wordcount.SpoutSourceWordCount.Tokenizer
 
flatMap(CoFlatMapFunction<IN1, IN2, R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
Applies a CoFlatMap transformation on a ConnectedStreams and maps the output to a common type.
flatMap(FlatMapFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Applies a FlatMap transformation on a DataStream.
flatMap(Tuple3<String, Long, Long>, Collector<String>) - Method in class org.apache.flink.streaming.api.functions.source.FileReadFunction
Deprecated.
 
flatMap(CoFlatMapFunction<IN1, IN2, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.ConnectedStreams
Applies a CoFlatMap transformation on these connected streams.
flatMap(Function2<IN1, Collector<R>, BoxedUnit>, Function2<IN2, Collector<R>, BoxedUnit>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.ConnectedStreams
Applies a CoFlatMap transformation on the connected streams.
flatMap(Function1<IN1, TraversableOnce<R>>, Function1<IN2, TraversableOnce<R>>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.ConnectedStreams
Applies a CoFlatMap transformation on the connected streams.
flatMap(FlatMapFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Creates a new DataStream by applying the given function to every element and flattening the results.
flatMap(Function2<T, Collector<R>, BoxedUnit>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Creates a new DataStream by applying the given function to every element and flattening the results.
flatMap(Function1<T, TraversableOnce<R>>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Creates a new DataStream by applying the given function to every element and flattening the results.
flatMap(String, Collector<Tuple2<String, Integer>>) - Method in class org.apache.flink.streaming.examples.twitter.TwitterExample.SelectEnglishAndTokenizeFlatMap
Select the language from the incoming JSON text
flatMap(String, Collector<PojoExample.Word>) - Method in class org.apache.flink.streaming.examples.wordcount.PojoExample.Tokenizer
 
flatMap(String, Collector<Tuple2<String, Integer>>) - Method in class org.apache.flink.streaming.examples.wordcount.WordCount.Tokenizer
 
flatMap(Row, Collector<Row>) - Method in class org.apache.flink.table.runtime.aggregate.DataSetSlideTimeWindowAggFlatMapFunction
 
flatMap(IN, Collector<OUT>) - Method in class org.apache.flink.table.runtime.CorrelateFlatMapRunner
 
flatMap(Row, Collector<Row>) - Method in class org.apache.flink.table.runtime.FlatMapRunner
 
flatMap(IN1, Collector<OUT>) - Method in class org.apache.flink.table.runtime.MapJoinLeftRunner
 
flatMap(IN2, Collector<OUT>) - Method in class org.apache.flink.table.runtime.MapJoinRightRunner
 
flatMap1(IN1, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.co.CoFlatMapFunction
This method is called for each element in the first of the connected streams.
flatMap2(IN2, Collector<OUT>) - Method in interface org.apache.flink.streaming.api.functions.co.CoFlatMapFunction
This method is called for each element in the second of the connected streams.
FlatMapDescriptor - Class in org.apache.flink.optimizer.operators
 
FlatMapDescriptor() - Constructor for class org.apache.flink.optimizer.operators.FlatMapDescriptor
 
FlatMapDriver<IT,OT> - Class in org.apache.flink.runtime.operators
Map task which is executed by a Task Manager.
FlatMapDriver() - Constructor for class org.apache.flink.runtime.operators.FlatMapDriver
 
FlatMapFunction<T,O> - Interface in org.apache.flink.api.common.functions
Base interface for flatMap functions.
FlatMapIterator<IN,OUT> - Class in org.apache.flink.api.java.functions
A convenience variant of the RichFlatMapFunction that returns elements through an iterator, rather then through a collector.
FlatMapIterator() - Constructor for class org.apache.flink.api.java.functions.FlatMapIterator
 
FlatMapNode - Class in org.apache.flink.optimizer.dag
The optimizer's internal representation of a FlatMap operator node.
FlatMapNode(FlatMapOperatorBase<?, ?, ?>) - Constructor for class org.apache.flink.optimizer.dag.FlatMapNode
 
FlatMapOperator<IN,OUT> - Class in org.apache.flink.api.java.operators
This operator represents the application of a "flatMap" function on a data set, and the result data set produced by the function.
FlatMapOperator(DataSet<IN>, TypeInformation<OUT>, FlatMapFunction<IN, OUT>, String) - Constructor for class org.apache.flink.api.java.operators.FlatMapOperator
 
FlatMapOperatorBase<IN,OUT,FT extends FlatMapFunction<IN,OUT>> - Class in org.apache.flink.api.common.operators.base
 
FlatMapOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.FlatMapOperatorBase
 
FlatMapOperatorBase(FT, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.FlatMapOperatorBase
 
FlatMapOperatorBase(Class<? extends FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.FlatMapOperatorBase
 
FlatMapRunner - Class in org.apache.flink.table.runtime
 
FlatMapRunner(String, String, TypeInformation<Row>) - Constructor for class org.apache.flink.table.runtime.FlatMapRunner
 
flatMapWith(Function1<T, TraversableOnce<R>>, TypeInformation<R>, ClassTag<R>) - Method in class org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions.OnDataSet
Applies a function fun to each item of the dataset, producing a collection of items that will be flattened in the resulting data set
flatMapWith(Function1<IN1, TraversableOnce<R>>, Function1<IN2, TraversableOnce<R>>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.extensions.impl.acceptPartialFunctions.OnConnectedStream
Applies a CoFlatMap transformation on the connected streams.
flatMapWith(Function1<T, TraversableOnce<R>>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.extensions.impl.acceptPartialFunctions.OnDataStream
Applies a function fun to each item of the stream, producing a collection of items that will be flattened in the resulting stream
flatMapWithState(Function2<T, Option<S>, Tuple2<TraversableOnce<R>, Option<S>>>, TypeInformation<R>, TypeInformation<S>) - Method in class org.apache.flink.streaming.api.scala.KeyedStream
Creates a new DataStream by applying the given stateful function to every element and flattening the results.
flatSelect(Map<String, List<IN>>, Collector<OUT>) - Method in interface org.apache.flink.cep.PatternFlatSelectFunction
Generates zero or more resulting elements given a map of detected pattern events.
flatSelect(PatternFlatSelectFunction<T, R>) - Method in class org.apache.flink.cep.PatternStream
Applies a flat select function to the detected pattern sequence.
flatSelect(PatternFlatSelectFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.cep.PatternStream
Applies a flat select function to the detected pattern sequence.
flatSelect(PatternFlatTimeoutFunction<T, L>, PatternFlatSelectFunction<T, R>) - Method in class org.apache.flink.cep.PatternStream
Applies a flat select function to the detected pattern sequence.
flatSelect(PatternFlatSelectFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.cep.scala.PatternStream
Applies a flat select function to the detected pattern sequence.
flatSelect(PatternFlatTimeoutFunction<T, L>, PatternFlatSelectFunction<T, R>, TypeInformation<L>, TypeInformation<R>) - Method in class org.apache.flink.cep.scala.PatternStream
Applies a flat select function to the detected pattern sequence.
flatSelect(Function2<Map<String, Iterable<T>>, Collector<R>, BoxedUnit>, TypeInformation<R>) - Method in class org.apache.flink.cep.scala.PatternStream
Applies a flat select function to the detected pattern sequence.
flatSelect(Function3<Map<String, Iterable<T>>, Object, Collector<L>, BoxedUnit>, Function2<Map<String, Iterable<T>>, Collector<R>, BoxedUnit>, TypeInformation<L>, TypeInformation<R>) - Method in class org.apache.flink.cep.scala.PatternStream
Applies a flat select function to the detected pattern sequence.
flatten(List<RelNode>, int, int[], List<Pair<RelNode, Integer>>) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
 
flatten() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Converts a Flink composite type (such as Tuple, POJO, etc.) and all of its direct subtypes into a flat representation where every subtype is a separate field.
FLATTEN() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
FLATTEN() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
Flattening - Class in org.apache.flink.table.expressions
Flattening of composite types.
Flattening(Expression) - Constructor for class org.apache.flink.table.expressions.Flattening
 
Flattening$ - Class in org.apache.flink.table.expressions
 
Flattening$() - Constructor for class org.apache.flink.table.expressions.Flattening$
 
flattenTypes(RelNode, boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
 
FLINK_BASE_DIR_PATH_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
This parameter should not be used any more. A running Flink cluster should make no assumption about its location.
FLINK_CONF_FILENAME - Static variable in class org.apache.flink.configuration.GlobalConfiguration
 
FLINK_JAR_PATH - Static variable in class org.apache.flink.yarn.YarnConfigKeys
 
FLINK_JM_JVM_OPTIONS - Static variable in class org.apache.flink.configuration.CoreOptions
 
FLINK_JVM_OPTIONS - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
FLINK_JVM_OPTIONS - Static variable in class org.apache.flink.configuration.CoreOptions
 
FLINK_PYTHON_DC_ID - Static variable in class org.apache.flink.python.api.PythonPlanBinder
 
FLINK_PYTHON_PLAN_NAME - Static variable in class org.apache.flink.python.api.PythonPlanBinder
 
FLINK_RECOVERY_DATA_DIR - Static variable in class org.apache.flink.yarn.highavailability.YarnHighAvailabilityServices
The name of the sub directory in which Flink stores the recovery data
FLINK_TM_JVM_OPTIONS - Static variable in class org.apache.flink.configuration.CoreOptions
 
FLINK_YARN_FILES - Static variable in class org.apache.flink.yarn.YarnConfigKeys
 
FlinkActor - Interface in org.apache.flink.runtime
Base trait for Flink's actors.
FlinkCalciteSqlValidator - Class in org.apache.flink.table.calcite
This is a copy of Calcite's CalciteSqlValidator to use with FlinkPlannerImpl.
FlinkCalciteSqlValidator(SqlOperatorTable, CalciteCatalogReader, JavaTypeFactory) - Constructor for class org.apache.flink.table.calcite.FlinkCalciteSqlValidator
 
FlinkClient - Class in org.apache.flink.storm.api
FlinkClient mimics a Storm NimbusClient and Nimbus.Client at once, to interact with Flink's JobManager instead of Storm's Nimbus.
FlinkClient(Map, String, int) - Constructor for class org.apache.flink.storm.api.FlinkClient
Instantiates a new FlinkClient for the given configuration, host name, and port.
FlinkClient(Map, String, int, Integer) - Constructor for class org.apache.flink.storm.api.FlinkClient
Instantiates a new FlinkClient for the given configuration, host name, and port.
flinkCollector - Variable in class org.apache.flink.storm.wrappers.BoltWrapper
We have to use this because Operators must output StreamRecord.
FlinkCompletableFuture<T> - Class in org.apache.flink.runtime.concurrent.impl
Implementation of CompletableFuture which is backed by Promise.
FlinkCompletableFuture() - Constructor for class org.apache.flink.runtime.concurrent.impl.FlinkCompletableFuture
 
flinkConfig - Variable in class org.apache.flink.client.program.ClusterClient
Configuration of the client
flinkConfig() - Method in class org.apache.flink.yarn.ApplicationClient
 
flinkConfiguration() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
FlinkConventions - Class in org.apache.flink.table.plan.nodes
 
FlinkConventions() - Constructor for class org.apache.flink.table.plan.nodes.FlinkConventions
 
FlinkConventions$ - Class in org.apache.flink.table.plan.nodes
 
FlinkConventions$() - Constructor for class org.apache.flink.table.plan.nodes.FlinkConventions$
 
FlinkCounterWrapper - Class in org.apache.flink.dropwizard.metrics
 
FlinkCounterWrapper(Counter) - Constructor for class org.apache.flink.dropwizard.metrics.FlinkCounterWrapper
 
FlinkDefaultRelMetadataProvider - Class in org.apache.flink.table.plan.cost
 
FlinkDefaultRelMetadataProvider() - Constructor for class org.apache.flink.table.plan.cost.FlinkDefaultRelMetadataProvider
 
FlinkDefaultRelMetadataProvider$ - Class in org.apache.flink.table.plan.cost
 
FlinkDefaultRelMetadataProvider$() - Constructor for class org.apache.flink.table.plan.cost.FlinkDefaultRelMetadataProvider$
 
FlinkDistributionOverlay - Class in org.apache.flink.runtime.clusterframework.overlays
Overlays Flink into a container, based on supplied bin/conf/lib directories.
FlinkDistributionOverlay(File, File, File) - Constructor for class org.apache.flink.runtime.clusterframework.overlays.FlinkDistributionOverlay
 
FlinkDistributionOverlay.Builder - Class in org.apache.flink.runtime.clusterframework.overlays
A builder for the FlinkDistributionOverlay.
FlinkException - Exception in org.apache.flink.util
Base class of all Flink-specific checked exceptions.
FlinkException(String) - Constructor for exception org.apache.flink.util.FlinkException
Creates a new Exception with the given message and null as the cause.
FlinkException(Throwable) - Constructor for exception org.apache.flink.util.FlinkException
Creates a new exception with a null message and the given cause.
FlinkException(String, Throwable) - Constructor for exception org.apache.flink.util.FlinkException
Creates a new exception with the given message and cause
flinkFileSystem - Variable in class org.apache.flink.yarn.highavailability.YarnHighAvailabilityServices
The Flink FileSystem object that represent the HDFS used by YARN
FlinkFixedPartitioner<T> - Class in org.apache.flink.streaming.connectors.kafka.partitioner
A partitioner ensuring that each internal Flink partition ends up in one Kafka partition.
FlinkFixedPartitioner() - Constructor for class org.apache.flink.streaming.connectors.kafka.partitioner.FlinkFixedPartitioner
 
FlinkFuture<T> - Class in org.apache.flink.runtime.concurrent.impl
Implementation of Future which is backed by Future.
FlinkFuture(Future<T>) - Constructor for class org.apache.flink.runtime.concurrent.impl.FlinkFuture
 
FlinkGaugeWrapper<T> - Class in org.apache.flink.dropwizard.metrics
 
FlinkGaugeWrapper(Gauge<T>) - Constructor for class org.apache.flink.dropwizard.metrics.FlinkGaugeWrapper
 
FlinkHistogramWrapper - Class in org.apache.flink.dropwizard.metrics
Wrapper to use a Flink Histogram as a Dropwizard Histogram.
FlinkHistogramWrapper(Histogram) - Constructor for class org.apache.flink.dropwizard.metrics.FlinkHistogramWrapper
 
FlinkILoop - Class in org.apache.flink.api.scala
 
FlinkILoop(String, int, Configuration, Option<String[]>, Option<BufferedReader>, PrintWriter) - Constructor for class org.apache.flink.api.scala.FlinkILoop
 
FlinkILoop(String, int, Configuration, Option<String[]>, BufferedReader, PrintWriter) - Constructor for class org.apache.flink.api.scala.FlinkILoop
 
FlinkILoop(String, int, Configuration, Option<String[]>) - Constructor for class org.apache.flink.api.scala.FlinkILoop
 
FlinkILoop(String, int, Configuration, BufferedReader, PrintWriter) - Constructor for class org.apache.flink.api.scala.FlinkILoop
 
FlinkKafkaConsumer010<T> - Class in org.apache.flink.streaming.connectors.kafka
The Flink Kafka Consumer is a streaming data source that pulls a parallel data stream from Apache Kafka 0.10.x.
FlinkKafkaConsumer010(String, DeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer010
Creates a new Kafka streaming source consumer for Kafka 0.10.x
FlinkKafkaConsumer010(String, KeyedDeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer010
Creates a new Kafka streaming source consumer for Kafka 0.10.x This constructor allows passing a KeyedDeserializationSchema for reading key/value pairs, offsets, and topic names from Kafka.
FlinkKafkaConsumer010(List<String>, DeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer010
Creates a new Kafka streaming source consumer for Kafka 0.10.x This constructor allows passing multiple topics to the consumer.
FlinkKafkaConsumer010(List<String>, KeyedDeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer010
Creates a new Kafka streaming source consumer for Kafka 0.10.x This constructor allows passing multiple topics and a key/value deserialization schema.
FlinkKafkaConsumer08<T> - Class in org.apache.flink.streaming.connectors.kafka
The Flink Kafka Consumer is a streaming data source that pulls a parallel data stream from Apache Kafka 0.8.x.
FlinkKafkaConsumer08(String, DeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer08
Creates a new Kafka streaming source consumer for Kafka 0.8.x
FlinkKafkaConsumer08(String, KeyedDeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer08
Creates a new Kafka streaming source consumer for Kafka 0.8.x This constructor allows passing a KeyedDeserializationSchema for reading key/value pairs, offsets, and topic names from Kafka.
FlinkKafkaConsumer08(List<String>, DeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer08
Creates a new Kafka streaming source consumer for Kafka 0.8.x This constructor allows passing multiple topics to the consumer.
FlinkKafkaConsumer08(List<String>, KeyedDeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer08
Creates a new Kafka streaming source consumer for Kafka 0.8.x This constructor allows passing multiple topics and a key/value deserialization schema.
FlinkKafkaConsumer081<T> - Class in org.apache.flink.streaming.connectors.kafka
Deprecated.
FlinkKafkaConsumer081(String, DeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer081
FlinkKafkaConsumer082<T> - Class in org.apache.flink.streaming.connectors.kafka
Deprecated.
FlinkKafkaConsumer082(String, DeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer082
FlinkKafkaConsumer09<T> - Class in org.apache.flink.streaming.connectors.kafka
The Flink Kafka Consumer is a streaming data source that pulls a parallel data stream from Apache Kafka 0.9.x.
FlinkKafkaConsumer09(String, DeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
Creates a new Kafka streaming source consumer for Kafka 0.9.x
FlinkKafkaConsumer09(String, KeyedDeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
Creates a new Kafka streaming source consumer for Kafka 0.9.x This constructor allows passing a KeyedDeserializationSchema for reading key/value pairs, offsets, and topic names from Kafka.
FlinkKafkaConsumer09(List<String>, DeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
Creates a new Kafka streaming source consumer for Kafka 0.9.x This constructor allows passing multiple topics to the consumer.
FlinkKafkaConsumer09(List<String>, KeyedDeserializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
Creates a new Kafka streaming source consumer for Kafka 0.9.x This constructor allows passing multiple topics and a key/value deserialization schema.
FlinkKafkaConsumerBase<T> - Class in org.apache.flink.streaming.connectors.kafka
Base class of all Flink Kafka Consumer data sources.
FlinkKafkaConsumerBase(List<String>, KeyedDeserializationSchema<T>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
Base constructor.
FlinkKafkaDelegatePartitioner<T> - Class in org.apache.flink.streaming.connectors.kafka.partitioner
Deprecated.
Delegate for KafkaPartitioner, use FlinkKafkaPartitioner instead
FlinkKafkaDelegatePartitioner(KafkaPartitioner<T>) - Constructor for class org.apache.flink.streaming.connectors.kafka.partitioner.FlinkKafkaDelegatePartitioner
Deprecated.
 
flinkKafkaPartitioner - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
User-provided partitioner for assigning an object to a Kafka partition for each topic.
FlinkKafkaPartitioner<T> - Class in org.apache.flink.streaming.connectors.kafka.partitioner
A FlinkKafkaPartitioner wraps logic on how to partition records across partitions of multiple Kafka topics.
FlinkKafkaPartitioner() - Constructor for class org.apache.flink.streaming.connectors.kafka.partitioner.FlinkKafkaPartitioner
 
FlinkKafkaProducer<IN> - Class in org.apache.flink.streaming.connectors.kafka
Deprecated.
FlinkKafkaProducer(String, String, SerializationSchema<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer
FlinkKafkaProducer(String, SerializationSchema<IN>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer
FlinkKafkaProducer(String, SerializationSchema<IN>, Properties, KafkaPartitioner) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer
FlinkKafkaProducer(String, String, KeyedSerializationSchema<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer
FlinkKafkaProducer(String, KeyedSerializationSchema<IN>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer
FlinkKafkaProducer(String, KeyedSerializationSchema<IN>, Properties, KafkaPartitioner) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer
FlinkKafkaProducer010<T> - Class in org.apache.flink.streaming.connectors.kafka
Flink Sink to produce data into a Kafka topic.
FlinkKafkaProducer010(String, String, SerializationSchema<T>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
Creates a FlinkKafkaProducer for a given topic.
FlinkKafkaProducer010(String, SerializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
Creates a FlinkKafkaProducer for a given topic.
FlinkKafkaProducer010(String, SerializationSchema<T>, Properties, FlinkKafkaPartitioner<T>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
Creates a FlinkKafkaProducer for a given topic.
FlinkKafkaProducer010(String, String, KeyedSerializationSchema<T>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
Creates a FlinkKafkaProducer for a given topic.
FlinkKafkaProducer010(String, KeyedSerializationSchema<T>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
Creates a FlinkKafkaProducer for a given topic.
FlinkKafkaProducer010(String, KeyedSerializationSchema<T>, Properties, FlinkKafkaPartitioner<T>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
Create Kafka producer This constructor does not allow writing timestamps to Kafka, it follow approach (a) (see above)
FlinkKafkaProducer010(String, SerializationSchema<T>, Properties, KafkaPartitioner<T>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
Deprecated.
This is a deprecated since it does not correctly handle partitioning when producing to multiple topics. Use FlinkKafkaProducer010.FlinkKafkaProducer010(String, SerializationSchema, Properties, FlinkKafkaPartitioner) instead.
FlinkKafkaProducer010(String, KeyedSerializationSchema<T>, Properties, KafkaPartitioner<T>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
Deprecated.
This is a deprecated constructor that does not correctly handle partitioning when producing to multiple topics. Use FlinkKafkaProducer010.FlinkKafkaProducer010(String, SerializationSchema, Properties, FlinkKafkaPartitioner) instead.
FlinkKafkaProducer010.FlinkKafkaProducer010Configuration<T> - Class in org.apache.flink.streaming.connectors.kafka
Configuration object returned by the writeToKafkaWithTimestamps() call.
FlinkKafkaProducer08<IN> - Class in org.apache.flink.streaming.connectors.kafka
Flink Sink to produce data into a Kafka topic.
FlinkKafkaProducer08(String, String, SerializationSchema<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer08
Creates a FlinkKafkaProducer for a given topic.
FlinkKafkaProducer08(String, SerializationSchema<IN>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer08
Creates a FlinkKafkaProducer for a given topic.
FlinkKafkaProducer08(String, SerializationSchema<IN>, Properties, FlinkKafkaPartitioner<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer08
The main constructor for creating a FlinkKafkaProducer.
FlinkKafkaProducer08(String, String, KeyedSerializationSchema<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer08
Creates a FlinkKafkaProducer for a given topic.
FlinkKafkaProducer08(String, KeyedSerializationSchema<IN>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer08
Creates a FlinkKafkaProducer for a given topic.
FlinkKafkaProducer08(String, KeyedSerializationSchema<IN>, Properties, FlinkKafkaPartitioner<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer08
The main constructor for creating a FlinkKafkaProducer.
FlinkKafkaProducer08(String, SerializationSchema<IN>, Properties, KafkaPartitioner<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer08
Deprecated.
This is a deprecated constructor that does not correctly handle partitioning when producing to multiple topics. Use FlinkKafkaProducer08.FlinkKafkaProducer08(String, SerializationSchema, Properties, FlinkKafkaPartitioner) instead.
FlinkKafkaProducer08(String, KeyedSerializationSchema<IN>, Properties, KafkaPartitioner<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer08
Deprecated.
This is a deprecated constructor that does not correctly handle partitioning when producing to multiple topics. Use FlinkKafkaProducer08.FlinkKafkaProducer08(String, KeyedSerializationSchema, Properties, FlinkKafkaPartitioner) instead.
FlinkKafkaProducer09<IN> - Class in org.apache.flink.streaming.connectors.kafka
Flink Sink to produce data into a Kafka topic.
FlinkKafkaProducer09(String, String, SerializationSchema<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer09
Creates a FlinkKafkaProducer for a given topic.
FlinkKafkaProducer09(String, SerializationSchema<IN>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer09
Creates a FlinkKafkaProducer for a given topic.
FlinkKafkaProducer09(String, SerializationSchema<IN>, Properties, FlinkKafkaPartitioner<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer09
Creates a FlinkKafkaProducer for a given topic.
FlinkKafkaProducer09(String, String, KeyedSerializationSchema<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer09
Creates a FlinkKafkaProducer for a given topic.
FlinkKafkaProducer09(String, KeyedSerializationSchema<IN>, Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer09
Creates a FlinkKafkaProducer for a given topic.
FlinkKafkaProducer09(String, KeyedSerializationSchema<IN>, Properties, FlinkKafkaPartitioner<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer09
Creates a FlinkKafkaProducer for a given topic.
FlinkKafkaProducer09(String, SerializationSchema<IN>, Properties, KafkaPartitioner<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer09
Deprecated.
This is a deprecated constructor that does not correctly handle partitioning when producing to multiple topics. Use FlinkKafkaProducer09.FlinkKafkaProducer09(String, SerializationSchema, Properties, FlinkKafkaPartitioner) instead.
FlinkKafkaProducer09(String, KeyedSerializationSchema<IN>, Properties, KafkaPartitioner<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer09
Deprecated.
This is a deprecated constructor that does not correctly handle partitioning when producing to multiple topics. Use FlinkKafkaProducer09(String, org.apache.flink.streaming.util.serialization.KeyedDeserializationSchema, Properties, FlinkKafkaPartitioner) instead.
FlinkKafkaProducerBase<IN> - Class in org.apache.flink.streaming.connectors.kafka
Flink Sink to produce data into a Kafka topic.
FlinkKafkaProducerBase(String, KeyedSerializationSchema<IN>, Properties, FlinkKafkaPartitioner<IN>) - Constructor for class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
The main constructor for creating a FlinkKafkaProducer.
FlinkLocalCluster - Class in org.apache.flink.storm.api
FlinkLocalCluster mimics a Storm LocalCluster.
FlinkLocalCluster() - Constructor for class org.apache.flink.storm.api.FlinkLocalCluster
 
FlinkLocalCluster(FlinkMiniCluster) - Constructor for class org.apache.flink.storm.api.FlinkLocalCluster
 
FlinkLocalCluster.DefaultLocalClusterFactory - Class in org.apache.flink.storm.api
A factory that instantiates a FlinkLocalCluster.
FlinkLocalCluster.LocalClusterFactory - Interface in org.apache.flink.storm.api
A factory that creates local clusters.
FlinkLogicalAggregate - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalAggregate(RelOptCluster, RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
FlinkLogicalAggregate$ - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalAggregate$() - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate$
 
FlinkLogicalAggregateConverter - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalAggregateConverter() - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregateConverter
 
FlinkLogicalCalc - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalCalc(RelOptCluster, RelTraitSet, RelNode, RexProgram) - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
FlinkLogicalCalc$ - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalCalc$() - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc$
 
FlinkLogicalCalcConverter - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalCalcConverter() - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalcConverter
 
FlinkLogicalCorrelate - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalCorrelate(RelOptCluster, RelTraitSet, RelNode, RelNode, CorrelationId, ImmutableBitSet, SemiJoinType) - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
FlinkLogicalCorrelate$ - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalCorrelate$() - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate$
 
FlinkLogicalCorrelateConverter - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalCorrelateConverter() - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelateConverter
 
FlinkLogicalIntersect - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalIntersect(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
FlinkLogicalIntersect$ - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalIntersect$() - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect$
 
FlinkLogicalIntersectConverter - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalIntersectConverter() - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersectConverter
 
FlinkLogicalJoin - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalJoin(RelOptCluster, RelTraitSet, RelNode, RelNode, RexNode, JoinRelType) - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
FlinkLogicalJoin$ - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalJoin$() - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin$
 
FlinkLogicalJoinConverter - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalJoinConverter() - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoinConverter
 
FlinkLogicalMinus - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalMinus(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
FlinkLogicalMinus$ - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalMinus$() - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus$
 
FlinkLogicalMinusConverter - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalMinusConverter() - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinusConverter
 
FlinkLogicalNativeTableScan - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalNativeTableScan(RelOptCluster, RelTraitSet, RelOptTable) - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
FlinkLogicalNativeTableScan$ - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalNativeTableScan$() - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan$
 
FlinkLogicalNativeTableScanConverter - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalNativeTableScanConverter() - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScanConverter
 
FlinkLogicalOverWindow - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalOverWindow(RelOptCluster, RelTraitSet, RelNode, List<RexLiteral>, RelDataType, List<Window.Group>) - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
FlinkLogicalOverWindow$ - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalOverWindow$() - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow$
 
FlinkLogicalOverWindowConverter - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalOverWindowConverter() - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindowConverter
 
FlinkLogicalRel - Interface in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalSort - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalSort(RelOptCluster, RelTraitSet, RelNode, RelCollation, RexNode, RexNode) - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
FlinkLogicalSort$ - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalSort$() - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort$
 
FlinkLogicalSortConverter - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalSortConverter() - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSortConverter
 
FlinkLogicalTableFunctionScan - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalTableFunctionScan(RelOptCluster, RelTraitSet, List<RelNode>, RexNode, Type, RelDataType, Set<RelColumnMapping>) - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
FlinkLogicalTableFunctionScan$ - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalTableFunctionScan$() - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan$
 
FlinkLogicalTableFunctionScanConverter - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalTableFunctionScanConverter() - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScanConverter
 
FlinkLogicalTableSourceScan - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalTableSourceScan(RelOptCluster, RelTraitSet, RelOptTable, TableSource<?>) - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
FlinkLogicalTableSourceScan$ - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalTableSourceScan$() - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan$
 
FlinkLogicalTableSourceScanConverter - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalTableSourceScanConverter() - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScanConverter
 
FlinkLogicalUnion - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalUnion(RelOptCluster, RelTraitSet, List<RelNode>, boolean) - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
FlinkLogicalUnion$ - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalUnion$() - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion$
 
FlinkLogicalUnionConverter - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalUnionConverter() - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnionConverter
 
FlinkLogicalValues - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalValues(RelOptCluster, RelTraitSet, RelDataType, ImmutableList<ImmutableList<RexLiteral>>) - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
FlinkLogicalValues$ - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalValues$() - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues$
 
FlinkLogicalValuesConverter - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalValuesConverter() - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValuesConverter
 
FlinkLogicalWindowAggregate - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalWindowAggregate(LogicalWindow, Seq<FlinkRelBuilder.NamedWindowProperty>, RelOptCluster, RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
FlinkLogicalWindowAggregate$ - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalWindowAggregate$() - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate$
 
FlinkLogicalWindowAggregateConverter - Class in org.apache.flink.table.plan.nodes.logical
 
FlinkLogicalWindowAggregateConverter() - Constructor for class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregateConverter
 
FlinkMesosSessionCli - Class in org.apache.flink.mesos.cli
Class handling the command line interface to the Mesos session.
FlinkMesosSessionCli() - Constructor for class org.apache.flink.mesos.cli.FlinkMesosSessionCli
 
FlinkMeterWrapper - Class in org.apache.flink.dropwizard.metrics
Wrapper to use a Flink Meter as a Dropwizard Meter.
FlinkMeterWrapper(Meter) - Constructor for class org.apache.flink.dropwizard.metrics.FlinkMeterWrapper
 
FlinkMeterWrapper(Meter, Clock) - Constructor for class org.apache.flink.dropwizard.metrics.FlinkMeterWrapper
 
FlinkMiniCluster - Class in org.apache.flink.runtime.minicluster
Abstract base class for Flink's mini cluster.
FlinkMiniCluster(Configuration, HighAvailabilityServices, boolean) - Constructor for class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
FlinkMiniCluster(Configuration, boolean) - Constructor for class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
FlinkMLTools - Class in org.apache.flink.ml.common
FlinkMLTools contains a set of convenience functions for Flink's machine learning library:
FlinkMLTools() - Constructor for class org.apache.flink.ml.common.FlinkMLTools
 
FlinkMLTools$ - Class in org.apache.flink.ml.common
FlinkMLTools contains a set of convenience functions for Flink's machine learning library:
FlinkMLTools$() - Constructor for class org.apache.flink.ml.common.FlinkMLTools$
 
FlinkMLTools.ModuloKeyPartitioner$ - Class in org.apache.flink.ml.common
Distributes the elements by taking the modulo of their keys and assigning it to this channel
FlinkPlan - Interface in org.apache.flink.optimizer.plan
A common interface for compiled Flink plans for both batch and streaming processing programs.
FlinkPlannerImpl - Class in org.apache.flink.table.calcite
NOTE: this is heavily inspired by Calcite's PlannerImpl.
FlinkPlannerImpl(FrameworkConfig, RelOptPlanner, FlinkTypeFactory) - Constructor for class org.apache.flink.table.calcite.FlinkPlannerImpl
 
FlinkPlannerImpl$ - Class in org.apache.flink.table.calcite
 
FlinkPlannerImpl$() - Constructor for class org.apache.flink.table.calcite.FlinkPlannerImpl$
 
FlinkPlannerImpl.ViewExpanderImpl - Class in org.apache.flink.table.calcite
Implements RelOptTable.ViewExpander interface for Planner.
FlinkRelBuilder - Class in org.apache.flink.table.calcite
Flink specific RelBuilder that changes the default type factory to a FlinkTypeFactory.
FlinkRelBuilder(Context, RelOptCluster, RelOptSchema) - Constructor for class org.apache.flink.table.calcite.FlinkRelBuilder
 
FlinkRelBuilder$ - Class in org.apache.flink.table.calcite
 
FlinkRelBuilder$() - Constructor for class org.apache.flink.table.calcite.FlinkRelBuilder$
 
FlinkRelBuilder.NamedWindowProperty - Class in org.apache.flink.table.calcite
Information necessary to create a window aggregate.
FlinkRelBuilder.NamedWindowProperty$ - Class in org.apache.flink.table.calcite
 
FlinkRelMdRowCount - Class in org.apache.flink.table.plan.cost
 
FlinkRelMdRowCount() - Constructor for class org.apache.flink.table.plan.cost.FlinkRelMdRowCount
 
FlinkRelMdRowCount$ - Class in org.apache.flink.table.plan.cost
 
FlinkRelMdRowCount$() - Constructor for class org.apache.flink.table.plan.cost.FlinkRelMdRowCount$
 
FlinkRelNode - Interface in org.apache.flink.table.plan.nodes
 
FlinkRelOptClusterFactory - Class in org.apache.flink.table.calcite
The utility class is to create special RelOptCluster instance which use FlinkDefaultRelMetadataProvider instead of DefaultRelMetadataProvider.
FlinkRelOptClusterFactory() - Constructor for class org.apache.flink.table.calcite.FlinkRelOptClusterFactory
 
FlinkRelOptClusterFactory$ - Class in org.apache.flink.table.calcite
The utility class is to create special RelOptCluster instance which use FlinkDefaultRelMetadataProvider instead of DefaultRelMetadataProvider.
FlinkRelOptClusterFactory$() - Constructor for class org.apache.flink.table.calcite.FlinkRelOptClusterFactory$
 
FlinkResourceManager<WorkerType extends ResourceIDRetrievable> - Class in org.apache.flink.runtime.clusterframework
Worker allocation steps
FlinkResourceManager(int, Configuration, LeaderRetrievalService) - Constructor for class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Creates a AbstractFrameworkMaster actor.
FlinkRuleSets - Class in org.apache.flink.table.plan.rules
 
FlinkRuleSets() - Constructor for class org.apache.flink.table.plan.rules.FlinkRuleSets
 
FlinkRuleSets$ - Class in org.apache.flink.table.plan.rules
 
FlinkRuleSets$() - Constructor for class org.apache.flink.table.plan.rules.FlinkRuleSets$
 
FlinkRuntimeException - Exception in org.apache.flink.util
Base class of all Flink-specific unchecked exceptions.
FlinkRuntimeException(String) - Constructor for exception org.apache.flink.util.FlinkRuntimeException
Creates a new Exception with the given message and null as the cause.
FlinkRuntimeException(Throwable) - Constructor for exception org.apache.flink.util.FlinkRuntimeException
Creates a new exception with a null message and the given cause.
FlinkRuntimeException(String, Throwable) - Constructor for exception org.apache.flink.util.FlinkRuntimeException
Creates a new exception with the given message and cause
FlinkShell - Class in org.apache.flink.api.scala
 
FlinkShell() - Constructor for class org.apache.flink.api.scala.FlinkShell
 
FlinkShell$ - Class in org.apache.flink.api.scala
 
FlinkShell$() - Constructor for class org.apache.flink.api.scala.FlinkShell$
 
FlinkShell.Config - Class in org.apache.flink.api.scala
Configuration object
FlinkShell.Config$ - Class in org.apache.flink.api.scala
 
FlinkShell.ExecutionMode$ - Class in org.apache.flink.api.scala
 
FlinkShell.YarnConfig - Class in org.apache.flink.api.scala
YARN configuration object
FlinkShell.YarnConfig$ - Class in org.apache.flink.api.scala
 
FlinkStatistic - Class in org.apache.flink.table.plan.stats
The class provides statistics for a FlinkTable.
FlinkStatistic(Option<TableStats>) - Constructor for class org.apache.flink.table.plan.stats.FlinkStatistic
 
FlinkStatistic$ - Class in org.apache.flink.table.plan.stats
Methods to create FlinkStatistic.
FlinkStatistic$() - Constructor for class org.apache.flink.table.plan.stats.FlinkStatistic$
 
FlinkSubmitter - Class in org.apache.flink.storm.api
FlinkSubmitter mimics a StormSubmitter to submit Storm topologies to a Flink cluster.
FlinkSubmitter() - Constructor for class org.apache.flink.storm.api.FlinkSubmitter
 
FlinkSubmitter.FlinkProgressListener - Interface in org.apache.flink.storm.api
Dummy interface use to track progress of file upload.
FlinkTable<T> - Class in org.apache.flink.table.plan.schema
 
FlinkTable(TypeInformation<T>, int[], String[], FlinkStatistic) - Constructor for class org.apache.flink.table.plan.schema.FlinkTable
 
FlinkTableFunctionImpl<T> - Class in org.apache.flink.table.plan.schema
This is heavily inspired by Calcite's TableFunctionImpl.
FlinkTableFunctionImpl(TypeInformation<T>, int[], String[], Method) - Constructor for class org.apache.flink.table.plan.schema.FlinkTableFunctionImpl
 
FlinkTopology - Class in org.apache.flink.storm.api
FlinkTopology translates a TopologyBuilder to a Flink program.
FlinkTypeFactory - Class in org.apache.flink.table.calcite
Flink specific type factory that represents the interface between Flink's TypeInformation and Calcite's RelDataType.
FlinkTypeFactory(RelDataTypeSystem) - Constructor for class org.apache.flink.table.calcite.FlinkTypeFactory
 
FlinkTypeFactory$ - Class in org.apache.flink.table.calcite
 
FlinkTypeFactory$() - Constructor for class org.apache.flink.table.calcite.FlinkTypeFactory$
 
FlinkTypeSystem - Class in org.apache.flink.table.calcite
Custom type system for Flink.
FlinkTypeSystem() - Constructor for class org.apache.flink.table.calcite.FlinkTypeSystem
 
FlinkUntypedActor - Class in org.apache.flink.runtime.akka
Base class for Flink's actors implemented with Java.
FlinkUntypedActor() - Constructor for class org.apache.flink.runtime.akka.FlinkUntypedActor
 
FlinkUserCodeClassLoader - Class in org.apache.flink.runtime.execution.librarycache
Gives the URLClassLoader a nicer name for debugging purposes.
FlinkUserCodeClassLoader(URL[]) - Constructor for class org.apache.flink.runtime.execution.librarycache.FlinkUserCodeClassLoader
 
FlinkUserCodeClassLoader(URL[], ClassLoader) - Constructor for class org.apache.flink.runtime.execution.librarycache.FlinkUserCodeClassLoader
 
FlinkYarnCLI - Class in org.apache.flink.yarn.cli
Class handling the command line interface to the YARN per job mode under flip-6.
FlinkYarnCLI(String, String) - Constructor for class org.apache.flink.yarn.cli.FlinkYarnCLI
 
FlinkYarnSessionCli - Class in org.apache.flink.yarn.cli
Class handling the command line interface to the YARN session.
FlinkYarnSessionCli(String, String) - Constructor for class org.apache.flink.yarn.cli.FlinkYarnSessionCli
 
FlinkYarnSessionCli(String, String, boolean) - Constructor for class org.apache.flink.yarn.cli.FlinkYarnSessionCli
 
FlinkZooKeeperQuorumPeer - Class in org.apache.flink.runtime.zookeeper
Simple wrapper for ZooKeeper's QuorumPeer, which reads a ZooKeeper config file and writes the required 'myid' file before starting the peer.
FlinkZooKeeperQuorumPeer() - Constructor for class org.apache.flink.runtime.zookeeper.FlinkZooKeeperQuorumPeer
 
flip() - Method in class org.apache.flink.runtime.io.disk.SpillingBuffer
 
Flip6LocalStreamEnvironment - Class in org.apache.flink.streaming.api.environment
The Flip6LocalStreamEnvironment is a StreamExecutionEnvironment that runs the program locally, multi-threaded, in the JVM where the environment is instantiated.
Flip6LocalStreamEnvironment() - Constructor for class org.apache.flink.streaming.api.environment.Flip6LocalStreamEnvironment
Creates a new mini cluster stream environment that uses the default configuration.
Flip6LocalStreamEnvironment(Configuration) - Constructor for class org.apache.flink.streaming.api.environment.Flip6LocalStreamEnvironment
Creates a new mini cluster stream environment that configures its local executor with the given configuration.
flipVertices() - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Edge
 
FLOAT - Static variable in class org.apache.flink.api.common.typeinfo.Types
 
FLOAT() - Method in class org.apache.flink.table.api.Types$
 
FLOAT() - Static method in class org.apache.flink.table.api.Types
 
FLOAT() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
FLOAT() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
float2Literal(float) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionConversions
 
FLOAT_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
FLOAT_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
FLOAT_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
FLOAT_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
FloatAvgAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Float Avg aggregate function
FloatAvgAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.FloatAvgAggFunction
 
FloatComparator - Class in org.apache.flink.api.common.typeutils.base
 
FloatComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.FloatComparator
 
FloatExplodeTableFunc - Class in org.apache.flink.table.plan.util
 
FloatExplodeTableFunc() - Constructor for class org.apache.flink.table.plan.util.FloatExplodeTableFunc
 
FloatingAvgAccumulator - Class in org.apache.flink.table.functions.aggfunctions
The initial accumulator for Floating Avg aggregate function
FloatingAvgAccumulator() - Constructor for class org.apache.flink.table.functions.aggfunctions.FloatingAvgAccumulator
 
FloatingAvgAggFunction<T> - Class in org.apache.flink.table.functions.aggfunctions
Base class for built-in Floating Avg aggregate function
FloatingAvgAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.FloatingAvgAggFunction
 
floatingNetworkBuffersPerGate() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
floatingPointNumber() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
floatingPointNumberFlink() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
floatingPointNumberFlink() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
FloatMaxAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Float Max aggregate function
FloatMaxAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.FloatMaxAggFunction
 
FloatMaxWithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Float Max with retraction aggregate function
FloatMaxWithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.FloatMaxWithRetractAggFunction
 
FloatMinAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Float Min aggregate function
FloatMinAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.FloatMinAggFunction
 
FloatMinWithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Float Min with retraction aggregate function
FloatMinWithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.FloatMinWithRetractAggFunction
 
FloatParser - Class in org.apache.flink.types.parser
Parses a text field into a Float.
FloatParser() - Constructor for class org.apache.flink.types.parser.FloatParser
 
FloatPrimitiveArrayComparator - Class in org.apache.flink.api.common.typeutils.base.array
 
FloatPrimitiveArrayComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArrayComparator
 
FloatPrimitiveArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
A serializer for float arrays.
FloatPrimitiveArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
FloatSerializer - Class in org.apache.flink.api.common.typeutils.base
 
FloatSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.FloatSerializer
 
FloatSerializer() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.FloatSerializer
 
FloatSum0AggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Float Sum0 aggregate function
FloatSum0AggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.FloatSum0AggFunction
 
FloatSum0WithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Float Sum0 with retract aggregate function
FloatSum0WithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.FloatSum0WithRetractAggFunction
 
FloatSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.FloatSumAgg
 
FloatSumAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Float Sum aggregate function
FloatSumAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.FloatSumAggFunction
 
FloatSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
Aggregator that can handle Float types
FloatSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator
 
FloatSummaryAggregator.MaxFloatAggregator - Class in org.apache.flink.api.java.summarize.aggregation
 
FloatSummaryAggregator.MinFloatAggregator - Class in org.apache.flink.api.java.summarize.aggregation
 
FloatSummaryAggregator.SumFloatAggregator - Class in org.apache.flink.api.java.summarize.aggregation
 
FloatSumWithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Float Sum with retract aggregate function
FloatSumWithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.FloatSumWithRetractAggFunction
 
FloatValue - Class in org.apache.flink.types
Boxed serializable and comparable single precision floating point type, representing the primitive type float.
FloatValue() - Constructor for class org.apache.flink.types.FloatValue
Initializes the encapsulated float with 0.0.
FloatValue(float) - Constructor for class org.apache.flink.types.FloatValue
Initializes the encapsulated float with the provided value.
FloatValueComparator - Class in org.apache.flink.api.common.typeutils.base
Specialized comparator for FloatValue based on CopyableValueComparator.
FloatValueComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
FloatValueParser - Class in org.apache.flink.types.parser
Parses a text field into a FloatValue
FloatValueParser() - Constructor for class org.apache.flink.types.parser.FloatValueParser
 
FloatValueSerializer - Class in org.apache.flink.api.common.typeutils.base
 
FloatValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
FloatValueSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.FloatValueSumAgg
 
FloatValueSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.FloatValueSummaryAggregator
 
FLOOR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The FLOOR function.
floor() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Calculates the largest integer less than or equal to a given number.
floor(TableSymbols.TableSymbolValue) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Rounds down a time point to the given unit.
FLOOR() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
FLOOR() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
Floor - Class in org.apache.flink.table.expressions
 
Floor(Expression) - Constructor for class org.apache.flink.table.expressions.Floor
 
Floor$ - Class in org.apache.flink.table.expressions
 
Floor$() - Constructor for class org.apache.flink.table.expressions.Floor$
 
FloorCeilCallGen - Class in org.apache.flink.table.codegen.calls
Generates floor/ceil function calls.
FloorCeilCallGen(Method, Option<Method>) - Constructor for class org.apache.flink.table.codegen.calls.FloorCeilCallGen
 
FloorCeilCallGen$ - Class in org.apache.flink.table.codegen.calls
 
FloorCeilCallGen$() - Constructor for class org.apache.flink.table.codegen.calls.FloorCeilCallGen$
 
flush() - Method in class org.apache.flink.api.avro.DataOutputEncoder
 
flush() - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
flush() - Method in class org.apache.flink.core.fs.FSDataOutputStream
Flushes the stream, writing any data currently buffered in stream implementation to the proper output stream.
flush() - Method in class org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
flush() - Method in class org.apache.flink.core.fs.local.LocalDataOutputStream
 
flush() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataOutputStream
 
flush() - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
 
flush() - Method in class org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
 
flush() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
 
flush() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
 
flush() - Method in class org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
 
flush() - Method in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter
 
flush() - Method in class org.apache.flink.streaming.connectors.fs.StreamWriterBase
 
flush() - Method in interface org.apache.flink.streaming.connectors.fs.Writer
Flushes out any internally held data, and returns the offset that the file must be truncated to at recovery.
flush() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer08
 
flush() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer09
 
flush() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
Flush pending records.
flush() - Method in class org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
flushOnCheckpoint - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
If true, the producer will wait until all outstanding records have been send to the broker.
flushOutputs() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
This method should be called before finishing the record emission, to make sure any data that is still buffered will be sent.
fold(T, O) - Method in interface org.apache.flink.api.common.functions.FoldFunction
Deprecated.
The core method of FoldFunction, combining two values into one value of the same type.
fold(T, O) - Method in class org.apache.flink.api.common.functions.RichFoldFunction
Deprecated.
 
fold(R, FoldFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
fold(R, FoldFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
fold(ACC, FoldFunction<T, ACC>, AllWindowFunction<ACC, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
fold(ACC, FoldFunction<T, ACC>, AllWindowFunction<ACC, R, W>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
fold(ACC, FoldFunction<T, ACC>, ProcessAllWindowFunction<ACC, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
fold(ACC, FoldFunction<T, ACC>, ProcessAllWindowFunction<ACC, R, W>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
fold(R, FoldFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Deprecated.
will be removed in a future version
fold(R, FoldFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
fold(R, FoldFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
fold(ACC, FoldFunction<T, ACC>, WindowFunction<ACC, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
fold(ACC, FoldFunction<T, ACC>, WindowFunction<ACC, R, K, W>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
fold(ACC, FoldFunction<T, ACC>, ProcessWindowFunction<ACC, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
fold(ACC, FoldFunction<T, ACC>, ProcessWindowFunction<ACC, R, K, W>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
fold(R, FoldFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Deprecated.
use [[aggregate()]] instead. Since .
fold(R, Function2<R, T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Deprecated.
use [[aggregate()]] instead. Since .
fold(ACC, FoldFunction<T, ACC>, AllWindowFunction<ACC, R, W>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Deprecated.
use [[aggregate()]] instead. Since .
fold(ACC, FoldFunction<T, ACC>, ProcessAllWindowFunction<ACC, R, W>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Deprecated.
use [[aggregate()]] instead. Since .
fold(ACC, Function2<ACC, T, ACC>, Function3<W, Iterable<ACC>, Collector<R>, BoxedUnit>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Deprecated.
use [[aggregate()]] instead. Since .
fold(ACC, Function2<ACC, T, ACC>, ProcessAllWindowFunction<ACC, R, W>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Deprecated.
use [[aggregate()]] instead. Since .
fold(R, T) - Method in class org.apache.flink.streaming.api.scala.function.util.ScalaFoldFunction
 
fold(R, FoldFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.KeyedStream
Deprecated.
will be removed in a future version. Since .
fold(R, Function2<R, T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.KeyedStream
Deprecated.
will be removed in a future version. Since .
fold(R, FoldFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Deprecated.
use [[aggregate()]] instead. Since .
fold(R, Function2<R, T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Deprecated.
use [[aggregate()]] instead. Since .
fold(ACC, FoldFunction<T, ACC>, WindowFunction<ACC, R, K, W>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Deprecated.
use [[aggregate()]] instead. Since .
fold(ACC, Function2<ACC, T, ACC>, Function4<K, W, Iterable<ACC>, Collector<R>, BoxedUnit>, TypeInformation<ACC>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Deprecated.
use [[aggregate()]] instead. Since .
fold(ACC, Function2<ACC, T, ACC>, ProcessWindowFunction<ACC, R, K, W>, TypeInformation<R>, TypeInformation<ACC>) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Deprecated.
use [[aggregate()]] instead. Since .
fold(ACC, FoldFunction<T, ACC>, ProcessWindowFunction<ACC, R, K, W>, TypeInformation<R>, TypeInformation<ACC>) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Deprecated.
use [[aggregate()]] instead. Since .
FoldApplyAllWindowFunction<W extends Window,T,ACC,R> - Class in org.apache.flink.streaming.api.functions.windowing
Deprecated.
will be removed in a future version
FoldApplyAllWindowFunction(ACC, FoldFunction<T, ACC>, AllWindowFunction<ACC, R, W>, TypeInformation<ACC>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.FoldApplyAllWindowFunction
Deprecated.
 
FoldApplyProcessAllWindowFunction<W extends Window,T,ACC,R> - Class in org.apache.flink.streaming.api.functions.windowing
Deprecated.
will be removed in a future version
FoldApplyProcessAllWindowFunction(ACC, FoldFunction<T, ACC>, ProcessAllWindowFunction<ACC, R, W>, TypeInformation<ACC>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessAllWindowFunction
Deprecated.
 
FoldApplyProcessWindowFunction<K,W extends Window,T,ACC,R> - Class in org.apache.flink.streaming.api.functions.windowing
Deprecated.
will be removed in a future version
FoldApplyProcessWindowFunction(ACC, FoldFunction<T, ACC>, ProcessWindowFunction<ACC, R, K, W>, TypeInformation<ACC>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessWindowFunction
Deprecated.
 
FoldApplyWindowFunction<K,W extends Window,T,ACC,R> - Class in org.apache.flink.streaming.api.functions.windowing
Deprecated.
will be removed in a future version
FoldApplyWindowFunction(ACC, FoldFunction<T, ACC>, WindowFunction<ACC, R, K, W>, TypeInformation<ACC>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.FoldApplyWindowFunction
Deprecated.
 
FoldFunction<O,T> - Interface in org.apache.flink.api.common.functions
Deprecated.
use AggregateFunction instead
FoldingState<T,ACC> - Interface in org.apache.flink.api.common.state
Deprecated.
will be removed in a future version
FoldingStateDescriptor<T,ACC> - Class in org.apache.flink.api.common.state
Deprecated.
will be removed in a future version in favor of AggregatingStateDescriptor
FoldingStateDescriptor(String, ACC, FoldFunction<T, ACC>, Class<ACC>) - Constructor for class org.apache.flink.api.common.state.FoldingStateDescriptor
Deprecated.
Creates a new FoldingStateDescriptor with the given name, type, and initial value.
FoldingStateDescriptor(String, ACC, FoldFunction<T, ACC>, TypeInformation<ACC>) - Constructor for class org.apache.flink.api.common.state.FoldingStateDescriptor
Deprecated.
Creates a new FoldingStateDescriptor with the given name and default value.
FoldingStateDescriptor(String, ACC, FoldFunction<T, ACC>, TypeSerializer<ACC>) - Constructor for class org.apache.flink.api.common.state.FoldingStateDescriptor
Deprecated.
Creates a new ValueStateDescriptor with the given name and default value.
foldWith(R, Function2<R, T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.extensions.impl.acceptPartialFunctions.OnKeyedStream
Folds the stream over a zero element with a reducer fun
foldWith(R, Function2<R, T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.extensions.impl.acceptPartialFunctions.OnWindowedStream
Applies the given fold function to each window.
followedBy(String) - Method in class org.apache.flink.cep.pattern.Pattern
Appends a new pattern to the existing one.
followedBy(String) - Method in class org.apache.flink.cep.scala.pattern.Pattern
Appends a new pattern to the existing one.
followedByAny(String) - Method in class org.apache.flink.cep.pattern.Pattern
Appends a new pattern to the existing one.
followedByAny(String) - Method in class org.apache.flink.cep.scala.pattern.Pattern
Appends a new pattern to the existing one.
following() - Method in class org.apache.flink.table.api.OverWindow
 
following() - Method in class org.apache.flink.table.api.OverWindowWithPreceding
 
following(String) - Method in class org.apache.flink.table.api.OverWindowWithPreceding
Set the following offset (based on time or row-count intervals) for over window.
following(Expression) - Method in class org.apache.flink.table.api.OverWindowWithPreceding
Set the following offset (based on time or row-count intervals) for over window.
following() - Method in class org.apache.flink.table.expressions.OverCall
 
forceNonParallel() - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Sets the parallelism and maximum parallelism of this operator to one.
forExternalizedCheckpoint(boolean) - Static method in class org.apache.flink.runtime.checkpoint.CheckpointProperties
Creates the checkpoint properties for an external checkpoint.
forFullCheckpoint() - Static method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
 
forGrouping(FieldList) - Static method in class org.apache.flink.optimizer.dataproperties.LocalProperties
 
format(IN) - Method in interface org.apache.flink.api.java.io.TextOutputFormat.TextFormatter
 
format() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
 
format(Tuple) - Method in interface org.apache.flink.storm.util.OutputFormatter
Converts a Storm Tuple to a string.
format(Tuple) - Method in class org.apache.flink.storm.util.SimpleOutputFormatter
Converts a Storm Tuple with 1 field to a string by retrieving the value of that field.
format(Tuple) - Method in class org.apache.flink.storm.util.TupleOutputFormatter
 
format - Variable in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
 
formatDurationParingErrorMessage() - Method in class org.apache.flink.runtime.akka.AkkaUtils$
 
formatDurationParingErrorMessage() - Static method in class org.apache.flink.runtime.akka.AkkaUtils
 
formatLogString(String) - Method in class org.apache.flink.runtime.operators.BatchTask
 
formatLogString(String) - Method in interface org.apache.flink.runtime.operators.TaskContext
 
formatNumber(double) - Static method in class org.apache.flink.optimizer.plandump.PlanJSONDumpGenerator
 
formatNumber(double, String) - Static method in class org.apache.flink.optimizer.plandump.PlanJSONDumpGenerator
 
formatScope(JobManagerMetricGroup, JobID, String) - Method in class org.apache.flink.runtime.metrics.scope.JobManagerJobScopeFormat
 
formatScope(String) - Method in class org.apache.flink.runtime.metrics.scope.JobManagerScopeFormat
 
formatScope(TaskMetricGroup, String) - Method in class org.apache.flink.runtime.metrics.scope.OperatorScopeFormat
 
formatScope(TaskManagerMetricGroup, JobID, String) - Method in class org.apache.flink.runtime.metrics.scope.TaskManagerJobScopeFormat
 
formatScope(String, String) - Method in class org.apache.flink.runtime.metrics.scope.TaskManagerScopeFormat
 
formatScope(TaskManagerJobMetricGroup, AbstractID, AbstractID, String, int, int) - Method in class org.apache.flink.runtime.metrics.scope.TaskScopeFormat
 
formatSystemProperties(Configuration) - Static method in class org.apache.flink.runtime.clusterframework.ContainerSpecification
Format the system properties as a shell-compatible command-line argument.
FormattingMapper<T> - Class in org.apache.flink.api.java.functions
 
FormattingMapper(TextOutputFormat.TextFormatter<T>) - Constructor for class org.apache.flink.api.java.functions.FormattingMapper
 
formatWrapper - Variable in class org.apache.flink.api.common.operators.GenericDataSinkBase
 
formatWrapper - Variable in class org.apache.flink.api.common.operators.GenericDataSourceBase
 
forOrdering(Ordering) - Static method in class org.apache.flink.optimizer.dataproperties.LocalProperties
 
forPath(String) - Static method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
 
forPath(String, boolean) - Static method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
 
forSavepoint(String) - Static method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
 
forSingleJobAppMaster(Configuration, Configuration) - Static method in class org.apache.flink.yarn.highavailability.YarnHighAvailabilityServices
Creates the high-availability services for a single-job Flink YARN application, to be used in the Application Master that runs both ResourceManager and JobManager.
forStandardCheckpoint() - Static method in class org.apache.flink.runtime.checkpoint.CheckpointProperties
Creates the checkpoint properties for a regular checkpoint.
forStandardSavepoint() - Static method in class org.apache.flink.runtime.checkpoint.CheckpointProperties
Creates the checkpoint properties for a (manually triggered) savepoint.
forward(Object, ActorGateway) - Method in interface org.apache.flink.runtime.instance.ActorGateway
Forwards a message.
forward(Object, ActorGateway) - Method in class org.apache.flink.runtime.instance.AkkaActorGateway
Forwards a message.
forward() - Method in class org.apache.flink.streaming.api.datastream.DataStream
Sets the partitioning of the DataStream so that the output elements are forwarded to the local subtask of the next operation.
forward() - Method in class org.apache.flink.streaming.api.scala.DataStream
Sets the partitioning of the DataStream so that the output tuples are forwarded to the local subtask of the next component (whenever possible).
ForwardPartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
Partitioner that forwards elements only to the locally running downstream operation.
ForwardPartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
 
forwardsRetractions(RelNode, Seq<RelNode>) - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamRetractionRules.SetAccModeRule
Checks if a RelNode forwards retraction messages from its children.
forYarnTaskManager(Configuration, Configuration) - Static method in class org.apache.flink.yarn.highavailability.YarnHighAvailabilityServices
Creates the high-availability services for the TaskManagers participating in a Flink YARN application.
FractionalTypeInfo<T> - Class in org.apache.flink.api.common.typeinfo
Type information for numeric fractional primitive types (double, float).
FractionalTypeInfo(Class<T>, Class<?>[], TypeSerializer<T>, Class<? extends TypeComparator<T>>) - Constructor for class org.apache.flink.api.common.typeinfo.FractionalTypeInfo
 
frameworkId() - Method in class org.apache.flink.mesos.scheduler.messages.Registered
 
frameworkInfo() - Method in class org.apache.flink.mesos.util.MesosConfiguration
The framework registration info.
FrameworkMessage - Class in org.apache.flink.mesos.scheduler.messages
Message sent when an executor sends a message.
FrameworkMessage(Protos.ExecutorID, Protos.SlaveID, byte[]) - Constructor for class org.apache.flink.mesos.scheduler.messages.FrameworkMessage
 
frameworkMessage(SchedulerDriver, Protos.ExecutorID, Protos.SlaveID, byte[]) - Method in class org.apache.flink.mesos.scheduler.SchedulerProxy
 
free() - Method in class org.apache.flink.core.memory.HeapMemorySegment
 
free() - Method in class org.apache.flink.core.memory.MemorySegment
Frees this memory segment.
FreeingBufferRecycler - Class in org.apache.flink.runtime.io.network.buffer
A simple buffer recycler that frees the memory segments.
freeSlot(SlotID, AllocationID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Free the given slot from the given allocation.
freeSlot(AllocationID) - Method in interface org.apache.flink.runtime.taskexecutor.slot.SlotActions
Free the task slot with the given allocation id.
freeSlot(AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Try to free the slot.
freeSlot(AllocationID, Throwable) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Tries to free the slot.
frequency - Variable in class org.apache.flink.table.examples.java.WordCountSQL.WC
 
frequency - Variable in class org.apache.flink.table.examples.java.WordCountTable.WC
 
frequency() - Method in class org.apache.flink.table.examples.scala.WordCountSQL.WC
 
frequency() - Method in class org.apache.flink.table.examples.scala.WordCountTable.WC
 
frm - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
from(IntermediateResultPartition, int, boolean) - Static method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
 
from(StoppableCallbackCallable<V>) - Static method in class org.apache.flink.runtime.io.async.AsyncStoppableTaskWithCallback
 
from(StreamRecord<T>) - Static method in class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
Creates a TimestampedValue from given StreamRecord.
fromArgs(String[]) - Static method in class org.apache.flink.api.java.utils.ParameterTool
Returns ParameterTool for the given arguments.
fromBinaryJava(byte[], Class<?>) - Method in class org.apache.flink.runtime.akka.serialization.IOReadableWritableSerializer
 
fromBinaryJava(byte[], Class<?>) - Method in class org.apache.flink.runtime.akka.serialization.WritableSerializer
 
fromBreeze() - Method in class org.apache.flink.ml.math.Breeze.Breeze2MatrixConverter
 
fromBreeze(BreezeVectorConverter<T>) - Method in class org.apache.flink.ml.math.Breeze.Breeze2VectorConverter
 
fromBuffer(Buffer, ClassLoader) - Static method in class org.apache.flink.runtime.io.network.api.serialization.EventSerializer
 
fromByteArray(byte[]) - Static method in class org.apache.flink.api.common.JobID
Creates a new JobID from the given byte sequence.
fromByteBuf(ByteBuf) - Static method in class org.apache.flink.runtime.executiongraph.ExecutionAttemptID
 
fromByteBuf(ByteBuf) - Static method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannelID
 
fromByteBuf(ByteBuf) - Static method in class org.apache.flink.runtime.jobgraph.IntermediateResultPartitionID
 
fromByteBuffer(ByteBuffer) - Static method in class org.apache.flink.api.common.JobID
 
fromBytes(byte[]) - Static method in class org.apache.flink.migration.util.SerializedValue
Deprecated.
 
fromBytes(byte[]) - Static method in class org.apache.flink.util.SerializedValue
 
fromCollection(Collection<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a DataSet from the given non-empty collection.
fromCollection(Collection<X>, TypeInformation<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a DataSet from the given non-empty collection.
fromCollection(Iterator<X>, Class<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a DataSet from the given iterator.
fromCollection(Iterator<X>, TypeInformation<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a DataSet from the given iterator.
fromCollection(Iterable<T>, ClassTag<T>, TypeInformation<T>) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Creates a DataSet from the given non-empty Iterable.
fromCollection(Iterator<T>, ClassTag<T>, TypeInformation<T>) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Creates a DataSet from the given Iterator.
fromCollection(Collection<Vertex<K, VV>>, Collection<Edge<K, EV>>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
Creates a graph from a Collection of vertices and a Collection of edges.
fromCollection(Collection<Edge<K, EV>>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
Creates a graph from a Collection of edges.
fromCollection(Collection<Edge<K, EV>>, MapFunction<K, VV>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
Creates a graph from a Collection of edges.
fromCollection(Seq<Vertex<K, VV>>, Seq<Edge<K, EV>>, ExecutionEnvironment, TypeInformation<K>, ClassTag<K>, TypeInformation<VV>, ClassTag<VV>, TypeInformation<EV>, ClassTag<EV>) - Method in class org.apache.flink.graph.scala.Graph$
Creates a Graph from a Seq of vertices and a Seq of edges.
fromCollection(Seq<Edge<K, EV>>, ExecutionEnvironment, TypeInformation<K>, ClassTag<K>, TypeInformation<EV>, ClassTag<EV>) - Method in class org.apache.flink.graph.scala.Graph$
Creates a Graph from a Seq of edges.
fromCollection(Seq<Edge<K, EV>>, MapFunction<K, VV>, ExecutionEnvironment, TypeInformation<K>, ClassTag<K>, TypeInformation<VV>, ClassTag<VV>, TypeInformation<EV>, ClassTag<EV>) - Method in class org.apache.flink.graph.scala.Graph$
Creates a graph from a Seq of edges.
fromCollection(Seq<Vertex<K, VV>>, Seq<Edge<K, EV>>, ExecutionEnvironment, TypeInformation<K>, ClassTag<K>, TypeInformation<VV>, ClassTag<VV>, TypeInformation<EV>, ClassTag<EV>) - Static method in class org.apache.flink.graph.scala.Graph
Creates a Graph from a Seq of vertices and a Seq of edges.
fromCollection(Seq<Edge<K, EV>>, ExecutionEnvironment, TypeInformation<K>, ClassTag<K>, TypeInformation<EV>, ClassTag<EV>) - Static method in class org.apache.flink.graph.scala.Graph
Creates a Graph from a Seq of edges.
fromCollection(Seq<Edge<K, EV>>, MapFunction<K, VV>, ExecutionEnvironment, TypeInformation<K>, ClassTag<K>, TypeInformation<VV>, ClassTag<VV>, TypeInformation<EV>, ClassTag<EV>) - Static method in class org.apache.flink.graph.scala.Graph
Creates a graph from a Seq of edges.
fromCollection(Collection<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a data stream from the given non-empty collection.
fromCollection(Collection<OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a data stream from the given non-empty collection.
fromCollection(Iterator<OUT>, Class<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a data stream from the given iterator.
fromCollection(Iterator<OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a data stream from the given iterator.
fromCollection(Seq<T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Creates a DataStream from the given non-empty Seq.
fromCollection(Iterator<T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Creates a DataStream from the given Iterator.
fromConfig(Configuration) - Static method in enum org.apache.flink.runtime.jobmanager.HighAvailabilityMode
Return the configured HighAvailabilityMode.
fromConfig(Configuration) - Static method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
Creates the scope formats as defined in the given configuration
fromConfig(Configuration) - Static method in enum org.apache.flink.runtime.util.ZooKeeperUtils.ZkClientACLMode
Return the configured ZooKeeperUtils.ZkClientACLMode.
fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.heartbeat.HeartbeatServices
Creates an HeartbeatServices instance from a Configuration.
fromConfiguration(Configuration, HighAvailabilityServices) - Static method in class org.apache.flink.runtime.jobmaster.JobManagerServices
 
fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.metrics.MetricRegistryConfiguration
Create a metric registry configuration object from the given Configuration.
fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.resourcemanager.ResourceManagerConfiguration
 
fromConfiguration(ResourceManagerRuntimeServicesConfiguration, HighAvailabilityServices, ScheduledExecutor) - Static method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServices
 
fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServicesConfiguration
 
fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
 
fromConfiguration(Configuration) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
fromConfiguration(TaskManagerServicesConfiguration, ResourceID) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
Creates and returns the task manager services.
fromConfiguration(Configuration, InetAddress, boolean) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
Utility method to extract TaskManager config parameters from the configuration and to sanity check them.
fromConfiguration(boolean, boolean, boolean) - Static method in class org.apache.flink.streaming.connectors.kafka.config.OffsetCommitModes
Determine the offset commit mode using several configuration values.
fromCOO(DataSet<Tuple3<Object, Object, Object>>, int, int, boolean) - Method in class org.apache.flink.ml.math.distributed.DistributedRowMatrix$
Builds a DistributedRowMatrix from a DataSet in COO.
fromCOO(DataSet<Tuple3<Object, Object, Object>>, int, int, boolean) - Static method in class org.apache.flink.ml.math.distributed.DistributedRowMatrix
Builds a DistributedRowMatrix from a DataSet in COO.
fromCOO(int, int, Seq<Tuple3<Object, Object, Object>>) - Method in class org.apache.flink.ml.math.SparseMatrix$
Constructs a sparse matrix from a coordinate list (COO) representation where each entry is stored as a tuple of (rowIndex, columnIndex, value).
fromCOO(int, int, Iterable<Tuple3<Object, Object, Object>>) - Method in class org.apache.flink.ml.math.SparseMatrix$
Constructs a sparse matrix from a coordinate list (COO) representation where each entry is stored as a tuple of (rowIndex, columnIndex, value).
fromCOO(int, int, Tuple3<Object, Object, Object>) - Method in class org.apache.flink.ml.math.SparseMatrix$
Convenience method to convert a single tuple with an integer value into a SparseMatrix.
fromCOO(int, int, Seq<Tuple3<Object, Object, Object>>) - Static method in class org.apache.flink.ml.math.SparseMatrix
Constructs a sparse matrix from a coordinate list (COO) representation where each entry is stored as a tuple of (rowIndex, columnIndex, value).
fromCOO(int, int, Iterable<Tuple3<Object, Object, Object>>) - Static method in class org.apache.flink.ml.math.SparseMatrix
Constructs a sparse matrix from a coordinate list (COO) representation where each entry is stored as a tuple of (rowIndex, columnIndex, value).
fromCOO(int, int, Tuple3<Object, Object, Object>) - Static method in class org.apache.flink.ml.math.SparseMatrix
Convenience method to convert a single tuple with an integer value into a SparseMatrix.
fromCOO(int, Seq<Tuple2<Object, Object>>) - Method in class org.apache.flink.ml.math.SparseVector$
Constructs a sparse vector from a coordinate list (COO) representation where each entry is stored as a tuple of (index, value).
fromCOO(int, Iterable<Tuple2<Object, Object>>) - Method in class org.apache.flink.ml.math.SparseVector$
Constructs a sparse vector from a coordinate list (COO) representation where each entry is stored as a tuple of (index, value).
fromCOO(int, Tuple2<Object, Object>) - Method in class org.apache.flink.ml.math.SparseVector$
Convenience method to be able to instantiate a SparseVector with a single element.
fromCOO(int, Seq<Tuple2<Object, Object>>) - Static method in class org.apache.flink.ml.math.SparseVector
Constructs a sparse vector from a coordinate list (COO) representation where each entry is stored as a tuple of (index, value).
fromCOO(int, Iterable<Tuple2<Object, Object>>) - Static method in class org.apache.flink.ml.math.SparseVector
Constructs a sparse vector from a coordinate list (COO) representation where each entry is stored as a tuple of (index, value).
fromCOO(int, Tuple2<Object, Object>) - Static method in class org.apache.flink.ml.math.SparseVector
Convenience method to be able to instantiate a SparseVector with a single element.
fromCsvReader(String, String, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
Creates a Graph from a CSV file of vertices and a CSV file of edges.
fromCsvReader(String, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
Creates a graph from a CSV file of edges.
fromCsvReader(String, MapFunction<K, VV>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
Creates a graph from a CSV file of edges.
fromCsvReader(ExecutionEnvironment, String, String, String, String, Character, boolean, String, boolean, int[], String, String, Character, boolean, String, boolean, int[], MapFunction<K, VV>, TypeInformation<K>, ClassTag<K>, TypeInformation<VV>, ClassTag<VV>, TypeInformation<EV>, ClassTag<EV>) - Method in class org.apache.flink.graph.scala.Graph$
Creates a Graph from a CSV file of edges.
fromCsvReader(ExecutionEnvironment, String, String, String, String, Character, boolean, String, boolean, int[], String, String, Character, boolean, String, boolean, int[], MapFunction<K, VV>, TypeInformation<K>, ClassTag<K>, TypeInformation<VV>, ClassTag<VV>, TypeInformation<EV>, ClassTag<EV>) - Static method in class org.apache.flink.graph.scala.Graph
Creates a Graph from a CSV file of edges.
fromDataSet(DataSet<Vertex<KT, VVT>>, DataSet<Vertex<KB, VVB>>, DataSet<BipartiteEdge<KT, KB, EV>>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.bipartite.BipartiteGraph
Create bipartite graph from datasets.
fromDataSet(DataSet<Vertex<K, VV>>, DataSet<Edge<K, EV>>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
Creates a graph from a DataSet of vertices and a DataSet of edges.
fromDataSet(DataSet<Edge<K, EV>>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
Creates a graph from a DataSet of edges.
fromDataSet(DataSet<Edge<K, EV>>, MapFunction<K, VV>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
Creates a graph from a DataSet of edges.
fromDataSet(DataSet<Vertex<K, VV>>, DataSet<Edge<K, EV>>, ExecutionEnvironment, TypeInformation<K>, ClassTag<K>, TypeInformation<VV>, ClassTag<VV>, TypeInformation<EV>, ClassTag<EV>) - Method in class org.apache.flink.graph.scala.Graph$
Creates a Graph from a DataSet of vertices and a DataSet of edges.
fromDataSet(DataSet<Edge<K, EV>>, ExecutionEnvironment, TypeInformation<K>, ClassTag<K>, TypeInformation<EV>, ClassTag<EV>) - Method in class org.apache.flink.graph.scala.Graph$
Creates a Graph from a DataSet of edges.
fromDataSet(DataSet<Edge<K, EV>>, MapFunction<K, VV>, ExecutionEnvironment, TypeInformation<K>, ClassTag<K>, TypeInformation<VV>, ClassTag<VV>, TypeInformation<EV>, ClassTag<EV>) - Method in class org.apache.flink.graph.scala.Graph$
Creates a graph from a DataSet of edges.
fromDataSet(DataSet<Vertex<K, VV>>, DataSet<Edge<K, EV>>, ExecutionEnvironment, TypeInformation<K>, ClassTag<K>, TypeInformation<VV>, ClassTag<VV>, TypeInformation<EV>, ClassTag<EV>) - Static method in class org.apache.flink.graph.scala.Graph
Creates a Graph from a DataSet of vertices and a DataSet of edges.
fromDataSet(DataSet<Edge<K, EV>>, ExecutionEnvironment, TypeInformation<K>, ClassTag<K>, TypeInformation<EV>, ClassTag<EV>) - Static method in class org.apache.flink.graph.scala.Graph
Creates a Graph from a DataSet of edges.
fromDataSet(DataSet<Edge<K, EV>>, MapFunction<K, VV>, ExecutionEnvironment, TypeInformation<K>, ClassTag<K>, TypeInformation<VV>, ClassTag<VV>, TypeInformation<EV>, ClassTag<EV>) - Static method in class org.apache.flink.graph.scala.Graph
Creates a graph from a DataSet of edges.
fromDataSet(DataSet<T>) - Method in class org.apache.flink.table.api.java.BatchTableEnvironment
Converts the given DataSet into a Table.
fromDataSet(DataSet<T>, String) - Method in class org.apache.flink.table.api.java.BatchTableEnvironment
Converts the given DataSet into a Table with specified field names.
fromDataSet(DataSet<T>) - Method in class org.apache.flink.table.api.scala.BatchTableEnvironment
Converts the given DataSet into a Table.
fromDataSet(DataSet<T>, Seq<Expression>) - Method in class org.apache.flink.table.api.scala.BatchTableEnvironment
Converts the given DataSet into a Table with specified field names.
fromDataStream(DataStream<T>) - Method in class org.apache.flink.table.api.java.StreamTableEnvironment
Converts the given DataStream into a Table.
fromDataStream(DataStream<T>, String) - Method in class org.apache.flink.table.api.java.StreamTableEnvironment
Converts the given DataStream into a Table with specified field names.
fromDataStream(DataStream<T>) - Method in class org.apache.flink.table.api.scala.StreamTableEnvironment
Converts the given DataStream into a Table.
fromDataStream(DataStream<T>, Seq<Expression>) - Method in class org.apache.flink.table.api.scala.StreamTableEnvironment
Converts the given DataStream into a Table with specified field names.
fromDeque(ArrayDeque<Tuple2<Long, List<T>>>, TypeSerializer<T>) - Static method in class org.apache.flink.runtime.state.SerializedCheckpointData
Converts a list of checkpoints with elements into an array of SerializedCheckpointData.
fromDeque(ArrayDeque<Tuple2<Long, List<T>>>, TypeSerializer<T>, DataOutputSerializer) - Static method in class org.apache.flink.runtime.state.SerializedCheckpointData
Converts a list of checkpoints into an array of SerializedCheckpointData.
fromEdge(IntermediateResultPartition, Execution) - Static method in class org.apache.flink.runtime.deployment.PartialInputChannelDeploymentDescriptor
Creates a partial input channel for the given partition and producing task.
fromEdges(ExecutionEdge[], SimpleSlot, boolean) - Static method in class org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor
Creates an input channel deployment descriptor for each partition.
fromElements(X...) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a new data set that contains the given elements.
fromElements(Class<X>, X...) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a new data set that contains the given elements.
fromElements(Seq<T>, ClassTag<T>, TypeInformation<T>) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Creates a new data set that contains the given elements.
fromElements(OUT...) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a new data stream that contains the given elements.
fromElements(Class<OUT>, OUT...) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a new data set that contains the given elements.
fromElements(Seq<T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Creates a DataStream that contains the given elements.
FromElementsFunction<T> - Class in org.apache.flink.streaming.api.functions.source
A stream source function that returns a sequence of elements.
FromElementsFunction(TypeSerializer<T>, T...) - Constructor for class org.apache.flink.streaming.api.functions.source.FromElementsFunction
 
FromElementsFunction(TypeSerializer<T>, Iterable<T>) - Constructor for class org.apache.flink.streaming.api.functions.source.FromElementsFunction
 
fromEnvironment(Configuration) - Method in class org.apache.flink.runtime.clusterframework.overlays.FlinkDistributionOverlay.Builder
Configures the overlay using the current environment.
fromEnvironment(Configuration) - Method in class org.apache.flink.runtime.clusterframework.overlays.HadoopConfOverlay.Builder
Configures the overlay using the current environment's Hadoop configuration.
fromEnvironment(Configuration) - Method in class org.apache.flink.runtime.clusterframework.overlays.HadoopUserOverlay.Builder
Configures the overlay using the current Hadoop user information (from UserGroupInformation).
fromEnvironment(Configuration) - Method in class org.apache.flink.runtime.clusterframework.overlays.KeytabOverlay.Builder
Configures the overlay using the current environment (and global configuration).
fromEnvironment(Configuration) - Method in class org.apache.flink.runtime.clusterframework.overlays.Krb5ConfOverlay.Builder
Configures the overlay using the current environment.
fromEnvironment(Configuration) - Method in class org.apache.flink.runtime.clusterframework.overlays.SSLStoreOverlay.Builder
Configures the overlay using the current environment (and global configuration).
fromExternalCatalogTable(ExternalCatalogTable) - Method in class org.apache.flink.table.catalog.ExternalTableSourceUtil$
Converts an ExternalCatalogTable instance to a TableSourceTable instance
fromExternalCatalogTable(ExternalCatalogTable) - Static method in class org.apache.flink.table.catalog.ExternalTableSourceUtil
Converts an ExternalCatalogTable instance to a TableSourceTable instance
fromExternalCatalogTable(ExternalCatalogTable) - Method in interface org.apache.flink.table.catalog.TableSourceConverter
Creates a TableSource for the given ExternalCatalogTable.
fromExternalCatalogTable(ExternalCatalogTable) - Method in class org.apache.flink.table.sources.CsvTableSourceConverter
 
fromGauge(Gauge<?>) - Static method in class org.apache.flink.dropwizard.metrics.FlinkGaugeWrapper
 
fromGenericOptionsParser(String[]) - Static method in class org.apache.flink.api.java.utils.ParameterTool
Deprecated.
Please use HadoopUtils.paramsFromGenericOptionsParser(String[]) from project flink-hadoop-compatibility
fromHexString(String) - Static method in class org.apache.flink.api.common.JobID
 
fromHexString(String) - Static method in class org.apache.flink.runtime.jobgraph.JobVertexID
 
FromIteratorFunction<T> - Class in org.apache.flink.streaming.api.functions.source
A SourceFunction that reads elements from an Iterator and emits them.
FromIteratorFunction(Iterator<T>) - Constructor for class org.apache.flink.streaming.api.functions.source.FromIteratorFunction
 
fromJobSubmissionResult(JobSubmissionResult) - Static method in class org.apache.flink.api.common.JobExecutionResult
Deprecated.
Will be removed in future versions.
fromJobVertexID(JobVertexID) - Static method in class org.apache.flink.runtime.jobgraph.OperatorID
 
fromKeyValueJsonArray(String) - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorUtils
 
fromMap(Map<String, String>) - Static method in class org.apache.flink.api.java.utils.ParameterTool
Returns ParameterTool for the given map
fromParallelCollection(SplittableIterator<X>, Class<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a new data set that contains elements in the iterator.
fromParallelCollection(SplittableIterator<X>, TypeInformation<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a new data set that contains elements in the iterator.
fromParallelCollection(SplittableIterator<T>, ClassTag<T>, TypeInformation<T>) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Creates a new data set that contains elements in the iterator.
fromParallelCollection(SplittableIterator<OUT>, Class<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a new data stream that contains elements in the iterator.
fromParallelCollection(SplittableIterator<OUT>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a new data stream that contains elements in the iterator.
fromParallelCollection(SplittableIterator<T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Creates a DataStream from the given SplittableIterator.
fromPropertiesFile(String) - Static method in class org.apache.flink.api.java.utils.ParameterTool
Returns ParameterTool for the given Properties file
fromPropertiesFile(File) - Static method in class org.apache.flink.api.java.utils.ParameterTool
Returns ParameterTool for the given Properties file.
fromPropertiesFile(InputStream) - Static method in class org.apache.flink.api.java.utils.ParameterTool
Returns ParameterTool for the given InputStream from Properties file.
fromRawEvent(long, String, String) - Static method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
 
fromSerializedEvent(ByteBuffer, ClassLoader) - Static method in class org.apache.flink.runtime.io.network.api.serialization.EventSerializer
 
FromSplittableIteratorFunction<T> - Class in org.apache.flink.streaming.api.functions.source
A SourceFunction that reads elements from an SplittableIterator and emits them.
FromSplittableIteratorFunction(SplittableIterator<T>) - Constructor for class org.apache.flink.streaming.api.functions.source.FromSplittableIteratorFunction
 
fromString(String) - Static method in class org.apache.flink.cep.nfa.DeweyNumber
Creates a dewey number from a string representation.
fromSystemProperties() - Static method in class org.apache.flink.api.java.utils.ParameterTool
Returns ParameterTool from the system properties.
fromTuple2DataSet(DataSet<Tuple2<K, K>>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
Creates a graph from a DataSet of Tuple2 objects for edges.
fromTuple2DataSet(DataSet<Tuple2<K, K>>, MapFunction<K, VV>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
Creates a graph from a DataSet of Tuple2 objects for edges.
fromTuple2DataSet(DataSet<Tuple2<K, K>>, ExecutionEnvironment, TypeInformation<K>, ClassTag<K>) - Method in class org.apache.flink.graph.scala.Graph$
Creates a Graph from a DataSet of Tuple2's representing the edges.
fromTuple2DataSet(DataSet<Tuple2<K, K>>, MapFunction<K, VV>, ExecutionEnvironment, TypeInformation<K>, ClassTag<K>, TypeInformation<VV>, ClassTag<VV>) - Method in class org.apache.flink.graph.scala.Graph$
Creates a Graph from a DataSet of Tuple2's representing the edges.
fromTuple2DataSet(DataSet<Tuple2<K, K>>, ExecutionEnvironment, TypeInformation<K>, ClassTag<K>) - Static method in class org.apache.flink.graph.scala.Graph
Creates a Graph from a DataSet of Tuple2's representing the edges.
fromTuple2DataSet(DataSet<Tuple2<K, K>>, MapFunction<K, VV>, ExecutionEnvironment, TypeInformation<K>, ClassTag<K>, TypeInformation<VV>, ClassTag<VV>) - Static method in class org.apache.flink.graph.scala.Graph
Creates a Graph from a DataSet of Tuple2's representing the edges.
fromTupleDataSet(DataSet<Tuple2<K, VV>>, DataSet<Tuple3<K, K, EV>>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
Creates a graph from a DataSet of Tuple2 objects for vertices and Tuple3 objects for edges.
fromTupleDataSet(DataSet<Tuple3<K, K, EV>>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
Creates a graph from a DataSet of Tuple3 objects for edges.
fromTupleDataSet(DataSet<Tuple3<K, K, EV>>, MapFunction<K, VV>, ExecutionEnvironment) - Static method in class org.apache.flink.graph.Graph
Creates a graph from a DataSet of Tuple3 objects for edges.
fromTupleDataSet(DataSet<Tuple2<K, VV>>, DataSet<Tuple3<K, K, EV>>, ExecutionEnvironment, TypeInformation<K>, ClassTag<K>, TypeInformation<VV>, ClassTag<VV>, TypeInformation<EV>, ClassTag<EV>) - Method in class org.apache.flink.graph.scala.Graph$
Creates a graph from DataSets of tuples for vertices and for edges.
fromTupleDataSet(DataSet<Tuple3<K, K, EV>>, ExecutionEnvironment, TypeInformation<K>, ClassTag<K>, TypeInformation<EV>, ClassTag<EV>) - Method in class org.apache.flink.graph.scala.Graph$
Creates a Graph from a DataSet of Tuples representing the edges.
fromTupleDataSet(DataSet<Tuple3<K, K, EV>>, MapFunction<K, VV>, ExecutionEnvironment, TypeInformation<K>, ClassTag<K>, TypeInformation<VV>, ClassTag<VV>, TypeInformation<EV>, ClassTag<EV>) - Method in class org.apache.flink.graph.scala.Graph$
Creates a Graph from a DataSet of Tuples representing the edges.
fromTupleDataSet(DataSet<Tuple2<K, VV>>, DataSet<Tuple3<K, K, EV>>, ExecutionEnvironment, TypeInformation<K>, ClassTag<K>, TypeInformation<VV>, ClassTag<VV>, TypeInformation<EV>, ClassTag<EV>) - Static method in class org.apache.flink.graph.scala.Graph
Creates a graph from DataSets of tuples for vertices and for edges.
fromTupleDataSet(DataSet<Tuple3<K, K, EV>>, ExecutionEnvironment, TypeInformation<K>, ClassTag<K>, TypeInformation<EV>, ClassTag<EV>) - Static method in class org.apache.flink.graph.scala.Graph
Creates a Graph from a DataSet of Tuples representing the edges.
fromTupleDataSet(DataSet<Tuple3<K, K, EV>>, MapFunction<K, VV>, ExecutionEnvironment, TypeInformation<K>, ClassTag<K>, TypeInformation<VV>, ClassTag<VV>, TypeInformation<EV>, ClassTag<EV>) - Static method in class org.apache.flink.graph.scala.Graph
Creates a Graph from a DataSet of Tuples representing the edges.
FrontMetricGroup<P extends AbstractMetricGroup<?>> - Class in org.apache.flink.runtime.metrics.groups
Metric group which forwards all registration calls to a variable parent metric group that injects a variable reporter index into calls to MetricGroup.getMetricIdentifier(String) or MetricGroup.getMetricIdentifier(String, CharacterFilter).
FrontMetricGroup(int, P) - Constructor for class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
 
FS_STATE_BACKEND_NAME - Static variable in class org.apache.flink.runtime.state.AbstractStateBackend
The shortcut configuration name for the FileSystem State backend
FS_STREAM_OPENING_TIMEOUT_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
The config parameter defining the timeout for filesystem stream opening.
FsCheckpointStateOutputStream(Path, FileSystem, int, int) - Constructor for class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
 
FsCheckpointStreamFactory - Class in org.apache.flink.runtime.state.filesystem
CheckpointStreamFactory that produces streams that write to a FileSystem.
FsCheckpointStreamFactory(Path, JobID, int) - Constructor for class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory
Creates a new state backend that stores its checkpoint data in the file system and location defined by the given URI.
FsCheckpointStreamFactory.FsCheckpointStateOutputStream - Class in org.apache.flink.runtime.state.filesystem
A CheckpointStreamFactory.CheckpointStateOutputStream that writes into a file and returns a StreamStateHandle upon closing.
FSDataInputStream - Class in org.apache.flink.core.fs
Interface for a data input stream to a file on a FileSystem.
FSDataInputStream() - Constructor for class org.apache.flink.core.fs.FSDataInputStream
 
FSDataInputStreamWrapper - Class in org.apache.flink.api.avro
Code copy pasted from org.apache.avro.mapred.FSInput (which is Apache licensed as well) The wrapper keeps track of the position in the data stream.
FSDataInputStreamWrapper(FSDataInputStream, long) - Constructor for class org.apache.flink.api.avro.FSDataInputStreamWrapper
 
FSDataInputStreamWrapper - Class in org.apache.flink.core.fs
Simple forwarding wrapper around FSDataInputStream
FSDataInputStreamWrapper(FSDataInputStream) - Constructor for class org.apache.flink.core.fs.FSDataInputStreamWrapper
 
FSDataOutputStream - Class in org.apache.flink.core.fs
An output stream to a file that is created via a FileSystem.
FSDataOutputStream() - Constructor for class org.apache.flink.core.fs.FSDataOutputStream
 
FSDataOutputStreamWrapper - Class in org.apache.flink.core.fs
Simple forwarding wrapper around FSDataInputStream
FSDataOutputStreamWrapper(FSDataOutputStream) - Constructor for class org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
FsFoldingState<K,N,T,ACC> - Class in org.apache.flink.migration.runtime.state.filesystem
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
FsFoldingState() - Constructor for class org.apache.flink.migration.runtime.state.filesystem.FsFoldingState
Deprecated.
 
FsFoldingState.Snapshot<K,N,T,ACC> - Class in org.apache.flink.migration.runtime.state.filesystem
Deprecated.
 
FsJobArchivist - Class in org.apache.flink.runtime.history
Utility class for writing an archive file to a FileSystem and reading it back.
FsListState<K,N,V> - Class in org.apache.flink.migration.runtime.state.filesystem
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
FsListState() - Constructor for class org.apache.flink.migration.runtime.state.filesystem.FsListState
Deprecated.
 
FsListState.Snapshot<K,N,V> - Class in org.apache.flink.migration.runtime.state.filesystem
Deprecated.
 
FsNegativeRunningJobsRegistry - Class in org.apache.flink.runtime.highavailability
This RunningJobsRegistry tracks the status jobs via marker files, marking running jobs viarunning marker files, marking finished jobs via finished marker files.
FsNegativeRunningJobsRegistry(Path) - Constructor for class org.apache.flink.runtime.highavailability.FsNegativeRunningJobsRegistry
Creates a new registry that writes to the FileSystem and working directory denoted by the given path.
FsNegativeRunningJobsRegistry(FileSystem, Path) - Constructor for class org.apache.flink.runtime.highavailability.FsNegativeRunningJobsRegistry
Creates a new registry that writes its files to the given FileSystem at the given working directory path.
FsReducingState<K,N,V> - Class in org.apache.flink.migration.runtime.state.filesystem
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
FsReducingState() - Constructor for class org.apache.flink.migration.runtime.state.filesystem.FsReducingState
Deprecated.
 
FsReducingState.Snapshot<K,N,V> - Class in org.apache.flink.migration.runtime.state.filesystem
Deprecated.
 
FsSavepointStreamFactory - Class in org.apache.flink.runtime.state.filesystem
A CheckpointStreamFactory that produces streams that write to a FileSystem.
FsSavepointStreamFactory(Path, JobID, int) - Constructor for class org.apache.flink.runtime.state.filesystem.FsSavepointStreamFactory
 
FsStateBackend - Class in org.apache.flink.migration.runtime.state.filesystem
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
FsStateBackend() - Constructor for class org.apache.flink.migration.runtime.state.filesystem.FsStateBackend
Deprecated.
 
FsStateBackend - Class in org.apache.flink.runtime.state.filesystem
The file state backend is a state backend that stores the state of streaming jobs in a file system.
FsStateBackend(String) - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackend
Creates a new state backend that stores its checkpoint data in the file system and location defined by the given URI.
FsStateBackend(String, boolean) - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackend
Creates a new state backend that stores its checkpoint data in the file system and location defined by the given URI.
FsStateBackend(Path) - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackend
Creates a new state backend that stores its checkpoint data in the file system and location defined by the given URI.
FsStateBackend(Path, boolean) - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackend
Creates a new state backend that stores its checkpoint data in the file system and location defined by the given URI.
FsStateBackend(URI) - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackend
Creates a new state backend that stores its checkpoint data in the file system and location defined by the given URI.
FsStateBackend(URI, boolean) - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackend
Creates a new state backend that stores its checkpoint data in the file system and location defined by the given URI.
FsStateBackend(URI, int) - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackend
Creates a new state backend that stores its checkpoint data in the file system and location defined by the given URI.
FsStateBackend(URI, int, boolean) - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackend
Creates a new state backend that stores its checkpoint data in the file system and location defined by the given URI.
FsStateBackendFactory - Class in org.apache.flink.runtime.state.filesystem
A factory that creates an FsStateBackend from a configuration.
FsStateBackendFactory() - Constructor for class org.apache.flink.runtime.state.filesystem.FsStateBackendFactory
 
FsValueState<K,N,V> - Class in org.apache.flink.migration.runtime.state.filesystem
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
FsValueState() - Constructor for class org.apache.flink.migration.runtime.state.filesystem.FsValueState
Deprecated.
 
FsValueState.Snapshot<K,N,V> - Class in org.apache.flink.migration.runtime.state.filesystem
Deprecated.
 
FULL_RESTART_STRATEGY_NAME - Static variable in class org.apache.flink.runtime.executiongraph.failover.FailoverStrategyLoader
Config name for the RestartAllStrategy
fullOuterJoin(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
Initiates a Full Outer Join transformation.
An Outer Join transformation joins two elements of two DataSets on key equality and provides multiple ways to combine joining elements into one DataSet.
Elements of both DataSets that do not have a matching element on the opposing side are joined with null and emitted to the resulting DataSet.
fullOuterJoin(DataSet<R>, JoinOperatorBase.JoinHint) - Method in class org.apache.flink.api.java.DataSet
Initiates a Full Outer Join transformation.
An Outer Join transformation joins two elements of two DataSets on key equality and provides multiple ways to combine joining elements into one DataSet.
Elements of both DataSets that do not have a matching element on the opposing side are joined with null and emitted to the resulting DataSet.
fullOuterJoin(DataSet<O>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
fullOuterJoin(DataSet<O>, JoinOperatorBase.JoinHint) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
fullOuterJoin(DataSet<O>) - Method in class org.apache.flink.api.scala.DataSet
Creates a new DataSet by performing a full outer join of this DataSet with the other DataSet, by combining two elements of two DataSets on key equality.
fullOuterJoin(DataSet<O>, JoinOperatorBase.JoinHint) - Method in class org.apache.flink.api.scala.DataSet
Special fullOuterJoin operation for explicitly telling the system what join strategy to use.
fullOuterJoin(Table, String) - Method in class org.apache.flink.table.api.Table
Joins two Tables.
fullOuterJoin(Table, Expression) - Method in class org.apache.flink.table.api.Table
Joins two Tables.
FullOuterJoinDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
The full outer join driver implements the logic of an outer join operator at runtime.
FullOuterJoinDriver() - Constructor for class org.apache.flink.runtime.operators.FullOuterJoinDriver
 
FullTypeInfo(Class<?>, ReflectionUtil.FullTypeInfo[]) - Constructor for class org.apache.flink.util.ReflectionUtil.FullTypeInfo
 
function - Variable in class org.apache.calcite.sql.validate.SqlUserDefinedAggFunction
 
Function - Interface in org.apache.flink.api.common.functions
The base interface for all user-defined functions.
function - Variable in class org.apache.flink.api.java.operators.FilterOperator
 
function - Variable in class org.apache.flink.api.java.operators.FlatMapOperator
 
function - Variable in class org.apache.flink.api.java.operators.MapOperator
 
function - Variable in class org.apache.flink.api.java.operators.MapPartitionOperator
 
function - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
function() - Method in class org.apache.flink.table.runtime.aggregate.DataSetSlideWindowAggReduceGroupFunction
 
function() - Method in class org.apache.flink.table.runtime.aggregate.DataSetTumbleTimeWindowAggReduceGroupFunction
 
function() - Method in class org.apache.flink.table.runtime.aggregate.RowTimeUnboundedOver
 
function() - Method in class org.apache.flink.table.runtime.MapSideJoinRunner
 
FunctionAnnotation - Class in org.apache.flink.api.java.functions
This class defines Java annotations for semantic assertions that can be added to Flink functions.
FunctionAnnotation.ForwardedFields - Annotation Type in org.apache.flink.api.java.functions
The ForwardedFields annotation declares fields which are never modified by the annotated function and which are forwarded at the same position to the output or unchanged copied to another position in the output.
FunctionAnnotation.ForwardedFieldsFirst - Annotation Type in org.apache.flink.api.java.functions
The ForwardedFieldsFirst annotation declares fields of the first input of a function which are never modified by the annotated function and which are forwarded at the same position to the output or unchanged copied to another position in the output.
FunctionAnnotation.ForwardedFieldsSecond - Annotation Type in org.apache.flink.api.java.functions
The ForwardedFieldsSecond annotation declares fields of the second input of a function which are never modified by the annotated function and which are forwarded at the same position to the output or unchanged copied to another position in the output.
FunctionAnnotation.NonForwardedFields - Annotation Type in org.apache.flink.api.java.functions
The NonForwardedFields annotation declares ALL fields which not preserved on the same position in a functions output.
FunctionAnnotation.NonForwardedFieldsFirst - Annotation Type in org.apache.flink.api.java.functions
The NonForwardedFieldsFirst annotation declares for a function ALL fields of its first input which are not preserved on the same position in its output.
FunctionAnnotation.NonForwardedFieldsSecond - Annotation Type in org.apache.flink.api.java.functions
The NonForwardedFieldsSecond annotation declares for a function ALL fields of its second input which are not preserved on the same position in its output.
FunctionAnnotation.ReadFields - Annotation Type in org.apache.flink.api.java.functions
The ReadFields annotation declares for a function all fields which it accesses and evaluates, i.e., all fields that are used by the function to compute its result.
FunctionAnnotation.ReadFieldsFirst - Annotation Type in org.apache.flink.api.java.functions
The ReadFieldsFirst annotation declares for a function all fields of the first input which it accesses and evaluates, i.e., all fields of the first input that are used by the function to compute its result.
FunctionAnnotation.ReadFieldsSecond - Annotation Type in org.apache.flink.api.java.functions
The ReadFieldsSecond annotation declares for a function all fields of the second input which it accesses and evaluates, i.e., all fields of the second input that are used by the function to compute its result.
FunctionAnnotation.SkipCodeAnalysis - Annotation Type in org.apache.flink.api.java.functions
The SkipCodeAnalysis annotation declares that a function will not be analyzed by Flink's code analysis capabilities independent of the configured CodeAnalysisMode.
functionCatalog() - Method in class org.apache.flink.table.api.TableEnvironment
 
FunctionCatalog - Class in org.apache.flink.table.validate
A catalog for looking up (user-defined) functions, used during validation phases of both Table API and SQL API.
FunctionCatalog() - Constructor for class org.apache.flink.table.validate.FunctionCatalog
 
FunctionCatalog$ - Class in org.apache.flink.table.validate
 
FunctionCatalog$() - Constructor for class org.apache.flink.table.validate.FunctionCatalog$
 
FunctionContext - Class in org.apache.flink.table.functions
A FunctionContext allows to obtain global runtime information about the context in which the user-defined function is executed.
FunctionContext(RuntimeContext) - Constructor for class org.apache.flink.table.functions.FunctionContext
 
FunctionGenerator - Class in org.apache.flink.table.codegen.calls
Global hub for user-defined and built-in advanced SQL functions.
FunctionGenerator() - Constructor for class org.apache.flink.table.codegen.calls.FunctionGenerator
 
FunctionGenerator$ - Class in org.apache.flink.table.codegen.calls
Global hub for user-defined and built-in advanced SQL functions.
FunctionGenerator$() - Constructor for class org.apache.flink.table.codegen.calls.FunctionGenerator$
 
functionIdent() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
functionIdent() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
functionIdentifier() - Method in class org.apache.flink.table.functions.UserDefinedFunction
 
FunctionInitializationContext - Interface in org.apache.flink.runtime.state
This interface provides a context in which user functions can initialize by registering to managed state (i.e.
functionName() - Method in class org.apache.flink.table.expressions.Call
 
functionName() - Method in class org.apache.flink.table.expressions.TableFunctionCall
 
functionName() - Method in class org.apache.flink.table.plan.logical.LogicalTableFunctionCall
 
FunctionSnapshotContext - Interface in org.apache.flink.runtime.state
This interface provides a context in which user functions that use managed state (i.e.
FunctionUtils - Class in org.apache.flink.api.common.functions.util
Utility class that contains helper methods to work with Flink Function class.
furtherPartitioning - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
 
furtherPartitioning - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
FUSION - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The FUSION operator.
Future<T> - Interface in org.apache.flink.runtime.concurrent
Flink's basic future abstraction.
future() - Method in class org.apache.flink.runtime.minicluster.OneTimeLeaderListenerFuture
Gets the future that is completed with the leader address and ID.
futureExecutor() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
futureExecutor() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
futureLock() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
Future lock
futuresToComplete() - Method in class org.apache.flink.runtime.jobmanager.JobManager
Futures which have to be completed before terminating the job manager
FutureUtil - Class in org.apache.flink.util
 
FutureUtils - Class in org.apache.flink.runtime.concurrent
A collection of utilities that expand the usage of Future and CompletableFuture.
FutureUtils() - Constructor for class org.apache.flink.runtime.concurrent.FutureUtils
 
FutureUtils.ConjunctFuture<T> - Interface in org.apache.flink.runtime.concurrent
A future that is complete once multiple other futures completed.
FutureUtils.RetryException - Exception in org.apache.flink.runtime.concurrent
 

G

GangliaReporter - Class in org.apache.flink.metrics.ganglia
 
GangliaReporter() - Constructor for class org.apache.flink.metrics.ganglia.GangliaReporter
 
gap() - Method in class org.apache.flink.table.plan.logical.SessionGroupWindow
 
garbageCollectorNames - Variable in class org.apache.flink.runtime.webmonitor.metrics.MetricStore.TaskManagerMetricStore
 
gather(Neighbor<VV, EV>) - Method in class org.apache.flink.graph.gsa.GatherFunction
This method is invoked once per superstep, for each Neighbor of each Vertex in the beginning of each superstep in a GatherSumApplyIteration.
GATHER_DURATION() - Method in class org.apache.flink.mesos.scheduler.LaunchCoordinator$
 
GATHER_DURATION() - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
GatherData(Seq<LaunchableTask>, Seq<VirtualMachineLease>) - Constructor for class org.apache.flink.mesos.scheduler.LaunchCoordinator.GatherData
 
GatherData$() - Constructor for class org.apache.flink.mesos.scheduler.LaunchCoordinator.GatherData$
 
GatherFunction<VV,EV,M> - Class in org.apache.flink.graph.gsa
The base class for the first step of a GatherSumApplyIteration.
GatherFunction() - Constructor for class org.apache.flink.graph.gsa.GatherFunction
 
GatherFunction<K,VV,Message> - Class in org.apache.flink.graph.spargel
This class must be extended by functions that compute the state of the vertex depending on the old state and the incoming messages.
GatherFunction() - Constructor for class org.apache.flink.graph.spargel.GatherFunction
 
GatheringOffers$() - Constructor for class org.apache.flink.mesos.scheduler.LaunchCoordinator.GatheringOffers$
 
gatherOrderExprs(SqlToRelConverter.Blackboard, SqlSelect, SqlNodeList, List<SqlNode>, List<RelFieldCollation>) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Creates a list of collations required to implement the ORDER BY clause, if there is one.
GatherSumApplyIteration<K,VV,EV,M> - Class in org.apache.flink.graph.gsa
This class represents iterative graph computations, programmed in a gather-sum-apply perspective.
Gauge<T> - Interface in org.apache.flink.metrics
A Gauge is a Metric that calculates a specific value at a point in time.
gauge(int, G) - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
 
gauge(String, G) - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
 
gauge(int, G) - Method in interface org.apache.flink.metrics.MetricGroup
Registers a new Gauge with Flink.
gauge(String, G) - Method in interface org.apache.flink.metrics.MetricGroup
Registers a new Gauge with Flink.
gauge(int, G) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
gauge(String, G) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
gauge(int, G) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
gauge(String, G) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
GaugeDump(QueryScopeInfo, String, String) - Constructor for class org.apache.flink.runtime.metrics.dump.MetricDump.GaugeDump
 
gauges - Variable in class org.apache.flink.metrics.reporter.AbstractReporter
 
generate() - Static method in class org.apache.flink.api.common.JobID
Creates a new (statistically) random JobID.
generate(ExecutionEnvironment) - Method in class org.apache.flink.graph.drivers.input.CirculantGraph
 
generate(ExecutionEnvironment) - Method in class org.apache.flink.graph.drivers.input.CompleteGraph
 
generate(ExecutionEnvironment) - Method in class org.apache.flink.graph.drivers.input.CycleGraph
 
generate(ExecutionEnvironment) - Method in class org.apache.flink.graph.drivers.input.EchoGraph
 
generate(ExecutionEnvironment) - Method in class org.apache.flink.graph.drivers.input.EmptyGraph
 
generate(ExecutionEnvironment) - Method in class org.apache.flink.graph.drivers.input.GeneratedGraph
Generate the graph as configured.
generate(ExecutionEnvironment) - Method in class org.apache.flink.graph.drivers.input.GridGraph
 
generate(ExecutionEnvironment) - Method in class org.apache.flink.graph.drivers.input.HypercubeGraph
 
generate(ExecutionEnvironment) - Method in class org.apache.flink.graph.drivers.input.PathGraph
 
generate(ExecutionEnvironment) - Method in class org.apache.flink.graph.drivers.input.RMatGraph
Generate the graph as configured.
generate(ExecutionEnvironment) - Method in class org.apache.flink.graph.drivers.input.SingletonEdgeGraph
 
generate(ExecutionEnvironment) - Method in class org.apache.flink.graph.drivers.input.StarGraph
 
generate() - Method in class org.apache.flink.graph.generator.CirculantGraph
 
generate() - Method in class org.apache.flink.graph.generator.CompleteGraph
 
generate() - Method in class org.apache.flink.graph.generator.CycleGraph
 
generate() - Method in class org.apache.flink.graph.generator.EchoGraph
 
generate() - Method in class org.apache.flink.graph.generator.EmptyGraph
 
generate() - Method in interface org.apache.flink.graph.generator.GraphGenerator
Generates the configured graph.
generate() - Method in class org.apache.flink.graph.generator.GridGraph
 
generate() - Method in class org.apache.flink.graph.generator.HypercubeGraph
 
generate() - Method in class org.apache.flink.graph.generator.PathGraph
 
generate() - Method in class org.apache.flink.graph.generator.RMatGraph
 
generate() - Method in class org.apache.flink.graph.generator.SingletonEdgeGraph
 
generate() - Method in class org.apache.flink.graph.generator.StarGraph
 
generate() - Static method in class org.apache.flink.runtime.clusterframework.types.ResourceID
Generate a random resource id.
generate(StreamExecutionEnvironment, List<StreamTransformation<?>>) - Static method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
Generates a StreamGraph by traversing the graph of StreamTransformations starting from the given transformations.
generate(CodeGenerator, Seq<GeneratedExpression>) - Method in interface org.apache.flink.table.codegen.calls.CallGenerator
 
generate(CodeGenerator, Seq<GeneratedExpression>) - Method in class org.apache.flink.table.codegen.calls.ConstantCallGen
 
generate(CodeGenerator, Seq<GeneratedExpression>) - Method in class org.apache.flink.table.codegen.calls.CurrentTimePointCallGen
 
generate(CodeGenerator, Seq<GeneratedExpression>) - Method in class org.apache.flink.table.codegen.calls.FloorCeilCallGen
 
generate(CodeGenerator, Seq<GeneratedExpression>) - Method in class org.apache.flink.table.codegen.calls.MethodCallGen
 
generate(CodeGenerator, Seq<GeneratedExpression>) - Method in class org.apache.flink.table.codegen.calls.MultiTypeMethodCallGen
 
generate(CodeGenerator, Seq<GeneratedExpression>) - Method in class org.apache.flink.table.codegen.calls.NotCallGenerator
 
generate(CodeGenerator, Seq<GeneratedExpression>) - Method in class org.apache.flink.table.codegen.calls.ScalarFunctionCallGen
 
generate(CodeGenerator, Seq<GeneratedExpression>) - Method in class org.apache.flink.table.codegen.calls.TableFunctionCallGen
 
generate(CodeGenerator, Seq<GeneratedExpression>) - Method in class org.apache.flink.table.codegen.calls.TrimCallGen
 
generateAggregations(String, CodeGenerator, Seq<TypeInformation<?>>, AggregateFunction<?, ?>[], int[][], int[], boolean, int[], Option<int[]>, Option<Tuple2<Object, Object>[]>, int, boolean, boolean, boolean) - Method in class org.apache.flink.table.codegen.CodeGenerator
Generates a GeneratedAggregations that can be passed to a Java compiler.
generateAnd(boolean, GeneratedExpression, GeneratedExpression) - Method in class org.apache.flink.table.codegen.calls.ScalarOperators$
 
generateAnd(boolean, GeneratedExpression, GeneratedExpression) - Static method in class org.apache.flink.table.codegen.calls.ScalarOperators
 
generateArithmeticOperator(String, boolean, TypeInformation<?>, GeneratedExpression, GeneratedExpression) - Method in class org.apache.flink.table.codegen.calls.ScalarOperators$
 
generateArithmeticOperator(String, boolean, TypeInformation<?>, GeneratedExpression, GeneratedExpression) - Static method in class org.apache.flink.table.codegen.calls.ScalarOperators
 
generateArray(CodeGenerator, TypeInformation<?>, Seq<GeneratedExpression>) - Method in class org.apache.flink.table.codegen.calls.ScalarOperators$
 
generateArray(CodeGenerator, TypeInformation<?>, Seq<GeneratedExpression>) - Static method in class org.apache.flink.table.codegen.calls.ScalarOperators
 
generateArrayCardinality(boolean, GeneratedExpression) - Method in class org.apache.flink.table.codegen.calls.ScalarOperators$
 
generateArrayCardinality(boolean, GeneratedExpression) - Static method in class org.apache.flink.table.codegen.calls.ScalarOperators
 
generateArrayElement(CodeGenerator, GeneratedExpression) - Method in class org.apache.flink.table.codegen.calls.ScalarOperators$
 
generateArrayElement(CodeGenerator, GeneratedExpression) - Static method in class org.apache.flink.table.codegen.calls.ScalarOperators
 
generateArrayElementAt(CodeGenerator, GeneratedExpression, GeneratedExpression) - Method in class org.apache.flink.table.codegen.calls.ScalarOperators$
 
generateArrayElementAt(CodeGenerator, GeneratedExpression, GeneratedExpression) - Static method in class org.apache.flink.table.codegen.calls.ScalarOperators
 
generateCallIfArgsNotNull(boolean, TypeInformation<?>, Seq<GeneratedExpression>, Function1<Seq<String>, String>) - Method in class org.apache.flink.table.codegen.calls.CallGenerator$
 
generateCast(boolean, GeneratedExpression, TypeInformation<?>) - Method in class org.apache.flink.table.codegen.calls.ScalarOperators$
 
generateCast(boolean, GeneratedExpression, TypeInformation<?>) - Static method in class org.apache.flink.table.codegen.calls.ScalarOperators
 
generateCollector(TableConfig, RowSchema, TypeInformation<Object>, RowSchema, Option<RexNode>, Option<int[]>) - Method in interface org.apache.flink.table.plan.nodes.CommonCorrelate
Generates table function collector.
generateComparison(String, boolean, GeneratedExpression, GeneratedExpression) - Method in class org.apache.flink.table.codegen.calls.ScalarOperators$
Generates comparison code for numeric types and comparable types of same type.
generateComparison(String, boolean, GeneratedExpression, GeneratedExpression) - Static method in class org.apache.flink.table.codegen.calls.ScalarOperators
Generates comparison code for numeric types and comparable types of same type.
generateConfiguration(Configuration) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
generateConfiguration(Configuration) - Method in class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
generateConfiguration() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
generateConverterResultExpression(TypeInformation<?>, Seq<String>) - Method in class org.apache.flink.table.codegen.CodeGenerator
Generates an expression that converts the first input (and second input) into the given type.
generateCorrelateAccessExprs() - Method in class org.apache.flink.table.codegen.CodeGenerator
Generates an expression from the left input and the right table function.
GeneratedAggregations - Class in org.apache.flink.table.runtime.aggregate
Base class for code-generated aggregations.
GeneratedAggregations() - Constructor for class org.apache.flink.table.runtime.aggregate.GeneratedAggregations
 
GeneratedAggregationsFunction - Class in org.apache.flink.table.codegen
Describes a generated aggregate helper function
GeneratedAggregationsFunction(String, String) - Constructor for class org.apache.flink.table.codegen.GeneratedAggregationsFunction
 
GeneratedAggregationsFunction$ - Class in org.apache.flink.table.codegen
 
GeneratedAggregationsFunction$() - Constructor for class org.apache.flink.table.codegen.GeneratedAggregationsFunction$
 
GeneratedCollector - Class in org.apache.flink.table.codegen
Describes a generated Collector.
GeneratedCollector(String, String) - Constructor for class org.apache.flink.table.codegen.GeneratedCollector
 
GeneratedCollector$ - Class in org.apache.flink.table.codegen
 
GeneratedCollector$() - Constructor for class org.apache.flink.table.codegen.GeneratedCollector$
 
generatedConversionFunction(TableConfig, Class<F>, TypeInformation<Object>, TypeInformation<Row>, String, Seq<String>, Option<int[]>) - Method in interface org.apache.flink.table.plan.nodes.CommonScan
 
GeneratedExpression - Class in org.apache.flink.table.codegen
Describes a generated expression.
GeneratedExpression(String, String, String, TypeInformation<?>) - Constructor for class org.apache.flink.table.codegen.GeneratedExpression
 
GeneratedExpression$ - Class in org.apache.flink.table.codegen
 
GeneratedExpression$() - Constructor for class org.apache.flink.table.codegen.GeneratedExpression$
 
GeneratedFunction<F extends Function,T> - Class in org.apache.flink.table.codegen
Describes a generated functions.Function
GeneratedFunction(String, TypeInformation<T>, String) - Constructor for class org.apache.flink.table.codegen.GeneratedFunction
 
GeneratedFunction$ - Class in org.apache.flink.table.codegen
 
GeneratedFunction$() - Constructor for class org.apache.flink.table.codegen.GeneratedFunction$
 
GeneratedGraph<K> - Class in org.apache.flink.graph.drivers.input
Base class for generated graphs.
GeneratedGraph() - Constructor for class org.apache.flink.graph.drivers.input.GeneratedGraph
 
GeneratedInput<F extends InputFormat<?,?>,T> - Class in org.apache.flink.table.codegen
Describes a generated InputFormat.
GeneratedInput(String, TypeInformation<T>, String) - Constructor for class org.apache.flink.table.codegen.GeneratedInput
 
GeneratedInput$ - Class in org.apache.flink.table.codegen
 
GeneratedInput$() - Constructor for class org.apache.flink.table.codegen.GeneratedInput$
 
GeneratedMultiGraph<K extends Comparable<K>> - Class in org.apache.flink.graph.drivers.input
Base class for graph generators which may create duplicate edges.
GeneratedMultiGraph() - Constructor for class org.apache.flink.graph.drivers.input.GeneratedMultiGraph
 
generateEquals(boolean, GeneratedExpression, GeneratedExpression) - Method in class org.apache.flink.table.codegen.calls.ScalarOperators$
 
generateEquals(boolean, GeneratedExpression, GeneratedExpression) - Static method in class org.apache.flink.table.codegen.calls.ScalarOperators
 
generateExpression(RexNode) - Method in class org.apache.flink.table.codegen.CodeGenerator
Generates an expression from a RexNode.
generateFullMatrix(double[], double[], int) - Method in class org.apache.flink.ml.recommendation.ALS$
 
generateFullMatrix(double[], double[], int) - Static method in class org.apache.flink.ml.recommendation.ALS
 
generateFunction(String, Class<F>, String, TypeInformation<T>) - Method in class org.apache.flink.table.codegen.CodeGenerator
Generates a Function that can be passed to Java compiler.
generateFunction(CodeGenerator, String, RowSchema, RowSchema, RexProgram, TableConfig, Class<T>) - Method in interface org.apache.flink.table.plan.nodes.CommonCalc
 
generateFunction(TableConfig, RowSchema, TypeInformation<Object>, RowSchema, SemiJoinType, RexCall, Option<int[]>, String, Class<T>) - Method in interface org.apache.flink.table.plan.nodes.CommonCorrelate
Generates the flat map function to run the user-defined table function.
generateFunction(CodeGenerator, String, RowSchema, RowSchema, RexProgram, TableConfig, Class<T>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
generateIfElse(boolean, Seq<GeneratedExpression>, TypeInformation<?>, int) - Method in class org.apache.flink.table.codegen.calls.ScalarOperators$
 
generateIfElse(boolean, Seq<GeneratedExpression>, TypeInformation<?>, int) - Static method in class org.apache.flink.table.codegen.calls.ScalarOperators
 
generateInputFieldUnboxing(TypeInformation<?>, String) - Method in class org.apache.flink.table.codegen.CodeGenerator
Converts the external boxed format to an internal mostly primitive field representation.
generateIsFalse(GeneratedExpression) - Method in class org.apache.flink.table.codegen.calls.ScalarOperators$
 
generateIsFalse(GeneratedExpression) - Static method in class org.apache.flink.table.codegen.calls.ScalarOperators
 
generateIsNotFalse(GeneratedExpression) - Method in class org.apache.flink.table.codegen.calls.ScalarOperators$
 
generateIsNotFalse(GeneratedExpression) - Static method in class org.apache.flink.table.codegen.calls.ScalarOperators
 
generateIsNotNull(boolean, GeneratedExpression) - Method in class org.apache.flink.table.codegen.calls.ScalarOperators$
 
generateIsNotNull(boolean, GeneratedExpression) - Static method in class org.apache.flink.table.codegen.calls.ScalarOperators
 
generateIsNotTrue(GeneratedExpression) - Method in class org.apache.flink.table.codegen.calls.ScalarOperators$
 
generateIsNotTrue(GeneratedExpression) - Static method in class org.apache.flink.table.codegen.calls.ScalarOperators
 
generateIsNull(boolean, GeneratedExpression) - Method in class org.apache.flink.table.codegen.calls.ScalarOperators$
 
generateIsNull(boolean, GeneratedExpression) - Static method in class org.apache.flink.table.codegen.calls.ScalarOperators
 
generateIsTrue(GeneratedExpression) - Method in class org.apache.flink.table.codegen.calls.ScalarOperators$
 
generateIsTrue(GeneratedExpression) - Static method in class org.apache.flink.table.codegen.calls.ScalarOperators
 
generateMapGet(CodeGenerator, GeneratedExpression, GeneratedExpression) - Method in class org.apache.flink.table.codegen.calls.ScalarOperators$
 
generateMapGet(CodeGenerator, GeneratedExpression, GeneratedExpression) - Static method in class org.apache.flink.table.codegen.calls.ScalarOperators
 
generateNonNullLiteral(TypeInformation<?>, String) - Method in class org.apache.flink.table.codegen.CodeGenerator
 
generateNot(boolean, GeneratedExpression) - Method in class org.apache.flink.table.codegen.calls.ScalarOperators$
 
generateNot(boolean, GeneratedExpression) - Static method in class org.apache.flink.table.codegen.calls.ScalarOperators
 
generateNotEquals(boolean, GeneratedExpression, GeneratedExpression) - Method in class org.apache.flink.table.codegen.calls.ScalarOperators$
 
generateNotEquals(boolean, GeneratedExpression, GeneratedExpression) - Static method in class org.apache.flink.table.codegen.calls.ScalarOperators
 
generateOr(boolean, GeneratedExpression, GeneratedExpression) - Method in class org.apache.flink.table.codegen.calls.ScalarOperators$
 
generateOr(boolean, GeneratedExpression, GeneratedExpression) - Static method in class org.apache.flink.table.codegen.calls.ScalarOperators
 
generateOutputFieldBoxing(GeneratedExpression) - Method in class org.apache.flink.table.codegen.CodeGenerator
Converts the internal mostly primitive field representation to an external boxed format.
generatePlan(JobGraph) - Static method in class org.apache.flink.runtime.jobgraph.jsonplan.JsonPlanGenerator
 
generateRandomMatrix(DataSet<Object>, int, long) - Method in class org.apache.flink.ml.recommendation.ALS$
 
generateRandomMatrix(DataSet<Object>, int, long) - Static method in class org.apache.flink.ml.recommendation.ALS
 
generateRecordTimestamp(boolean) - Method in class org.apache.flink.table.codegen.CodeGenerator
 
generateRegistration() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
This method generate a specific Registration, for example TaskExecutor Registration at the ResourceManager
generateRegistration() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorToResourceManagerConnection
 
generateResultExpression(TypeInformation<?>, Seq<String>, Seq<RexNode>) - Method in class org.apache.flink.table.codegen.CodeGenerator
Generates an expression from a sequence of RexNode.
generateResultExpression(Seq<GeneratedExpression>, TypeInformation<?>, Seq<String>) - Method in class org.apache.flink.table.codegen.CodeGenerator
Generates an expression from a sequence of other expressions.
generateRowConverterFunction(TypeInformation<Row>, RowSchema, TypeInformation<OUT>, String) - Method in class org.apache.flink.table.api.TableEnvironment
 
generateSequence(long, long) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a new data set that contains a sequence of numbers.
generateSequence(long, long) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Creates a new data set that contains a sequence of numbers.
generateSequence(long, long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a new data stream that contains a sequence of numbers.
generateSequence(long, long) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Creates a new DataStream that contains a sequence of numbers.
generateSlotOffer() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
Generate the slot offer from this TaskSlot.
generateStringConcatOperator(boolean, GeneratedExpression, GeneratedExpression) - Method in class org.apache.flink.table.codegen.calls.ScalarOperators$
 
generateStringConcatOperator(boolean, GeneratedExpression, GeneratedExpression) - Static method in class org.apache.flink.table.codegen.calls.ScalarOperators
 
generateSymbol(Enum<?>) - Method in class org.apache.flink.table.codegen.CodeGenerator
 
generateTableFunctionCollector(String, String, TypeInformation<Object>) - Method in class org.apache.flink.table.codegen.CodeGenerator
Generates a TableFunctionCollector that can be passed to Java compiler.
generateTaskManagerConfiguration(Configuration, String, int, int, FiniteDuration) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
Generate a task manager configuration.
generateTemporalPlusMinus(boolean, boolean, GeneratedExpression, GeneratedExpression) - Method in class org.apache.flink.table.codegen.calls.ScalarOperators$
 
generateTemporalPlusMinus(boolean, boolean, GeneratedExpression, GeneratedExpression) - Static method in class org.apache.flink.table.codegen.calls.ScalarOperators
 
generateTypeString(StringBuilder, boolean) - Static method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
generateUnaryArithmeticOperator(String, boolean, TypeInformation<?>, GeneratedExpression) - Method in class org.apache.flink.table.codegen.calls.ScalarOperators$
 
generateUnaryArithmeticOperator(String, boolean, TypeInformation<?>, GeneratedExpression) - Static method in class org.apache.flink.table.codegen.calls.ScalarOperators
 
generateUnaryIntervalPlusMinus(boolean, boolean, GeneratedExpression) - Method in class org.apache.flink.table.codegen.calls.ScalarOperators$
 
generateUnaryIntervalPlusMinus(boolean, boolean, GeneratedExpression) - Static method in class org.apache.flink.table.codegen.calls.ScalarOperators
 
generateValuesInputFormat(String, Seq<String>, TypeInformation<T>) - Method in class org.apache.flink.table.codegen.CodeGenerator
Generates a values input format that can be passed to Java compiler.
generateZookeeperPath(String, String) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
 
generator() - Method in interface org.apache.flink.graph.generator.random.RandomGenerable
Returns an initialized RandomGenerator.
GenericArraySerializer<C> - Class in org.apache.flink.api.common.typeutils.base
A serializer for arrays of objects.
GenericArraySerializer(Class<C>, TypeSerializer<C>) - Constructor for class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
GenericArraySerializerConfigSnapshot<C> - Class in org.apache.flink.api.common.typeutils.base
Point-in-time configuration of a GenericArraySerializer.
GenericArraySerializerConfigSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.GenericArraySerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
GenericArraySerializerConfigSnapshot(Class<C>, TypeSerializer<C>) - Constructor for class org.apache.flink.api.common.typeutils.base.GenericArraySerializerConfigSnapshot
 
GenericClassDescriptor(int, scala.reflect.macros.Context.universe) - Constructor for class org.apache.flink.api.scala.codegen.TypeDescriptors.GenericClassDescriptor
 
GenericCsvInputFormat<OT> - Class in org.apache.flink.api.common.io
 
GenericCsvInputFormat() - Constructor for class org.apache.flink.api.common.io.GenericCsvInputFormat
 
GenericCsvInputFormat(Path) - Constructor for class org.apache.flink.api.common.io.GenericCsvInputFormat
 
GenericDataSinkBase<IN> - Class in org.apache.flink.api.common.operators
Operator for nodes that act as data sinks, storing the data they receive.
GenericDataSinkBase(OutputFormat<IN>, UnaryOperatorInformation<IN, Nothing>, String) - Constructor for class org.apache.flink.api.common.operators.GenericDataSinkBase
Creates a GenericDataSink with the provided OutputFormat implementation and the given name.
GenericDataSinkBase(UserCodeWrapper<? extends OutputFormat<IN>>, UnaryOperatorInformation<IN, Nothing>, String) - Constructor for class org.apache.flink.api.common.operators.GenericDataSinkBase
Creates a GenericDataSink with the provided OutputFormat implementation and the given name.
GenericDataSourceBase<OUT,T extends InputFormat<OUT,?>> - Class in org.apache.flink.api.common.operators
Abstract superclass for data sources in a Pact plan.
GenericDataSourceBase(T, OperatorInformation<OUT>, String) - Constructor for class org.apache.flink.api.common.operators.GenericDataSourceBase
Creates a new instance for the given file using the given input format.
GenericDataSourceBase(T, OperatorInformation<OUT>) - Constructor for class org.apache.flink.api.common.operators.GenericDataSourceBase
Creates a new instance for the given file using the given input format, using the default name.
GenericDataSourceBase(Class<? extends T>, OperatorInformation<OUT>, String) - Constructor for class org.apache.flink.api.common.operators.GenericDataSourceBase
Creates a new instance for the given file using the given input format.
GenericDataSourceBase(Class<? extends T>, OperatorInformation<OUT>) - Constructor for class org.apache.flink.api.common.operators.GenericDataSourceBase
Creates a new instance for the given file using the given input format, using the default name.
GenericDataSourceBase.SplitDataProperties<T> - Interface in org.apache.flink.api.common.operators
 
GenericFlatTypePostPass<X,T extends AbstractSchema<X>> - Class in org.apache.flink.optimizer.postpass
 
GenericFlatTypePostPass() - Constructor for class org.apache.flink.optimizer.postpass.GenericFlatTypePostPass
 
GenericInputFormat<OT> - Class in org.apache.flink.api.common.io
Generic base class for all Rich inputs that are not based on files.
GenericInputFormat() - Constructor for class org.apache.flink.api.common.io.GenericInputFormat
 
GenericInputSplit - Class in org.apache.flink.core.io
A generic input split that has only a partition number.
GenericInputSplit(int, int) - Constructor for class org.apache.flink.core.io.GenericInputSplit
Creates a generic input split with the given split number.
GenericLossFunction - Class in org.apache.flink.ml.optimization
Generic loss function which lets you build a loss function out of the PartialLossFunction and the PredictionFunction.
GenericLossFunction(PartialLossFunction, PredictionFunction) - Constructor for class org.apache.flink.ml.optimization.GenericLossFunction
 
GenericLossFunction$ - Class in org.apache.flink.ml.optimization
 
GenericLossFunction$() - Constructor for class org.apache.flink.ml.optimization.GenericLossFunction$
 
GenericMetricGroup - Class in org.apache.flink.runtime.metrics.groups
A simple named MetricGroup that is used to hold subgroups of metrics.
GenericMetricGroup(MetricRegistry, AbstractMetricGroup, String) - Constructor for class org.apache.flink.runtime.metrics.groups.GenericMetricGroup
 
GenericPairComparator<T1,T2> - Class in org.apache.flink.api.common.typeutils
 
GenericPairComparator(TypeComparator<T1>, TypeComparator<T2>) - Constructor for class org.apache.flink.api.common.typeutils.GenericPairComparator
 
GenericParameterValuesProvider - Class in org.apache.flink.api.java.io.jdbc.split
This splits generator actually does nothing but wrapping the query parameters computed by the user before creating the JDBCInputFormat instance.
GenericParameterValuesProvider(Serializable[][]) - Constructor for class org.apache.flink.api.java.io.jdbc.split.GenericParameterValuesProvider
 
GenericRelDataType - Class in org.apache.flink.table.plan.schema
Generic type for encapsulating Flink's TypeInformation.
GenericRelDataType(TypeInformation<?>, boolean, RelDataTypeSystem) - Constructor for class org.apache.flink.table.plan.schema.GenericRelDataType
 
GenericTypeComparator<T extends Comparable<T>> - Class in org.apache.flink.api.java.typeutils.runtime
TypeComparator for all types that extend Comparable.
GenericTypeComparator(boolean, TypeSerializer<T>, Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
GenericTypeInfo<T> - Class in org.apache.flink.api.java.typeutils
 
GenericTypeInfo(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.GenericTypeInfo
 
GenericTypeSerializerConfigSnapshot<T> - Class in org.apache.flink.api.common.typeutils
Configuration snapshot for serializers for generic types.
GenericTypeSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.GenericTypeSerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
GenericTypeSerializerConfigSnapshot(Class<T>) - Constructor for class org.apache.flink.api.common.typeutils.GenericTypeSerializerConfigSnapshot
 
GenericWriteAheadSink<IN> - Class in org.apache.flink.streaming.runtime.operators
Generic Sink that emits its input elements into an arbitrary backend.
GenericWriteAheadSink(CheckpointCommitter, TypeSerializer<IN>, String) - Constructor for class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
 
get(int) - Method in class org.apache.flink.api.common.operators.util.FieldList
 
get() - Method in interface org.apache.flink.api.common.state.AppendingState
Returns the current value for the state.
get(UK) - Method in interface org.apache.flink.api.common.state.MapState
Returns the current value associated with the given key.
get(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the String value for the given key.
get(String, String) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the String value for the given key.
get() - Method in class org.apache.flink.client.program.ClusterClient.LazyActorSystemLoader
Creates a new ActorSystem or returns an existing one.
get() - Method in class org.apache.flink.contrib.streaming.state.RocksDBAggregatingState
 
get() - Method in class org.apache.flink.contrib.streaming.state.RocksDBFoldingState
Deprecated.
 
get() - Method in class org.apache.flink.contrib.streaming.state.RocksDBListState
 
get(UK) - Method in class org.apache.flink.contrib.streaming.state.RocksDBMapState
 
get() - Method in class org.apache.flink.contrib.streaming.state.RocksDBReducingState
 
get(URI) - Static method in class org.apache.flink.core.fs.FileSystem
Returns a reference to the FileSystem instance for accessing the file system identified by the given URI.
get(int) - Method in class org.apache.flink.core.memory.HeapMemorySegment
 
get(int, byte[]) - Method in class org.apache.flink.core.memory.HeapMemorySegment
 
get(int, byte[], int, int) - Method in class org.apache.flink.core.memory.HeapMemorySegment
 
get(DataOutput, int, int) - Method in class org.apache.flink.core.memory.HeapMemorySegment
 
get(int, ByteBuffer, int) - Method in class org.apache.flink.core.memory.HeapMemorySegment
 
get(int) - Method in class org.apache.flink.core.memory.HybridMemorySegment
 
get(int, byte[]) - Method in class org.apache.flink.core.memory.HybridMemorySegment
 
get(int, byte[], int, int) - Method in class org.apache.flink.core.memory.HybridMemorySegment
 
get(DataOutput, int, int) - Method in class org.apache.flink.core.memory.HybridMemorySegment
 
get(int, ByteBuffer, int) - Method in class org.apache.flink.core.memory.HybridMemorySegment
 
get(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads the byte at the given position.
get(int, byte[]) - Method in class org.apache.flink.core.memory.MemorySegment
Bulk get method.
get(int, byte[], int, int) - Method in class org.apache.flink.core.memory.MemorySegment
Bulk get method.
get(DataOutput, int, int) - Method in class org.apache.flink.core.memory.MemorySegment
 
get(int, ByteBuffer, int) - Method in class org.apache.flink.core.memory.MemorySegment
Bulk get method.
get() - Method in class org.apache.flink.graph.utils.proxy.OptionalBoolean
Get the boolean state.
get(Parameter<T>) - Method in class org.apache.flink.ml.common.ParameterMap
Retrieves a parameter value associated to a given key.
get(ActorSystem) - Static method in class org.apache.flink.runtime.akka.RemoteAddressExtension
 
get(JobID, String) - Method in class org.apache.flink.runtime.blob.BlobClient
Downloads the BLOB identified by the given job ID and key from the BLOB server.
get(BlobKey) - Method in class org.apache.flink.runtime.blob.BlobClient
Downloads the BLOB identified by the given BLOB key from the BLOB server.
get(BlobKey, File) - Method in interface org.apache.flink.runtime.blob.BlobView
Copies a blob to a local file.
get(JobID, String, File) - Method in interface org.apache.flink.runtime.blob.BlobView
Copies a blob to a local file.
get(BlobKey, File) - Method in class org.apache.flink.runtime.blob.FileSystemBlobStore
 
get(JobID, String, File) - Method in class org.apache.flink.runtime.blob.FileSystemBlobStore
 
get(BlobKey, File) - Method in class org.apache.flink.runtime.blob.VoidBlobStore
 
get(JobID, String, File) - Method in class org.apache.flink.runtime.blob.VoidBlobStore
 
get() - Static method in class org.apache.flink.runtime.clusterframework.messages.CheckAndAllocateContainers
Gets the singleton instance.
get() - Static method in class org.apache.flink.runtime.clusterframework.messages.RegisterInfoMessageListenerSuccessful
Gets the singleton instance.
get() - Static method in class org.apache.flink.runtime.clusterframework.messages.UnRegisterInfoMessageListener
Gets the singleton instance.
get() - Method in interface org.apache.flink.runtime.concurrent.Future
Gets the result value of the future.
get(long, TimeUnit) - Method in interface org.apache.flink.runtime.concurrent.Future
Gets the result value of the future.
get() - Method in class org.apache.flink.runtime.concurrent.impl.FlinkFuture
 
get(long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.impl.FlinkFuture
 
get(String) - Method in class org.apache.flink.runtime.iterative.concurrent.Broker
blocking retrieval and removal of the object to share
get() - Static method in class org.apache.flink.runtime.messages.Acknowledge
Gets the singleton instance.
get() - Method in class org.apache.flink.runtime.messages.TaskManagerMessages.SendHeartbeat$
Accessor for the case object instance, to simplify Java interoperability.
get() - Method in class org.apache.flink.runtime.messages.TaskManagerMessages.SendStackTrace$
Accessor for the case object instance, to simplify Java interoperability.
get(int) - Method in class org.apache.flink.runtime.operators.util.BitSet
Returns true if the bit is set in the specified index.
get(int) - Method in class org.apache.flink.runtime.operators.util.BloomFilter.BitSet
Returns true if the bit is set in the specified index.
get(int) - Method in class org.apache.flink.runtime.state.ChainedStateHandle
Get the state handle for a single operator in the operator chain by it's index.
get() - Method in class org.apache.flink.runtime.state.DoneFuture
 
get(long, TimeUnit) - Method in class org.apache.flink.runtime.state.DoneFuture
 
get(K, N) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
get(N) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
get() - Method in class org.apache.flink.runtime.state.heap.HeapAggregatingState
 
get() - Method in class org.apache.flink.runtime.state.heap.HeapFoldingState
Deprecated.
 
get() - Method in class org.apache.flink.runtime.state.heap.HeapListState
 
get(UK) - Method in class org.apache.flink.runtime.state.heap.HeapMapState
 
get() - Method in class org.apache.flink.runtime.state.heap.HeapReducingState
 
get(N) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
get(K, N) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
get(N) - Method in class org.apache.flink.runtime.state.heap.StateTable
Returns the state of the mapping for the composite of active key and given namespace.
get(K, N) - Method in class org.apache.flink.runtime.state.heap.StateTable
Returns the state for the composite of active key and given namespace.
get() - Static method in class org.apache.flink.runtime.state.VoidNamespace
Getter for the singleton instance
get(JobID) - Method in class org.apache.flink.runtime.taskexecutor.JobManagerTable
 
get() - Method in class org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
 
get() - Static method in class org.apache.flink.runtime.util.EmptyIterator
Gets a singleton instance of the empty iterator.
get() - Static method in class org.apache.flink.runtime.util.EmptyMutableObjectIterator
Gets a singleton instance of the empty iterator.
get(int) - Method in class org.apache.flink.runtime.util.EvictingBoundedList
 
get(K) - Method in class org.apache.flink.runtime.util.LRUCacheMap
 
get(Throwable, ClassLoader) - Static method in exception org.apache.flink.runtime.util.SerializedThrowable
 
get(Object) - Method in class org.apache.flink.storm.util.StormConfig
 
get() - Method in interface org.apache.flink.streaming.api.operators.async.queue.AsyncCollectionResult
Return the asynchronous result collection.
get() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamRecordQueueEntry
 
get() - Static method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow
 
get() - Method in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter.AvroKeyValue
 
get(K) - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
Looks up the value mapped under the given key.
get(T) - Method in class org.apache.flink.streaming.util.typeutils.FieldAccessor
Gets the value of the field (specified in the constructor) of the given record.
get(String) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Accesses the field of a Flink composite type (such as Tuple, POJO, etc.) by name and returns it's value.
get(int) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Accesses the field of a Flink composite type (such as Tuple, POJO, etc.) by index and returns it's value.
GET() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
GET() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
get() - Method in class org.apache.flink.types.BooleanValue
 
get(int) - Method in class org.apache.flink.types.ListValue
 
get(Object) - Method in class org.apache.flink.types.MapValue
 
get75thPercentile() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxHistogramMBean
 
get95thPercentile() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxHistogramMBean
 
get98thPercentile() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxHistogramMBean
 
get999thPercentile() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxHistogramMBean
 
get99thPercentile() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxHistogramMBean
 
GET_PARTITIONS_RETRIES_KEY - Static variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer08
Configuration key for the number of retries for getting the partition info
getAccessor(TypeInformation<T>, int, ExecutionConfig) - Static method in class org.apache.flink.streaming.util.typeutils.FieldAccessorFactory
Creates a FieldAccessor for the given field position, which can be used to get and set the specified field on instances of this type.
getAccessor(TypeInformation<T>, String, ExecutionConfig) - Static method in class org.apache.flink.streaming.util.typeutils.FieldAccessorFactory
Creates a FieldAccessor for the field that is given by a field expression, which can be used to get and set the specified field on instances of this type.
getAccessTime() - Method in interface org.apache.flink.core.fs.FileStatus
Get the access time of the file.
getAccessTime() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
 
getAccessTime() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
 
getAccMode() - Method in class org.apache.flink.table.plan.nodes.datastream.AccModeTrait
 
getAccumulatedRecordCount() - Method in class org.apache.flink.api.common.io.BlockInfo
Returns the accumulated record count.
getAccumulateMethodSignature(AggregateFunction<?, ?>, Seq<TypeInformation<?>>) - Method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils$
Returns signatures of accumulate methods matching the given signature of TypeInformation.
getAccumulateMethodSignature(AggregateFunction<?, ?>, Seq<TypeInformation<?>>) - Static method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils
Returns signatures of accumulate methods matching the given signature of TypeInformation.
getAccumulator(String) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Get an existing accumulator object.
getAccumulator(String) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getAccumulator(ExecutionEnvironment, String) - Method in class org.apache.flink.graph.AnalyticHelper
Gets the accumulator with the given name.
getAccumulatorMap() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
getAccumulatorRegistry() - Method in interface org.apache.flink.runtime.execution.Environment
Return the registry for accumulators which are periodically sent to the job manager.
getAccumulatorRegistry() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getAccumulatorRegistry() - Method in class org.apache.flink.runtime.taskmanager.Task
 
getAccumulatorResult(String) - Method in class org.apache.flink.api.common.JobExecutionResult
Gets the accumulator with the given name.
getAccumulatorResult(String) - Method in class org.apache.flink.client.program.DetachedEnvironment.DetachedJobExecutionResult
 
getAccumulatorResultsStringified() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns the aggregated user-defined accumulators as strings.
getAccumulatorResultsStringified() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getAccumulatorResultsStringified() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Returns the a stringified version of the user-defined accumulators.
getAccumulators(JobID) - Method in class org.apache.flink.client.program.ClusterClient
Requests and returns the accumulators for the given job identifier.
getAccumulators(JobID, ClassLoader) - Method in class org.apache.flink.client.program.ClusterClient
Requests and returns the accumulators for the given job identifier.
getAccumulators() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Gets the accumulator results.
getAccumulators() - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
Gets flink and user-defined accumulators in serialized form.
getAccumulatorsSerialized() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns a map containing the serialized values of user-defined accumulators.
getAccumulatorsSerialized() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getAccumulatorsSerialized() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Gets a serialized accumulator map.
getAccumulatorType() - Method in class org.apache.flink.table.functions.aggfunctions.BigIntegralAvgAggFunction
 
getAccumulatorType() - Method in class org.apache.flink.table.functions.aggfunctions.CountAggFunction
 
getAccumulatorType() - Method in class org.apache.flink.table.functions.aggfunctions.DecimalAvgAggFunction
 
getAccumulatorType() - Method in class org.apache.flink.table.functions.aggfunctions.DecimalSumAggFunction
 
getAccumulatorType() - Method in class org.apache.flink.table.functions.aggfunctions.DecimalSumWithRetractAggFunction
 
getAccumulatorType() - Method in class org.apache.flink.table.functions.aggfunctions.FloatingAvgAggFunction
 
getAccumulatorType() - Method in class org.apache.flink.table.functions.aggfunctions.IntegralAvgAggFunction
 
getAccumulatorType() - Method in class org.apache.flink.table.functions.aggfunctions.MaxAggFunction
 
getAccumulatorType() - Method in class org.apache.flink.table.functions.aggfunctions.MaxWithRetractAggFunction
 
getAccumulatorType() - Method in class org.apache.flink.table.functions.aggfunctions.MinAggFunction
 
getAccumulatorType() - Method in class org.apache.flink.table.functions.aggfunctions.MinWithRetractAggFunction
 
getAccumulatorType() - Method in class org.apache.flink.table.functions.aggfunctions.SumAggFunction
 
getAccumulatorType() - Method in class org.apache.flink.table.functions.aggfunctions.SumWithRetractAggFunction
 
getAckTimestamp() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
Returns the timestamp when the acknowledgement of this subtask was received at the coordinator.
getAckTimestampStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
Returns the summary stats for the ACK timestamps.
getAclForPath(String) - Method in class org.apache.flink.runtime.util.ZooKeeperUtils.SecureAclProvider
 
getAction() - Method in class org.apache.flink.cep.nfa.StateTransition
 
getActiveCustomCommandLine(CommandLine) - Method in class org.apache.flink.client.CliFrontend
Gets the custom command-line for the arguments.
getActiveSlots(JobID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Return an iterator of active slots (their application ids) for the given job id.
getActiveTimerTimestamps() - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
getActorGateway() - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
getActorGatewayFuture() - Method in class org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderGatewayListener
 
getActorRef(String, ActorSystem, FiniteDuration) - Method in class org.apache.flink.runtime.akka.AkkaUtils$
Returns an ActorRef for the actor specified by the path parameter.
getActorRef(String, ActorSystem, FiniteDuration) - Static method in class org.apache.flink.runtime.akka.AkkaUtils
Returns an ActorRef for the actor specified by the path parameter.
getActorRefFuture(String, ActorSystem, FiniteDuration) - Method in class org.apache.flink.runtime.akka.AkkaUtils$
Returns a Future to the ActorRef of an actor.
getActorRefFuture(String, ActorSystem, FiniteDuration) - Static method in class org.apache.flink.runtime.akka.AkkaUtils
Returns a Future to the ActorRef of an actor.
getActual() - Method in exception org.apache.flink.runtime.highavailability.LeaderIdMismatchException
 
getActualBytes() - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
getActualLeaderSessionID() - Method in exception org.apache.flink.runtime.rpc.exceptions.LeaderSessionIDException
Get actual leader session id
getAdamicAdarScore() - Method in class org.apache.flink.graph.library.similarity.AdamicAdar.Result
Get the Adamic-Adar score, equal to the sum over common neighbors of the inverse logarithm of degree
getAddress(ActorSystem) - Method in class org.apache.flink.runtime.akka.AkkaUtils$
Returns the address of the given ActorSystem.
getAddress(ActorSystem) - Static method in class org.apache.flink.runtime.akka.AkkaUtils
Returns the address of the given ActorSystem.
getAddress() - Method in class org.apache.flink.runtime.io.network.ConnectionID
 
getAddress() - Method in exception org.apache.flink.runtime.io.network.netty.exception.TransportException
 
getAddress() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
getAddress() - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
getAddress() - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Return the address of the task manager with which the gateway is associated.
getAddress() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
 
getAddress() - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
getAddress() - Method in interface org.apache.flink.runtime.leaderelection.LeaderContender
Returns the address of the LeaderContender under which other instances can connect to it.
getAddress() - Method in class org.apache.flink.runtime.query.netty.KvStateServer
Returns the address of this server.
getAddress() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
getAddress() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
Gets the address of the underlying RPC endpoint.
getAddress() - Method in interface org.apache.flink.runtime.rpc.RpcGateway
Returns the fully qualified address under which the associated rpc endpoint is reachable.
getAddress() - Method in interface org.apache.flink.runtime.rpc.RpcService
Return the hostname or host address under which the rpc service can be reached.
getAddress() - Method in class org.apache.flink.runtime.util.LeaderConnectionInfo
 
getAggCallList() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
getAggCallList() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
getAggCallList() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getAggCalls() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
 
getAggregate() - Method in interface org.apache.flink.api.common.aggregators.Aggregator
Gets the aggregator's current aggregate.
getAggregate() - Method in class org.apache.flink.api.common.aggregators.DoubleSumAggregator
 
getAggregate() - Method in class org.apache.flink.api.common.aggregators.LongSumAggregator
 
getAggregate() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregator
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.AggregationFunction
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.MaxAggregationFunction.ImmutableMaxAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.MaxAggregationFunction.MutableMaxAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.MinAggregationFunction.ImmutableMinAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.MinAggregationFunction.MutableMinAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.ByteSumAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.ByteValueSumAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.DoubleSumAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.DoubleValueSumAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.FloatSumAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.FloatValueSumAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.IntSumAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.IntValueSumAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.LongSumAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.LongValueSumAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.ShortSumAgg
 
getAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.ShortValueSumAgg
 
getAggregatedUserAccumulatorsStringified() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
Returns the aggregated user-defined accumulators as strings.
getAggregatedUserAccumulatorsStringified() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
 
getAggregatedUserAccumulatorsStringified() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getAggregateFunction() - Method in class org.apache.flink.api.common.state.AggregatingStateDescriptor
Returns the aggregate function to be used for the state.
getAggregateFunctionAccumulatorType(AggregateFunction<IN, ACC, ?>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getAggregateFunctionReturnType(AggregateFunction<IN, ?, OUT>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getAggregateJobVertexState(int[], int) - Static method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
A utility function that computes an "aggregated" state for the vertex.
getAggregates() - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepBarrier
 
getAggregates(ClassLoader) - Method in class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
 
getAggregateState() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
Returns the aggregated ExecutionState for this job vertex.
getAggregateState() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
 
getAggregateState() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getAggregator() - Method in class org.apache.flink.api.common.aggregators.AggregatorWithName
Gets the aggregator.
getAggregator(String) - Method in class org.apache.flink.runtime.iterative.task.RuntimeAggregatorRegistry
 
getAggregatorNames() - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepBarrier
 
getAggregatorNames() - Method in class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
 
getAggregators() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
 
getAggregators() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
 
getAggregators() - Method in interface org.apache.flink.api.common.operators.IterationOperator
 
getAggregators() - Method in class org.apache.flink.api.java.operators.DeltaIteration
Gets the registry for aggregators for the iteration.
getAggregators() - Method in class org.apache.flink.api.java.operators.IterativeDataSet
Gets the registry for aggregators.
getAggregators() - Method in class org.apache.flink.graph.IterationConfiguration
Gets the set of aggregators that are registered for this vertex-centric iteration.
getAkkaConfig(Configuration, String, int) - Method in class org.apache.flink.runtime.akka.AkkaUtils$
Return a remote Akka config for the given configuration values.
getAkkaConfig(Configuration) - Method in class org.apache.flink.runtime.akka.AkkaUtils$
Return a local Akka config for the given configuration values.
getAkkaConfig(Configuration, Option<Tuple2<String, Object>>) - Method in class org.apache.flink.runtime.akka.AkkaUtils$
Creates an akka config with the provided configuration values.
getAkkaConfig(Configuration, String, int) - Static method in class org.apache.flink.runtime.akka.AkkaUtils
Return a remote Akka config for the given configuration values.
getAkkaConfig(Configuration) - Static method in class org.apache.flink.runtime.akka.AkkaUtils
Return a local Akka config for the given configuration values.
getAkkaConfig(Configuration, Option<Tuple2<String, Object>>) - Static method in class org.apache.flink.runtime.akka.AkkaUtils
Creates an akka config with the provided configuration values.
getAkkaURL(ActorSystem, ActorRef) - Method in class org.apache.flink.runtime.akka.AkkaUtils$
Returns the given ActorRef's path string representation with host and port of the ActorSystem in which the actor is running.
getAkkaURL(ActorSystem, String) - Method in class org.apache.flink.runtime.akka.AkkaUtils$
Returns the AkkaURL for a given ActorSystem and a path describing a running Actor in the actor system.
getAkkaURL(ActorSystem, ActorRef) - Static method in class org.apache.flink.runtime.akka.AkkaUtils
Returns the given ActorRef's path string representation with host and port of the ActorSystem in which the actor is running.
getAkkaURL(ActorSystem, String) - Static method in class org.apache.flink.runtime.akka.AkkaUtils
Returns the AkkaURL for a given ActorSystem and a path describing a running Actor in the actor system.
getAlgorithmName() - Method in class org.apache.flink.graph.asm.degree.annotate.directed.EdgeDegreesPair
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.degree.annotate.directed.EdgeSourceDegrees
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.degree.annotate.directed.EdgeTargetDegrees
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexInDegree
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexOutDegree
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeDegreePair
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeSourceDegree
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeTargetDegree
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.VertexDegree
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.degree.filter.undirected.MaximumDegree
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.simple.directed.Simplify
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.simple.undirected.Simplify
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.translate.TranslateEdgeValues
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.translate.TranslateGraphIds
 
getAlgorithmName() - Method in class org.apache.flink.graph.asm.translate.TranslateVertexValues
 
getAlgorithmName() - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient
 
getAlgorithmName() - Method in class org.apache.flink.graph.library.clustering.directed.TriangleListing
 
getAlgorithmName() - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient
 
getAlgorithmName() - Method in class org.apache.flink.graph.library.clustering.undirected.TriangleListing
 
getAlgorithmName() - Method in class org.apache.flink.graph.library.link_analysis.HITS
 
getAlgorithmName() - Method in class org.apache.flink.graph.library.link_analysis.PageRank
 
getAlgorithmName() - Method in class org.apache.flink.graph.library.similarity.AdamicAdar
 
getAlgorithmName() - Method in class org.apache.flink.graph.library.similarity.JaccardIndex
 
getAlgorithmName() - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingDataSet
Algorithms are identified by name rather than by class to allow subclassing.
getAlgorithmName() - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingGraph
Algorithms are identified by name rather than by class to allow subclassing.
getAlignmentBuffered() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
Returns the total buffered bytes during alignment over all subtasks.
getAlignmentBuffered() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
 
getAlignmentBuffered() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
 
getAlignmentBuffered() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpointStats
 
getAlignmentBuffered() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
Returns the number of bytes buffered during stream alignment (for exactly-once only).
getAlignmentBuffered() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
Returns the total buffered bytes during alignment over all subtasks.
getAlignmentBufferedStats() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStatsSummary
Returns the summary stats for the bytes buffered during alignment.
getAlignmentBufferedStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
Returns the summary stats for the buffered bytes during alignments.
getAlignmentDuration() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
Returns the duration of the stream alignment (for exactly-once only).
getAlignmentDurationNanos() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
getAlignmentDurationNanos() - Method in class org.apache.flink.streaming.runtime.io.BarrierBuffer
 
getAlignmentDurationNanos() - Method in class org.apache.flink.streaming.runtime.io.BarrierTracker
 
getAlignmentDurationNanos() - Method in interface org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
Gets the time that the latest alignment took, in nanoseconds.
getAlignmentDurationStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
Returns the summary stats for the alignment duration.
getAllAccumulatorResults() - Method in class org.apache.flink.api.common.JobExecutionResult
Gets all accumulators produced by the job.
getAllAccumulatorResults() - Method in class org.apache.flink.client.program.DetachedEnvironment.DetachedJobExecutionResult
 
getAllAccumulators() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Deprecated.
Use getAccumulator(..) to obtain the value of an accumulator.
getAllAccumulators() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getAllAggregators() - Method in class org.apache.flink.runtime.iterative.task.RuntimeAggregatorRegistry
 
getAllAndLock() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Gets all available state handles from ZooKeeper and locks the respective state nodes.
getAllCheckpoints() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
Returns all CompletedCheckpoint instances.
getAllCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
 
getAllCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
 
getAllDeclaredFields(Class<?>, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
Recursively determine all declared fields This is required because class.getFields() is not returning fields defined in parent classes.
getAllDeclaredMethods(Class<?>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils
Returns all declared methods of a class including methods of superclasses.
getAllExecutionVertexes() - Method in class org.apache.flink.runtime.executiongraph.failover.FailoverRegion
get all execution vertexes contained in this region
getAllExecutionVertices() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns an iterable containing all execution vertices for this execution graph.
getAllExecutionVertices() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getAllExecutionVertices() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getAllInputGates() - Method in interface org.apache.flink.runtime.execution.Environment
 
getAllInputGates() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getAllInputGates() - Method in class org.apache.flink.runtime.taskmanager.Task
 
getAllIntermediateResults() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getAllLibraries() - Method in class org.apache.flink.client.program.PackagedProgram
Returns all provided libraries needed to run the program.
getAllNodes() - Method in class org.apache.flink.optimizer.plan.OptimizedPlan
Gets all the nodes from this OptimizedPlan.
getAllocatedSlot() - Method in class org.apache.flink.runtime.instance.Slot
Gets the allocated slot that this slot refers to.
getAllocatedSlots(JobID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Return an iterator of allocated slots for the given job id.
getAllocationId() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
getAllocationId() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
 
getAllocationId() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
getAllocationId() - Method in class org.apache.flink.runtime.resourcemanager.SlotRequest
Get the unique identification of this request
getAllocationId() - Method in exception org.apache.flink.runtime.taskexecutor.exceptions.SlotOccupiedException
 
getAllocationId() - Method in class org.apache.flink.runtime.taskexecutor.slot.SlotOffer
 
getAllocationId() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
 
getAllocationID() - Method in class org.apache.flink.runtime.taskexecutor.SlotStatus
Get the allocation id of this slot
getAllocationId() - Method in class org.apache.flink.runtime.taskmanager.Task
 
getAllOperators() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
 
getAllowedSignatures() - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
getAllowedSignatures(String) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
getAllowedSignatures() - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
getAllowedSignatures(String) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
getAllowedSignatures() - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
getAllowedSignatures(String) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
getAllowedSignatures() - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
getAllowedSignatures(String) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
getAllowOrigin() - Method in class org.apache.flink.runtime.webmonitor.WebMonitorConfig
 
getAllowQueuedScheduling() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
 
getAllPaths() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Return a list of all valid paths for state handles.
getAllRegisteredAggregators() - Method in class org.apache.flink.api.common.aggregators.AggregatorRegistry
 
getAllRegisteredInstances() - Method in class org.apache.flink.runtime.instance.InstanceManager
 
getAllSortedByNameAndLock() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Gets all available state handles from ZooKeeper sorted by name (ascending) and locks the respective state nodes.
getAllTaskStateStats() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
Returns all task state stats instances.
getAllVariables() - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
 
getAllVariables() - Method in interface org.apache.flink.metrics.MetricGroup
Returns a map of all variables and their associated value, for example {"<host>"="host-7", "<tm_id>"="taskmanager-2"}
getAllVariables() - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
getAllVariables() - Method in class org.apache.flink.runtime.metrics.groups.ComponentMetricGroup
 
getAllVariables() - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
getAllVertices() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns a map containing all job vertices for this execution graph.
getAllVertices() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getAllVertices() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getAllWriters() - Method in interface org.apache.flink.runtime.execution.Environment
 
getAllWriters() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getAllWriters() - Method in class org.apache.flink.runtime.taskmanager.Task
 
getAlt() - Method in class org.apache.flink.api.java.utils.Option
 
getAlternativePlans(CostEstimator) - Method in class org.apache.flink.optimizer.dag.AbstractPartialSolutionNode
 
getAlternativePlans(CostEstimator) - Method in class org.apache.flink.optimizer.dag.BinaryUnionNode
 
getAlternativePlans(CostEstimator) - Method in class org.apache.flink.optimizer.dag.DataSinkNode
 
getAlternativePlans(CostEstimator) - Method in class org.apache.flink.optimizer.dag.DataSourceNode
 
getAlternativePlans(CostEstimator) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
Computes the plan alternatives for this node, an implicitly for all nodes that are children of this node.
getAlternativePlans(CostEstimator) - Method in class org.apache.flink.optimizer.dag.SingleInputNode
 
getAlternativePlans(CostEstimator) - Method in class org.apache.flink.optimizer.dag.TwoInputNode
 
getAnalyzedUdfSemanticsFlag() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
 
getAnalyzedUdfSemanticsFlag() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
 
getAndIncrement() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointIDCounter
Atomically increments the current checkpoint ID.
getAndIncrement() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
 
getAndIncrement() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
 
getAndLock(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Gets the RetrievableStateHandle stored in the given ZooKeeper node and locks it.
getAndRemove(String) - Method in class org.apache.flink.runtime.iterative.concurrent.Broker
blocking retrieval and removal of the object to share
getAppConfigurationEntry(String) - Method in class org.apache.flink.runtime.security.DynamicConfiguration
Retrieve the AppConfigurationEntries for the specified name from this Configuration.
getAppId() - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Attributes
 
getApplicationId() - Method in class org.apache.flink.yarn.YarnClusterClient
 
getApplicationId() - Method in class org.apache.flink.yarn.YarnClusterClientV2
 
getApplicationMasterClass() - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
The class to bootstrap the application master of the Yarn cluster (runs main method).
getApplicationMasterClass() - Method in class org.apache.flink.yarn.YarnClusterDescriptor
 
getApplicationMasterClass() - Method in class org.apache.flink.yarn.YarnClusterDescriptorV2
 
getApplicationStatus() - Method in class org.apache.flink.yarn.YarnClusterClient
 
getApplicationStatus() - Method in class org.apache.flink.yarn.YarnClusterClientV2
 
getApplyBcastVars() - Method in class org.apache.flink.graph.gsa.GSAConfiguration
Get the broadcast variables of the ApplyFunction.
getArchivedExecutionConfig() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns the ArchivedExecutionConfig for this execution graph.
getArchivedExecutionConfig() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getArchivedExecutionConfig() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Returns the serializable ArchivedExecutionConfig
getArchivedJsons(Path) - Static method in class org.apache.flink.runtime.history.FsJobArchivist
Reads the given archive file and returns a Collection of contained ArchivedJson.
getArchiveName(int) - Method in class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
getArchiveProps(Class<? extends MemoryArchivist>, int, Option<Path>) - Method in class org.apache.flink.runtime.jobmanager.JobManager$
 
getArchiveProps(Class<? extends MemoryArchivist>, int, Option<Path>) - Static method in class org.apache.flink.runtime.jobmanager.JobManager
 
getArchiveProps(Class<? extends MemoryArchivist>, int, Option<Path>) - Method in class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
getArchivistClass() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosApplicationMasterRunner
 
getArchivistClass() - Method in class org.apache.flink.yarn.YarnApplicationMasterRunner
 
getArgs() - Method in class org.apache.flink.client.cli.CancelOptions
 
getArgs() - Method in class org.apache.flink.client.cli.SavepointOptions
 
getArgs() - Method in class org.apache.flink.client.cli.StopOptions
 
getArgs() - Method in class org.apache.flink.runtime.rpc.akka.messages.LocalRpcInvocation
 
getArgs() - Method in class org.apache.flink.runtime.rpc.akka.messages.RemoteRpcInvocation
 
getArgs() - Method in interface org.apache.flink.runtime.rpc.akka.messages.RpcInvocation
Returns the arguments of the remote procedure call
getArguments() - Method in class org.apache.flink.client.program.PackagedProgram
 
getArity() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
getArity() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
getArity() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
getArity() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
getArity() - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
getArity() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
Gets the arity of this type - the number of fields without nesting.
getArity() - Method in class org.apache.flink.api.java.tuple.Tuple
Gets the number of field in the tuple (the tuple arity).
getArity() - Method in class org.apache.flink.api.java.tuple.Tuple0
 
getArity() - Method in class org.apache.flink.api.java.tuple.Tuple1
 
getArity() - Method in class org.apache.flink.api.java.tuple.Tuple10
 
getArity() - Method in class org.apache.flink.api.java.tuple.Tuple11
 
getArity() - Method in class org.apache.flink.api.java.tuple.Tuple12
 
getArity() - Method in class org.apache.flink.api.java.tuple.Tuple13
 
getArity() - Method in class org.apache.flink.api.java.tuple.Tuple14
 
getArity() - Method in class org.apache.flink.api.java.tuple.Tuple15
 
getArity() - Method in class org.apache.flink.api.java.tuple.Tuple16
 
getArity() - Method in class org.apache.flink.api.java.tuple.Tuple17
 
getArity() - Method in class org.apache.flink.api.java.tuple.Tuple18
 
getArity() - Method in class org.apache.flink.api.java.tuple.Tuple19
 
getArity() - Method in class org.apache.flink.api.java.tuple.Tuple2
 
getArity() - Method in class org.apache.flink.api.java.tuple.Tuple20
 
getArity() - Method in class org.apache.flink.api.java.tuple.Tuple21
 
getArity() - Method in class org.apache.flink.api.java.tuple.Tuple22
 
getArity() - Method in class org.apache.flink.api.java.tuple.Tuple23
 
getArity() - Method in class org.apache.flink.api.java.tuple.Tuple24
 
getArity() - Method in class org.apache.flink.api.java.tuple.Tuple25
 
getArity() - Method in class org.apache.flink.api.java.tuple.Tuple3
 
getArity() - Method in class org.apache.flink.api.java.tuple.Tuple4
 
getArity() - Method in class org.apache.flink.api.java.tuple.Tuple5
 
getArity() - Method in class org.apache.flink.api.java.tuple.Tuple6
 
getArity() - Method in class org.apache.flink.api.java.tuple.Tuple7
 
getArity() - Method in class org.apache.flink.api.java.tuple.Tuple8
 
getArity() - Method in class org.apache.flink.api.java.tuple.Tuple9
 
getArity() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
 
getArity() - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
 
getArity() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
 
getArity() - Method in class org.apache.flink.api.java.typeutils.ListTypeInfo
 
getArity() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
 
getArity() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
getArity() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
getArity() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
getArity() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
getArity() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
getArity() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
getArity() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
 
getArity() - Method in class org.apache.flink.api.scala.typeutils.EitherTypeInfo
 
getArity() - Method in class org.apache.flink.api.scala.typeutils.EnumValueTypeInfo
 
getArity() - Method in class org.apache.flink.api.scala.typeutils.OptionTypeInfo
 
getArity() - Method in class org.apache.flink.api.scala.typeutils.ScalaNothingTypeInfo
 
getArity() - Method in class org.apache.flink.api.scala.typeutils.TraversableTypeInfo
 
getArity() - Method in class org.apache.flink.api.scala.typeutils.TryTypeInfo
 
getArity() - Method in class org.apache.flink.api.scala.typeutils.UnitTypeInfo
 
getArity() - Method in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
 
getArity() - Method in class org.apache.flink.table.runtime.types.CRowTypeInfo
 
getArity() - Method in class org.apache.flink.table.typeutils.InternalTypeInfo
 
getArity() - Static method in class org.apache.flink.table.typeutils.RowIntervalTypeInfo
 
getArity() - Static method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
 
getArity() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
 
getArity() - Method in class org.apache.flink.types.Row
Get the number of fields in the Row.
getArray() - Method in class org.apache.flink.core.memory.HeapMemorySegment
Gets the byte array that backs this memory segment.
getArray() - Method in class org.apache.flink.core.memory.HybridMemorySegment
 
getArtifacts() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification
Get the container artifacts.
getAssignedResource() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
getAssignedResourceLocation() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
Returns the TaskManagerLocation for this execution.
getAssignedResourceLocation() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
 
getAssignedResourceLocation() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
getAssignedSlotRequest() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
getAssignmentMode() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo
 
getAssignmentMode() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo.Snapshot
 
getAsyncCheckpointDuration() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
Returns the duration of the asynchronous part of the checkpoint.
getAsyncCheckpointDurationStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
Returns the summary stats for the async checkpoint duration.
getAsyncDurationMillis() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
getAsyncExecutor() - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerServices
Gets the async executor which executes outside of the main thread of the ResourceManager
getAsyncOperationsThreadPool() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
getAttemptId() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
Returns the ExecutionAttemptID for this Execution.
getAttemptId() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
 
getAttemptId() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
getAttemptNumber() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Gets the attempt number of this parallel subtask.
getAttemptNumber() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getAttemptNumber() - Method in class org.apache.flink.api.common.TaskInfo
Gets the attempt number of this parallel subtask.
getAttemptNumber() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
Returns the attempt number of the subtask
getAttemptNumber() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
Returns the attempt number for this execution.
getAttemptNumber() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
 
getAttemptNumber() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
getAttributes() - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Places
 
getAttributes() - Method in interface org.apache.flink.streaming.connectors.nifi.NiFiDataPacket
 
getAttributes() - Method in class org.apache.flink.streaming.connectors.nifi.StandardNiFiDataPacket
 
getAuthorityScore() - Method in class org.apache.flink.graph.library.link_analysis.HITS.Result
Get the authority score.
getAutoWatermarkInterval() - Method in class org.apache.flink.api.common.ExecutionConfig
Returns the interval of the automatic watermark emission.
getAvailablePort() - Static method in class org.apache.flink.util.NetUtils
Find a non-occupied port.
getAverage() - Method in class org.apache.flink.runtime.checkpoint.MinMaxAvgStats
Calculates the average over all seen values.
getAverageClusteringCoefficient() - Method in class org.apache.flink.graph.library.clustering.directed.AverageClusteringCoefficient.Result
Get the average clustering coefficient.
getAverageClusteringCoefficient() - Method in class org.apache.flink.graph.library.clustering.undirected.AverageClusteringCoefficient.Result
Get the average clustering coefficient.
getAverageDegree() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
Get the average degree, the average number of in- plus out-edges per vertex.
getAverageDegree() - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics.Result
Get the average degree, the average number of edges per vertex.
getAverageRecordWidth() - Method in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
Gets the estimated average number of bytes per record.
getAverageRecordWidth() - Method in interface org.apache.flink.api.common.io.statistics.BaseStatistics
Gets the average width of a record, in bytes.
getAvgOutputRecordSize() - Method in class org.apache.flink.api.common.operators.CompilerHints
 
getBackendIdentifier() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
 
getBackoffType() - Method in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase.BulkFlushBackoffPolicy
 
getBackPressureRatio(int) - Method in class org.apache.flink.runtime.webmonitor.OperatorBackPressureStats
Returns the ratio of stack traces indicating back pressure to total number of sampled stack traces.
getBasePath() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
Gets the base directory where all state-containing files are stored.
getBaseStatistics(String) - Method in class org.apache.flink.optimizer.DataStatistics
Gets the base statistics for the input identified by the given identifier.
getBasicAndBasicValueTupleTypeInfo(Class<?>...) - Static method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
getBasicTupleTypeInfo(Class<?>...) - Static method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
getBatchBlocking() - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
Gets all the elements found in the list, or blocks until at least one element was added.
getBatchBlocking(long) - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
Gets all the elements found in the list, or blocks until at least one element was added.
getBatchModel() - Method in class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.Predictor
 
getBcastVars() - Method in class org.apache.flink.graph.pregel.VertexCentricConfiguration
Get the broadcast variables of the compute function.
getBinary(int) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getBinaryByField(String) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getBinaryLength() - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
 
getBinaryLength() - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
 
getBinaryLength() - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
 
getBinaryLength() - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
 
getBinaryLength() - Method in class org.apache.flink.types.BooleanValue
 
getBinaryLength() - Method in class org.apache.flink.types.ByteValue
 
getBinaryLength() - Method in class org.apache.flink.types.CharValue
 
getBinaryLength() - Method in interface org.apache.flink.types.CopyableValue
Gets the length of the data type when it is serialized, in bytes.
getBinaryLength() - Method in class org.apache.flink.types.DoubleValue
 
getBinaryLength() - Method in class org.apache.flink.types.FloatValue
 
getBinaryLength() - Method in class org.apache.flink.types.IntValue
 
getBinaryLength() - Method in class org.apache.flink.types.LongValue
 
getBinaryLength() - Method in class org.apache.flink.types.NullValue
 
getBinaryLength() - Method in class org.apache.flink.types.Record
 
getBinaryLength() - Method in class org.apache.flink.types.ShortValue
 
getBinaryLength() - Method in class org.apache.flink.types.StringValue
 
getBinaryOperatorReturnType(Function, Class<?>, int, int, int, int[], int[], int[], TypeInformation<IN1>, TypeInformation<IN2>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
Returns the binary operator's return type.
getBitmask() - Method in enum org.apache.flink.graph.EdgeOrder
Returns a bitmask used for marking whether an edge is in the same direction as in the original edge set (FORWARD), is flipped relative to the original edge set (REVERSE), or both (MUTUAL).
getBitmask() - Method in class org.apache.flink.graph.library.clustering.directed.TriangleListing.Result
Get the bitmask indicating the presence of the six potential connecting edges.
getBitSize(long) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
 
getBlobManagerPort() - Method in class org.apache.flink.runtime.jobmaster.message.ClassloadingProps
 
getBlobPort() - Method in class org.apache.flink.runtime.jobmaster.JMTMRegistrationSuccess
 
getBlobServerPort() - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
 
getBlockCount() - Method in class org.apache.flink.graph.generator.random.BlockInfo
 
getBlockCount() - Method in class org.apache.flink.runtime.io.disk.FileChannelOutputView
Gets the number of blocks written by this output view.
getBlockCount() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
Gets the number of blocks used by this view.
getBlockCount() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
 
getBlockCount() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ChannelWithBlockCount
 
getBlockIndex() - Method in class org.apache.flink.graph.generator.random.BlockInfo
 
getBlockSize() - Method in class org.apache.flink.api.common.io.BinaryInputFormat
 
getBlockSize() - Method in interface org.apache.flink.core.fs.FileStatus
Get the block size of the file.
getBlockSize() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
 
getBlockSize() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
 
getBoolean(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the Boolean value for the given key.
getBoolean(String, boolean) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the Boolean value for the given key.
getBoolean(String, boolean) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given key as a boolean.
getBoolean(ConfigOption<Boolean>) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as a boolean.
getBoolean(String, boolean) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getBoolean(ConfigOption<Boolean>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getBoolean(int) - Method in class org.apache.flink.core.memory.HeapMemorySegment
 
getBoolean(int) - Method in class org.apache.flink.core.memory.HybridMemorySegment
 
getBoolean(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads one byte at the given position and returns its boolean representation.
getBoolean(String, boolean) - Method in class org.apache.flink.metrics.MetricConfig
Searches for the property with the specified key in this property list.
getBoolean(int) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getBoolean(Properties, String, boolean) - Static method in class org.apache.flink.util.PropertiesUtil
Get boolean from properties.
getBooleanByField(String) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getBootstrap() - Method in class org.apache.flink.runtime.webmonitor.utils.WebFrontendBootstrap
 
getBottomId() - Method in class org.apache.flink.graph.bipartite.BipartiteEdge
 
getBottomVertices() - Method in class org.apache.flink.graph.bipartite.BipartiteGraph
Get dataset with bottom vertices.
getBounding_box() - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Places
 
getBranchesForParent(DagConnection) - Method in class org.apache.flink.optimizer.dag.DataSinkNode
 
getBranchesForParent(DagConnection) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
getBranchingNode() - Method in class org.apache.flink.optimizer.dag.OptimizerNode.UnclosedBranchDescriptor
 
getBranchPlan() - Method in class org.apache.flink.optimizer.plan.PlanNode
 
getBroadcastConnectionNames() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
Return the list of names associated with broadcast inputs for this node.
getBroadcastConnections() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
Return the list of inputs associated with broadcast variables for this node.
getBroadcastGroupSize(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getBroadcastInputName(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getBroadcastInputs() - Method in class org.apache.flink.api.common.operators.AbstractUdfOperator
Returns the input, or null, if none is set.
getBroadcastInputs() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
The BulkIteration meta operator cannot have broadcast inputs.
getBroadcastInputs() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
DeltaIteration meta operator cannot have broadcast inputs.
getBroadcastInputs() - Method in class org.apache.flink.optimizer.plan.PlanNode
Gets a list of all broadcast inputs attached to this node.
getBroadcastInputSerializer(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getBroadcastSet(String) - Method in class org.apache.flink.graph.gsa.ApplyFunction
Gets the broadcast data set registered under the given name.
getBroadcastSet(String) - Method in class org.apache.flink.graph.gsa.GatherFunction
Gets the broadcast data set registered under the given name.
getBroadcastSet(String) - Method in class org.apache.flink.graph.gsa.SumFunction
Gets the broadcast data set registered under the given name.
getBroadcastSet(String) - Method in class org.apache.flink.graph.pregel.ComputeFunction
Gets the broadcast data set registered under the given name.
getBroadcastSet(String) - Method in class org.apache.flink.graph.spargel.GatherFunction
Gets the broadcast data set registered under the given name.
getBroadcastSet(String) - Method in class org.apache.flink.graph.spargel.ScatterFunction
Gets the broadcast data set registered under the given name.
getBroadcastSets() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
 
getBroadcastSets() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
 
getBroadcastSets() - Method in interface org.apache.flink.api.java.operators.UdfOperator
Gets the broadcast sets (name and data set) that have been added to context of the UDF.
getBroadcastVariable(String) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Returns the result bound to the broadcast variable identified by the given name.
getBroadcastVariable(String) - Method in class org.apache.flink.api.common.functions.util.RuntimeUDFContext
 
getBroadcastVariable(String) - Method in class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
 
getBroadcastVariable(String) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
getBroadcastVariableManager() - Method in interface org.apache.flink.runtime.execution.Environment
 
getBroadcastVariableManager() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
 
getBroadcastVariableManager() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getBroadcastVariableWithInitializer(String, BroadcastVariableInitializer<T, C>) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Returns the result bound to the broadcast variable identified by the given name.
getBroadcastVariableWithInitializer(String, BroadcastVariableInitializer<T, C>) - Method in class org.apache.flink.api.common.functions.util.RuntimeUDFContext
 
getBroadcastVariableWithInitializer(String, BroadcastVariableInitializer<T, C>) - Method in class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
 
getBroadcastVariableWithInitializer(String, BroadcastVariableInitializer<T, C>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
getBrokerID(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getBucketBoundary(int, int) - Method in interface org.apache.flink.api.common.distributions.DataDistribution
Returns the i'th bucket's upper bound, given that the distribution is to be split into totalBuckets buckets.
getBucketPath(Clock, Path, T) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BasePathBucketer
 
getBucketPath(Clock, Path, T) - Method in interface org.apache.flink.streaming.connectors.fs.bucketing.Bucketer
Returns the Path of a bucket file.
getBucketPath(Clock, Path, T) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.DateTimeBucketer
 
getBuf() - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
getBuffer() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
getBufferPool() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
getBufferPool() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
 
getBufferProvider() - Method in class org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
 
getBufferProvider() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
getBufferProvider() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
 
getBufferSize() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
getBufferTimeout() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Gets the maximum time frequency (milliseconds) for the flushing of the output buffers.
getBufferTimeout() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getBufferTimeout() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getBufferTimeout() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
Returns the buffer timeout of the job.
getBufferTimeout() - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Gets the default buffer timeout set for this environment
getBufferTimeout() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
Returns the buffer timeout of this StreamTransformation.
getBuildComparator() - Method in class org.apache.flink.api.common.operators.util.JoinHashMap
 
getBuildSerializer() - Method in class org.apache.flink.api.common.operators.util.JoinHashMap
 
getBuildSideBlockCount() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
 
getBuildSideChannel() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
 
getBuildSideComparator() - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
 
getBuildSideIterator() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
getBuildSideRecordCount() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
 
getBuildSideSerializer() - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
 
getBuiltInDecoRuleSet() - Method in class org.apache.flink.table.api.StreamTableEnvironment
Returns the built-in decoration rules that are defined by the environment.
getBuiltInLogicalOptRuleSet() - Method in class org.apache.flink.table.api.TableEnvironment
Returns the built-in logical optimization rules that are defined by the environment.
getBuiltInNormRuleSet() - Method in class org.apache.flink.table.api.BatchTableEnvironment
Returns the built-in normalization rules that are defined by the environment.
getBuiltInNormRuleSet() - Method in class org.apache.flink.table.api.StreamTableEnvironment
Returns the built-in normalization rules that are defined by the environment.
getBuiltInNormRuleSet() - Method in class org.apache.flink.table.api.TableEnvironment
Returns the built-in normalization rules that are defined by the environment.
getBuiltInPhysicalOptRuleSet() - Method in class org.apache.flink.table.api.BatchTableEnvironment
Returns the built-in optimization rules that are defined by the environment.
getBuiltInPhysicalOptRuleSet() - Method in class org.apache.flink.table.api.StreamTableEnvironment
Returns the built-in optimization rules that are defined by the environment.
getBuiltInPhysicalOptRuleSet() - Method in class org.apache.flink.table.api.TableEnvironment
Returns the built-in physical optimization rules that are defined by the environment.
getByte(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the Byte value for the given key.
getByte(String, byte) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the Byte value for the given key.
getByte(int) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getByteArray() - Method in class org.apache.flink.migration.util.SerializedValue
Deprecated.
Returns the serialized value or null if no value is set.
getByteArray() - Method in class org.apache.flink.runtime.util.DataOutputSerializer
 
getByteArray() - Method in class org.apache.flink.util.SerializedValue
Returns the serialized value or null if no value is set.
getByteByField(String) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getByteDiff() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
 
getBytes(String, byte[]) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given key as a byte array.
getBytes(String, byte[]) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getBytes() - Method in class org.apache.flink.configuration.MemorySize
Gets the memory size in bytes.
getBytes() - Method in class org.apache.flink.util.AbstractID
Gets the bytes underlying this ID.
getBytesBufferedInAlignment() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
getBytesInLatestSegment() - Method in class org.apache.flink.runtime.io.disk.FileChannelOutputView
Gets the number of bytes written in the latest memory segment.
getBytesMemoryUsed() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
Gets the number of bytes used by this output view, including written bytes and header bytes.
getBytesWritten() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
Gets the number of pay-load bytes already written.
getBytesWritten() - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller
Gets the number of bytes written in the current spill file.
getCachedFile(String) - Method in class org.apache.flink.table.functions.FunctionContext
Gets the local temporary file copy of a distributed cache files.
getCachedFiles() - Method in class org.apache.flink.api.common.Plan
return the registered caches files
getCachedFiles() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Get the list of cached files that were registered for distribution among the task managers.
getCachedFiles() - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Gets cache files.
getCalciteConfig() - Method in class org.apache.flink.table.api.TableConfig
Returns the current configuration of Calcite for Table API and SQL queries.
getCall() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
getCallable() - Method in class org.apache.flink.runtime.rpc.akka.messages.CallAsync
 
getCallGenerator(SqlOperator, Seq<TypeInformation<?>>, TypeInformation<?>) - Method in class org.apache.flink.table.codegen.calls.FunctionGenerator$
Returns a CallGenerator that generates all required code for calling the given SqlOperator.
getCallGenerator(SqlOperator, Seq<TypeInformation<?>>, TypeInformation<?>) - Static method in class org.apache.flink.table.codegen.calls.FunctionGenerator
Returns a CallGenerator that generates all required code for calling the given SqlOperator.
getCallLocationName() - Static method in class org.apache.flink.api.java.Utils
 
getCallLocationName(int) - Static method in class org.apache.flink.api.java.Utils
 
getCancelables() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
getCandidateAtBranchPoint(OptimizerNode) - Method in class org.apache.flink.optimizer.plan.PlanNode
 
getCapacity() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
Gets the total capacity of this hash table, in bytes.
getCapacity() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
getCapacity() - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
Gets the total capacity of this sorter, in bytes.
getCapacity() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
getCategory() - Method in class org.apache.flink.runtime.metrics.dump.MetricDump.CounterDump
 
getCategory() - Method in class org.apache.flink.runtime.metrics.dump.MetricDump.GaugeDump
 
getCategory() - Method in class org.apache.flink.runtime.metrics.dump.MetricDump
Returns the category for this MetricDump.
getCategory() - Method in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
getCategory() - Method in class org.apache.flink.runtime.metrics.dump.MetricDump.MeterDump
 
getCategory() - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
Returns the category for this QueryScopeInfo.
getCategory() - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobManagerQueryScopeInfo
 
getCategory() - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobQueryScopeInfo
 
getCategory() - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
 
getCategory() - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskManagerQueryScopeInfo
 
getCategory() - Method in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
 
getCause() - Method in class org.apache.flink.runtime.query.netty.message.KvStateRequestFailure
Returns the failure cause.
getCause() - Static method in exception org.apache.flink.table.api.AmbiguousTableSourceConverterException
 
getCause() - Static method in exception org.apache.flink.table.api.CatalogAlreadyExistException
 
getCause() - Static method in exception org.apache.flink.table.api.CatalogNotExistException
 
getCause() - Static method in exception org.apache.flink.table.api.ExpressionParserException
 
getCause() - Static method in exception org.apache.flink.table.api.ExternalCatalogAlreadyExistException
 
getCause() - Static method in exception org.apache.flink.table.api.ExternalCatalogNotExistException
 
getCause() - Static method in exception org.apache.flink.table.api.NoMatchedTableSourceConverterException
 
getCause() - Static method in exception org.apache.flink.table.api.SqlParserException
 
getCause() - Static method in exception org.apache.flink.table.api.TableAlreadyExistException
 
getCause() - Static method in exception org.apache.flink.table.api.TableException
 
getCause() - Static method in exception org.apache.flink.table.api.TableNotExistException
 
getCause() - Static method in exception org.apache.flink.table.api.UnresolvedException
 
getCause() - Static method in exception org.apache.flink.table.api.ValidationException
 
getCbf() - Method in class org.apache.flink.api.scala.typeutils.TraversableSerializer
 
getCenterWidth() - Method in class org.apache.flink.ml.nn.QuadTree.Node
for testing purposes only; used in QuadTreeSuite.scala
getCentroidDataSet(ParameterTool, ExecutionEnvironment) - Method in class org.apache.flink.examples.scala.clustering.KMeans$
 
getCentroidDataSet(ParameterTool, ExecutionEnvironment) - Static method in class org.apache.flink.examples.scala.clustering.KMeans
 
getChainedOutputs(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getChainedStubConfig(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getChainedTask(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getChainedTaskName(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getChainEntryPoint() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
 
getChainIndex() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getChainingStrategy() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getChainingStrategy() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
 
getChainLength() - Method in class org.apache.flink.runtime.checkpoint.TaskState
Deprecated.
 
getChainLength() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
 
getChannel() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ChannelWithBlockCount
 
getChannel() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
 
getChannelID() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
 
getChannelID() - Method in interface org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
Gets the channel ID of this I/O channel.
getChannelIndex() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
getChar(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads a char value from the given position, in the system's native byte order.
getCharArray() - Method in class org.apache.flink.types.StringValue
Returns this StringValue's internal character data.
getCharBigEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads an character value (16 bit, 2 bytes) from the given position, in big-endian byte order.
getCharLittleEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads an character value (16 bit, 2 bytes) from the given position, in little-endian byte order.
getCharset() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
Get the character set used for the row delimiter.
getCharset() - Method in class org.apache.flink.api.java.io.CsvReader
Gets the character set for the reader.
getCharset() - Method in class org.apache.flink.streaming.util.serialization.SimpleStringSchema
Gets the charset used by this schema for serialization.
getCharset() - Static method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
getCharset() - Method in class org.apache.flink.types.parser.FieldParser
Gets the character set used for this parser.
getCharsetName() - Method in class org.apache.flink.api.java.io.TextInputFormat
 
getCharsetName() - Method in class org.apache.flink.api.java.io.TextOutputFormat
 
getCharsetName() - Method in class org.apache.flink.api.java.io.TextValueInputFormat
 
getCheckpointById(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
 
getCheckpointConfig() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Gets the checkpoint config, which defines values like checkpoint interval, delay between checkpoints, etc.
getCheckpointConfig() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getCheckpointConfig() - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Gets the checkpoint config, which defines values like checkpoint interval, delay between checkpoints, etc.
getCheckpointCoordinator() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns the CheckpointCoordinator for this execution graph.
getCheckpointCoordinator() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getCheckpointCoordinator() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getCheckpointId() - Method in class org.apache.flink.migration.runtime.checkpoint.savepoint.SavepointV0
 
getCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
Returns the ID of this checkpoint.
getCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetaData
 
getCheckpointID() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
getCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
getCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.RestoredCheckpointStats
Returns the ID of this checkpoint.
getCheckpointId() - Method in interface org.apache.flink.runtime.checkpoint.savepoint.Savepoint
Returns the checkpoint ID of the savepoint.
getCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
 
getCheckpointId() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
 
getCheckpointId() - Method in class org.apache.flink.runtime.io.network.api.CancelCheckpointMarker
 
getCheckpointId() - Method in class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
 
getCheckpointId() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
 
getCheckpointId() - Method in interface org.apache.flink.runtime.state.ManagedSnapshotContext
Returns the ID of the checkpoint for which the snapshot is taken.
getCheckpointId() - Method in class org.apache.flink.runtime.state.SerializedCheckpointData
Gets the checkpointId of the checkpoint.
getCheckpointId() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
 
getCheckpointIdCounter() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
getCheckpointingMode() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
Gets the checkpointing mode (exactly-once vs.
getCheckpointingMode() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Returns the checkpointing mode (exactly-once vs.
getCheckpointingMode() - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
 
getCheckpointingSettings() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Gets the settings for asynchronous snapshots.
getCheckpointInterval() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
getCheckpointInterval() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
Gets the interval in which checkpoints are periodically scheduled.
getCheckpointInterval() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Returns the checkpointing interval or -1 if checkpointing is disabled.
getCheckpointLock() - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
Returns the checkpoint lock.
getCheckpointLock() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
Gets the lock object on which all operations that involve data and state mutation have to lock.
getCheckpointMetrics() - Method in class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
 
getCheckpointMode() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getCheckpointMode() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
Returns the checkpointing mode.
getCheckpointOptions() - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
 
getCheckpointOptions() - Method in class org.apache.flink.runtime.messages.checkpoint.TriggerCheckpoint
 
getCheckpointRecoveryFactory() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
Gets the checkpoint recovery factory for the job manager
getCheckpointRecoveryFactory() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
 
getCheckpointRecoveryFactory() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
getCheckpointRecoveryFactory() - Method in class org.apache.flink.yarn.highavailability.AbstractYarnNonHaServices
 
getCheckpointResponder() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
getCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
 
getCheckpointStatsSnapshot() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns a snapshot of the checkpoint statistics or null if checkpointing is disabled.
getCheckpointStatsSnapshot() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getCheckpointStatsSnapshot() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getCheckpointStore() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
getCheckpointTimeout() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
getCheckpointTimeout() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
getCheckpointTimeout() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
Gets the maximum time that a checkpoint may take before being discarded.
getCheckpointTimestamp() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
getCheckpointTimestamp() - Method in interface org.apache.flink.runtime.state.ManagedSnapshotContext
Returns timestamp (wall clock time) when the master node triggered the checkpoint for which the state snapshot is taken.
getCheckpointTimestamp() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
 
getCheckpointType() - Method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
Returns the type of checkpoint to perform.
getChecksum() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
 
getChecksum() - Method in class org.apache.flink.graph.asm.dataset.ChecksumHashCode.Checksum
Get the checksum over the hash() of elements.
getChild(ActorRef, String, ActorSystem, FiniteDuration) - Method in class org.apache.flink.runtime.akka.AkkaUtils$
Returns a Future to the ActorRef of the child of a given actor.
getChild(ActorRef, String, ActorSystem, FiniteDuration) - Static method in class org.apache.flink.runtime.akka.AkkaUtils
Returns a Future to the ActorRef of the child of a given actor.
getChildExps() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
getChildExps() - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
getChildExps() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
getChildExps() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
getChildExps() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
getChildExps() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
getChildExps() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
getChildExps() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
getChildExps() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
getChildExps() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
getChildExps() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
getChildExps() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
getChildExps() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
getChildExps() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
getChildExps() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
getChildExps() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getChildRelNodes(RelNode) - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamRetractionRules$
Get all children RelNodes of a RelNode.
getChildRelNodes(RelNode) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamRetractionRules
Get all children RelNodes of a RelNode.
getChoices() - Method in class org.apache.flink.api.java.utils.Option
 
getClass(String, Class<? extends T>, ClassLoader) - Method in class org.apache.flink.configuration.Configuration
Returns the class associated with the given key as a string.
getClass(String, Class<? extends T>, ClassLoader) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getClassLoader() - Method in class org.apache.flink.runtime.client.JobListeningContext
The class loader necessary to deserialize the result of a job execution, i.e.
getClassLoader(JobID) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
 
getClassLoader(JobID) - Method in class org.apache.flink.runtime.execution.librarycache.FallbackLibraryCacheManager
 
getClassLoader(JobID) - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
Returns the user code class loader associated with id.
getClasspaths() - Method in class org.apache.flink.client.cli.ProgramOptions
 
getClasspaths() - Method in class org.apache.flink.client.program.ContextEnvironment
 
getClasspaths() - Method in class org.apache.flink.client.program.JobWithJars
Returns list of classpaths that need to be submitted with the plan.
getClasspaths() - Method in class org.apache.flink.client.program.PackagedProgram
Returns the classpaths that are required by the program.
getClasspaths() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
 
getClazz() - Method in class org.apache.flink.util.ReflectionUtil.FullTypeInfo
 
getClazzIterator() - Method in class org.apache.flink.util.ReflectionUtil.FullTypeInfo
 
getCleanupInterval() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getCleanUpInterval() - Method in class org.apache.flink.runtime.webmonitor.BackPressureStatsTracker
Cleanup interval for completed stats cache.
getClient() - Method in class org.apache.flink.client.program.ContextEnvironment
 
getClient() - Method in class org.apache.flink.storm.api.FlinkClient
Return a reference to itself.
getClientChannelHandlers() - Method in interface org.apache.flink.runtime.io.network.netty.NettyProtocol
 
getClientConfiguration() - Method in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
 
getClientConnectTimeoutSeconds() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
getClientMessageClass() - Method in class org.apache.flink.runtime.client.JobAttachmentClientActor
 
getClientMessageClass() - Method in class org.apache.flink.runtime.client.JobClientActor
Hook to let the client know about messages that should start a timer for a timeout
getClientMessageClass() - Method in class org.apache.flink.runtime.client.JobSubmissionClientActor
 
getClientNumThreads() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
getClientSecurityConfigurationMap() - Static method in class org.apache.flink.test.util.SecureTestEnvironment
 
getClientTimeout(Configuration) - Method in class org.apache.flink.runtime.akka.AkkaUtils$
 
getClientTimeout(Configuration) - Static method in class org.apache.flink.runtime.akka.AkkaUtils
 
getClosableRegistry() - Method in class org.apache.flink.runtime.state.StateInitializationContextImpl
 
getClosedBranchingNodes() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
getCluster() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
 
getCluster() - Method in class org.apache.flink.streaming.connectors.cassandra.ClusterBuilder
 
getCluster() - Method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
getCluster() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
getCluster() - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
getCluster() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
getCluster() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
getCluster() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
getCluster() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
getCluster() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
getCluster() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
getCluster() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
getCluster() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
getCluster() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
getCluster() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
getCluster() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
getCluster() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
getCluster() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
getCluster() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getClusterDescription() - Method in interface org.apache.flink.client.deployment.ClusterDescriptor
Returns a String containing details about the cluster (NodeManagers, available memory, ...)
getClusterDescription() - Method in class org.apache.flink.client.deployment.StandaloneClusterDescriptor
 
getClusterDescription() - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
 
getClusterDescriptor() - Method in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
 
getClusterIdentifier() - Method in class org.apache.flink.client.program.ClusterClient
Returns a string representation of the cluster.
getClusterIdentifier() - Method in class org.apache.flink.client.program.StandaloneClusterClient
 
getClusterIdentifier() - Method in class org.apache.flink.yarn.YarnClusterClient
 
getClusterIdentifier() - Method in class org.apache.flink.yarn.YarnClusterClientV2
 
getClusterInfo() - Method in class org.apache.flink.storm.api.FlinkLocalCluster
 
getClusterStatus() - Method in class org.apache.flink.client.program.ClusterClient
Returns the latest cluster status, with number of Taskmanagers and slots
getClusterStatus() - Method in class org.apache.flink.client.program.StandaloneClusterClient
 
GetClusterStatus - Class in org.apache.flink.runtime.clusterframework.messages
Message sent to the resource manager to request a GetClusterStatusResponse which contains the current number of task managers and the total number of task slots.
getClusterStatus() - Method in class org.apache.flink.yarn.YarnClusterClient
This method is only available if the cluster hasn't been started in detached mode.
getClusterStatus() - Method in class org.apache.flink.yarn.YarnClusterClientV2
This method is only available if the cluster hasn't been started in detached mode.
GetClusterStatusResponse - Class in org.apache.flink.runtime.clusterframework.messages
The reply to a GetClusterStatus message sent by the job manager.
GetClusterStatusResponse(int, int) - Constructor for class org.apache.flink.runtime.clusterframework.messages.GetClusterStatusResponse
 
getCodeAnalysisMode() - Method in class org.apache.flink.api.common.ExecutionConfig
Returns the CodeAnalysisMode of the program.
getCoGroupReturnTypes(CoGroupFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getCoGroupReturnTypes(CoGroupFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getCollation() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
getCollation() - Static method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
getCollationList() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
getCollationList() - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
getCollationList() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
getCollationList() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
getCollationList() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
getCollationList() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
getCollationList() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
getCollationList() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
getCollationList() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
getCollationList() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
getCollationList() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
getCollationList() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
getCollationList() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
getCollationList() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
getCollationList() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
getCollationList() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getCollations() - Method in class org.apache.flink.table.plan.stats.FlinkStatistic
 
getCollector() - Method in class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
 
getCollector() - Method in class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
 
getCollector() - Method in class org.apache.flink.table.runtime.TableFunctionCollector
Gets the internal collector which used to emit the final row.
getCollectorValues() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
getCoLocationGroup() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getCoLocationGroup() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
getColumnFamily(StateDescriptor<?, S>, TypeSerializer<N>) - Method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
Creates a column family handle for use with a k/v state.
getColumnMappings() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
getColumnMonotonicities() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
 
getColumnName(int) - Method in class org.apache.flink.table.api.TableSchema
Returns the specified column name for the given column index.
getColumnNames() - Method in class org.apache.flink.table.api.TableSchema
Returns all column names as an array.
getColumnOptions() - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
Gets the RocksDB ColumnFamilyOptions to be used for all RocksDB instances.
getColumnStats(String) - Method in class org.apache.flink.table.plan.stats.FlinkStatistic
Returns the stats of the specified the column.
getCombineHint() - Method in class org.apache.flink.api.common.operators.base.ReduceOperatorBase
 
getCombinerUtilityNode() - Method in class org.apache.flink.optimizer.dag.GroupReduceNode
 
getCombinerUtilityNode() - Method in class org.apache.flink.optimizer.dag.ReduceNode
 
getCommandLine() - Method in class org.apache.flink.client.cli.CommandLineOptions
 
getCommentPrefix() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
getCommittedOffset() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionState
 
getCommittedOffset(KafkaTopicPartition) - Method in class org.apache.flink.streaming.connectors.kafka.internals.ZookeeperOffsetHandler
 
getCommonFileExtensions() - Method in class org.apache.flink.api.common.io.compression.Bzip2InputStreamFactory
 
getCommonFileExtensions() - Method in class org.apache.flink.api.common.io.compression.DeflateInflaterInputStreamFactory
 
getCommonFileExtensions() - Method in class org.apache.flink.api.common.io.compression.GzipInflaterInputStreamFactory
 
getCommonFileExtensions() - Method in interface org.apache.flink.api.common.io.compression.InflaterInputStreamFactory
Lists a collection of typical file extensions (e.g., "gz", "gzip") that are associated with the compression algorithm in the InflaterInputStream T.
getCommonFileExtensions() - Method in class org.apache.flink.api.common.io.compression.XZInputStreamFactory
 
getComparability() - Static method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
getComparator(int) - Method in class org.apache.flink.optimizer.plan.SingleInputPlanNode
Gets the specified comparator from this PlanNode.
getComparator1() - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
 
getComparator2() - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
 
getComparatorWithCurrentReference() - Method in class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator
 
getComparatorWithCurrentReference() - Method in class org.apache.flink.runtime.util.ReusingKeyGroupedIterator
 
getCompatibleVersions() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot
 
getCompatibleVersions() - Method in class org.apache.flink.api.scala.typeutils.EnumValueSerializer.ScalaEnumSerializerConfigSnapshot
 
getCompatibleVersions() - Method in class org.apache.flink.core.io.VersionedIOReadableWritable
Returns the compatible version values.
getCompatibleVersions() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
 
getCompatibleVersions() - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
 
getCompiler_hints() - Method in class org.apache.flink.table.explain.Node
 
getCompilerHints() - Method in class org.apache.flink.api.common.operators.Operator
Gets the compiler hints for this contract instance.
getCompletionFuture() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
Returns the completion future.
getComponentClass() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
Gets the class that represents the component type.
getComponentClass() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializerConfigSnapshot
 
getComponentConfiguration() - Method in class org.apache.flink.storm.exclamation.operators.ExclamationBolt
 
getComponentConfiguration() - Method in class org.apache.flink.storm.util.AbstractBoltSink
 
getComponentConfiguration() - Method in class org.apache.flink.storm.util.AbstractLineSpout
 
getComponentConfiguration() - Method in class org.apache.flink.storm.util.NullTerminatingSpout
 
getComponentConfiguration() - Method in class org.apache.flink.storm.wordcount.operators.BoltCounter
 
getComponentConfiguration() - Method in class org.apache.flink.storm.wordcount.operators.BoltCounterByName
 
getComponentConfiguration() - Method in class org.apache.flink.storm.wordcount.operators.BoltTokenizer
 
getComponentConfiguration() - Method in class org.apache.flink.storm.wordcount.operators.BoltTokenizerByName
 
getComponentInfo() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
getComponentInfo() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
getComponentType() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
Gets the type information of the component type.
getComponentType() - Static method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
getComponentTypeClass() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
GetCompositeField - Class in org.apache.flink.table.expressions
 
GetCompositeField(Expression, Object) - Constructor for class org.apache.flink.table.expressions.GetCompositeField
 
GetCompositeField$ - Class in org.apache.flink.table.expressions
 
GetCompositeField$() - Constructor for class org.apache.flink.table.expressions.GetCompositeField$
 
getCondition() - Method in class org.apache.flink.cep.nfa.StateTransition
 
getCondition() - Method in class org.apache.flink.cep.pattern.Pattern
 
getCondition() - Method in class org.apache.flink.cep.scala.pattern.Pattern
 
getCondition() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
getConditionContext() - Method in class org.apache.flink.cep.nfa.ComputationState
 
getConfig() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Gets the config object that defines execution parameters.
getConfig() - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Gets the config object.
getConfig() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Gets the config object.
getConfig() - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Gets the config object.
getConfig() - Method in class org.apache.flink.table.api.TableEnvironment
Returns the table config to define the runtime behavior of the Table API.
getConfigDir() - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
 
getConfigDir() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerCliOptions
 
getConfiguration() - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
getConfiguration() - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
 
getConfiguration() - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns a Configuration object from this ParameterTool
getConfiguration() - Method in class org.apache.flink.client.CliFrontend
Getter which returns a copy of the associated configuration
getConfiguration() - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
Returns the Configuration of the HCatInputFormat.
getConfiguration() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
Returns the vertex's configuration object which can be used to pass custom settings to the task at runtime.
getConfiguration() - Method in class org.apache.flink.runtime.minicluster.StandaloneMiniCluster
 
getConfiguration() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
Gets the configuration that holds the actual values encoded.
getConfiguration() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getConfiguration() - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo
Gets the configuration that the TaskManager was started with.
getConfiguration() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getConfiguration() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
getConfigurationDirectoryFromEnv() - Static method in class org.apache.flink.client.CliFrontend
 
getConfiguredClient(Map) - Static method in class org.apache.flink.storm.api.FlinkClient
Returns a FlinkClient that uses the configured Config.NIMBUS_HOST and Config.NIMBUS_THRIFT_PORT as JobManager address.
getConfiguredMemory() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
Returns the size of the managed memory (in megabytes), if configured.
getConnectionFactory() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig
 
getConnectionId() - Method in class org.apache.flink.runtime.clusterframework.messages.ReconnectResourceManager
 
getConnectionId() - Method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
 
getConnectionIndex() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
 
getConnectionIndex() - Method in class org.apache.flink.runtime.io.network.ConnectionID
 
getConnectionManager() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
getConnectionTimeout() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig
Retrieve the connection timeout.
getConstants() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
getConsumedPartitionId() - Method in class org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor
 
getConsumedPartitionLocation() - Method in class org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor
 
getConsumedPartitionType() - Method in class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
Returns the type of this input channel's consumed result partition.
getConsumedPartitionType() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
Returns the type of this input channel's consumed result partition.
getConsumedResultId() - Method in class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
 
getConsumedResultId() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
getConsumedSubpartitionIndex() - Method in class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
 
getConsumers() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
 
getConsumers() - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
 
getConsumingStrategy() - Method in class org.apache.flink.cep.pattern.Quantifier
 
getContainedTypeSerializer() - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer
 
getContainedTypeSerializer() - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.StreamRecordSerializer
 
getContainedTypeSerializer() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
getContainerMapping() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
getContainingBulkIteration() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.PartialSolutionPlaceHolder
 
getContainingIterationNode() - Method in class org.apache.flink.optimizer.plan.BulkPartialSolutionPlanNode
 
getContainingIterationNode() - Method in class org.apache.flink.optimizer.plan.SolutionSetPlanNode
 
getContainingIterationNode() - Method in class org.apache.flink.optimizer.plan.WorksetPlanNode
 
getContainingTask() - Method in class org.apache.flink.runtime.operators.BatchTask
 
getContainingTask() - Method in interface org.apache.flink.runtime.operators.TaskContext
 
getContainingTask() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getContainingWorksetIteration() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase.SolutionSetPlaceHolder
 
getContainingWorksetIteration() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase.WorksetPlaceHolder
 
getContent() - Method in interface org.apache.flink.streaming.connectors.nifi.NiFiDataPacket
 
getContent() - Method in class org.apache.flink.streaming.connectors.nifi.StandardNiFiDataPacket
 
getContents() - Method in class org.apache.flink.table.explain.Node
 
getContext() - Method in class org.apache.flink.graph.Graph
 
getContributors() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
getConvention() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
getConvention() - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
getConvention() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
getConvention() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
getConvention() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
getConvention() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
getConvention() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
getConvention() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
getConvention() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
getConvention() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
getConvention() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
getConvention() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
getConvention() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
getConvention() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
getConvention() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
getConvention() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getConvergenceCriterion() - Method in class org.apache.flink.api.common.aggregators.AggregatorRegistry
 
getConvergenceCriterion(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getConvergenceCriterionAggregatorName() - Method in class org.apache.flink.api.common.aggregators.AggregatorRegistry
 
getConvergenceCriterionAggregatorName() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getConversionMapper(TypeInformation<IN>, RowSchema, TypeInformation<OUT>, String) - Method in class org.apache.flink.table.api.BatchTableEnvironment
Creates a final converter that maps the internal row type to external type.
getConversionMapper(TypeInformation<IN>, RowSchema, TypeInformation<OUT>, String) - Method in class org.apache.flink.table.api.StreamTableEnvironment
Creates a final converter that maps the internal row type to external type.
getConvertDeserializer() - Method in class org.apache.flink.api.common.typeutils.CompatibilityResult
 
getCoordinates() - Method in class org.apache.flink.contrib.tweetinputformat.model.places.BoundingBox
 
getCoordinates() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Coordinates
 
getCoordinates() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
getCopyOfBuffer() - Method in class org.apache.flink.runtime.util.DataOutputSerializer
 
getCorrectHostnamePort(String) - Static method in class org.apache.flink.util.NetUtils
Method to validate if the given String represents a hostname:port.
getCorrelationId() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
getCorrelVariable() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
getCorrelVariable() - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
getCorrelVariable() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
getCorrelVariable() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
getCorrelVariable() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
getCorrelVariable() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
getCorrelVariable() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
getCorrelVariable() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
getCorrelVariable() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
getCorrelVariable() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
getCorrelVariable() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
getCorrelVariable() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
getCorrelVariable() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
getCorrelVariable() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
getCorrelVariable() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
getCorrelVariable() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getCosts() - Method in class org.apache.flink.table.explain.Node
 
getCostWeight() - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
 
getCostWeight() - Method in class org.apache.flink.optimizer.dag.DagConnection
 
getCostWeight() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
getCostWeight() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
 
getCostWeight() - Method in class org.apache.flink.optimizer.plan.Channel
 
getCostWeight() - Method in class org.apache.flink.optimizer.plan.PlanNode
 
getCount() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
 
getCount() - Method in class org.apache.flink.dropwizard.metrics.DropwizardHistogramWrapper
 
getCount() - Method in class org.apache.flink.dropwizard.metrics.DropwizardMeterWrapper
 
getCount() - Method in class org.apache.flink.dropwizard.metrics.FlinkCounterWrapper
 
getCount() - Method in class org.apache.flink.dropwizard.metrics.FlinkHistogramWrapper
 
getCount() - Method in class org.apache.flink.dropwizard.metrics.FlinkMeterWrapper
 
getCount() - Method in class org.apache.flink.graph.asm.dataset.ChecksumHashCode.Checksum
Get the number of elements.
getCount() - Method in interface org.apache.flink.metrics.Counter
Returns the current count.
getCount() - Method in interface org.apache.flink.metrics.Histogram
Get the count of seen elements.
getCount() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxCounterMBean
 
getCount() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxHistogramMBean
 
getCount() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxMeterMBean
 
getCount() - Method in interface org.apache.flink.metrics.Meter
Get number of events marked on the meter.
getCount() - Method in class org.apache.flink.metrics.MeterView
 
getCount() - Method in class org.apache.flink.metrics.SimpleCounter
Returns the current count.
getCount() - Method in class org.apache.flink.metrics.util.TestMeter
 
getCount() - Method in class org.apache.flink.runtime.checkpoint.MinMaxAvgStats
Returns the count of all seen values.
getCount003() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
Get the count of "003" triads which have zero connecting vertices.
getCount012() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
Get the count of "012" triads which have one unidirectional edge among the vertices.
getCount021c() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
Get the count of "021c" triads which have two unidirectional edges among the vertices, forming an open triplet; one edge sources and one edge targets the center vertex.
getCount021d() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
Get the count of "021d" triads which have two unidirectional edges among the vertices, forming an open triplet; both edges source the center vertex.
getCount021u() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
Get the count of "021u" triads which have two unidirectional edges among the vertices, forming an open triplet; both edges target the center vertex.
getCount03() - Method in class org.apache.flink.graph.library.clustering.undirected.TriadicCensus.Result
Get the count of "03" triads which have zero connecting vertices.
getCount030c() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
Get the count of "030c" triads which have three unidirectional edges among the vertices, forming a closed triplet, a triangle; the three unidirectional edges both source and target different vertices.
getCount030t() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
Get the count of "030t" triads which have three unidirectional edges among the vertices, forming a closed triplet, a triangle; two of the unidirectional edges source/target the same vertex.
getCount102() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
Get the count of "102" triads which have one bidirectional edge among the vertices.
getCount111d() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
Get the count of "111d" triads which have one unidirectional and one bidirectional edge among the vertices, forming an open triplet; the unidirectional edge targets the center vertex.
getCount111u() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
Get the count of "111u" triads which have one unidirectional and one bidirectional edge among the vertices, forming an open triplet; the unidirectional edge sources the center vertex.
getCount12() - Method in class org.apache.flink.graph.library.clustering.undirected.TriadicCensus.Result
Get the count of "12" triads which have one edge among the vertices.
getCount120c() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
Get the count of "120c" triads which have two unidirectional edges and one bidirectional edge among the vertices, forming a closed triplet, a triangle; one vertex is sourced by and targeted by the unidirectional edges.
getCount120d() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
Get the count of "120d" triads which have two unidirectional edges and one bidirectional edge among the vertices, forming a closed triplet, a triangle; both unidirectional edges source the same vertex.
getCount120u() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
Get the count of "120u" triads which have two unidirectional and one bidirectional edges among the vertices, forming a closed triplet, a triangle; both unidirectional edges target the same vertex.
getCount201() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
Get the count of "201" triads which have two unidirectional edges among the vertices, forming an open triplet.
getCount21() - Method in class org.apache.flink.graph.library.clustering.undirected.TriadicCensus.Result
Get the count of "21" triads which have two edges among the vertices and form a open triplet.
getCount210() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
Get the count of "210" triads which have one unidirectional edge and two bidirectional edges among the vertices, forming a closed triplet, a triangle.
getCount30() - Method in class org.apache.flink.graph.library.clustering.undirected.TriadicCensus.Result
Get the count of "30" triads which have three edges among the vertices and form a closed triplet, a triangle.
getCount300() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
Get the count of "300" triads which have three bidirectional edges among the vertices, forming a closed triplet, a triangle.
getCounter(Enum<?>) - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyReporter
 
getCounter(String, String) - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyReporter
 
getCounter() - Method in class org.apache.flink.cep.nfa.ComputationState
 
getCountry() - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Places
 
getCountry_code() - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Places
 
getCounts() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
Get the array of counts.
getCounts() - Method in class org.apache.flink.graph.library.clustering.undirected.TriadicCensus.Result
Get the array of counts.
getCounts() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsSnapshot
Returns the snapshotted checkpoint counts.
getCpu() - Method in class org.apache.flink.table.plan.cost.DataSetCost
 
getCpuCores() - Method in class org.apache.flink.api.common.operators.ResourceSpec
 
getCpuCores() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
Get the cpu cores needed
getCpuCost() - Method in class org.apache.flink.optimizer.costs.Costs
Gets the cost for the CPU.
getCreated_at() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
getCreated_at() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getCreateDump() - Static method in class org.apache.flink.runtime.metrics.dump.MetricQueryService
 
getCreationTimestamp() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
getCredentialsFromUGI(UserGroupInformation) - Static method in class org.apache.flink.api.java.hadoop.common.HadoopInputFormatCommonBase
This method only exists because there is no UserGroupInformation.getCredentials() method in Hadoop 1.x Note that this method returns "null" in Hadoop 1.x environments.
getCrossHint() - Method in class org.apache.flink.api.common.operators.base.CrossOperatorBase
 
getCrossHint() - Method in class org.apache.flink.api.java.operators.CrossOperator
 
getCrossReturnTypes(CrossFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getCrossReturnTypes(CrossFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getCumulativeCosts() - Method in class org.apache.flink.optimizer.plan.PlanNode
Gets the cumulative costs of this nose.
getCumulativeCostsShare() - Method in class org.apache.flink.optimizer.plan.PlanNode
 
getCurrent() - Method in class org.apache.flink.api.common.operators.util.ListKeyGroupedIterator.ValuesIterator
 
getCurrent() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable.ProbeIterator
 
getCurrent() - Method in interface org.apache.flink.runtime.util.KeyGroupedIterator
 
getCurrent() - Method in class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator
 
getCurrent() - Method in class org.apache.flink.runtime.util.ReusingKeyGroupedIterator
 
getCurrent() - Method in class org.apache.flink.util.LongValueSequenceIterator
 
getCurrent() - Method in class org.apache.flink.util.NumberSequenceIterator
 
getCurrentAllocation(int) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Get the current allocation for the task slot with the given index.
getCurrentAssignedResource() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getCurrentAssignedResourceLocation() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
Returns the TaskManagerLocation for this execution vertex.
getCurrentAssignedResourceLocation() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
 
getCurrentAssignedResourceLocation() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getCurrentBackoff() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
Returns the current backoff in ms.
getCurrentBuffer() - Method in class org.apache.flink.runtime.io.network.api.serialization.AdaptiveSpanningRecordDeserializer
 
getCurrentBuffer() - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
 
getCurrentBuffer() - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
Retrieves the current target buffer and sets its size to the actual number of written bytes.
getCurrentBuffer() - Method in class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
 
getCurrentBuffer() - Method in class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
 
getCurrentCheckpointId() - Method in class org.apache.flink.streaming.runtime.io.BarrierBuffer
Gets the ID defining the current pending, or just completed, checkpoint.
getCurrentConfiguration() - Method in class org.apache.flink.runtime.security.modules.JaasModule
 
getCurrentExecutionAttempt() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
Returns the current execution for this execution vertex.
getCurrentExecutionAttempt() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
 
getCurrentExecutionAttempt() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getCurrentKey() - Method in class org.apache.flink.hadoopcompatibility.mapred.wrapper.HadoopTupleUnwrappingIterator
 
getCurrentKey() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
getCurrentKey() - Method in interface org.apache.flink.runtime.state.heap.InternalKeyContext
Used by states to access the current key.
getCurrentKey() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getCurrentKey() - Method in interface org.apache.flink.streaming.api.operators.KeyContext
 
getCurrentKeyGroup() - Method in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
Returns the key group that is currently being written.
getCurrentKeyGroupIndex() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
getCurrentKeyGroupIndex() - Method in interface org.apache.flink.runtime.state.heap.InternalKeyContext
Returns the key-group to which the current key belongs.
getCurrentlyRunningJobsJava() - Method in class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
getCurrentNumberOfSubtasks() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
Returns the current number of subtasks the respective task is split into.
getCurrentOffset() - Method in class org.apache.flink.runtime.io.disk.SimpleCollectingOutputView
 
getCurrentOperatingSystem() - Static method in enum org.apache.flink.util.OperatingSystem
Gets the operating system that the JVM runs on from the java system properties.
getCurrentPartialSolutionPlanNode() - Method in class org.apache.flink.optimizer.dag.BulkPartialSolutionNode
 
getCurrentPartitionWatermark() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionStateWithPunctuatedWatermarks
 
getCurrentPositionInSegment() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
Gets the position from which the next byte will be read.
getCurrentPositionInSegment() - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
Gets the current write position (the position where the next bytes will be written) in the current memory segment.
getCurrentProbeRecord() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
getCurrentProcessingTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner.WindowAssignerContext
Returns the current processing time.
getCurrentProcessingTime() - Method in interface org.apache.flink.streaming.api.windowing.evictors.Evictor.EvictorContext
Returns the current processing time.
getCurrentProcessingTime() - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
Returns the current processing time.
getCurrentProcessingTime() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
getCurrentProcessingTime() - Method in class org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
Returns the current processing time.
getCurrentProcessingTime() - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
 
getCurrentProcessingTime() - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
getCurrentRestartAttempt() - Method in class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
 
getCurrentSegment() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
Gets the memory segment that will be used to read the next bytes from.
getCurrentSegment() - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
Gets the segment that the view currently writes to.
getCurrentSegmentLimit() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
Gets the current limit in the memory segment.
getCurrentSolutionSetPlanNode() - Method in class org.apache.flink.optimizer.dag.SolutionSetNode
 
getCurrentState() - Method in class org.apache.flink.api.common.io.BinaryInputFormat
 
getCurrentState() - Method in interface org.apache.flink.api.common.io.CheckpointableInputFormat
Returns the split currently being read, along with its current state.
getCurrentState() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
getCurrentState() - Method in class org.apache.flink.api.java.io.AvroInputFormat
 
getCurrentTableCapacity() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
Gets the current table capacity, i.e., the number of slots in the hash table, without and overflow chaining.
getCurrentUserRetweet() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
getCurrentWatermark() - Method in interface org.apache.flink.streaming.api.functions.AssignerWithPeriodicWatermarks
Returns the current watermark.
getCurrentWatermark() - Method in class org.apache.flink.streaming.api.functions.IngestionTimeExtractor
 
getCurrentWatermark() - Method in interface org.apache.flink.streaming.api.functions.TimestampExtractor
Deprecated.
Returns the current watermark.
getCurrentWatermark() - Method in class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
 
getCurrentWatermark() - Method in class org.apache.flink.streaming.api.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor
 
getCurrentWatermark() - Method in interface org.apache.flink.streaming.api.windowing.evictors.Evictor.EvictorContext
Returns the current watermark time.
getCurrentWatermark() - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
Returns the current watermark time.
getCurrentWatermark() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
getCurrentWatermarkTimestamp() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionStateWithPeriodicWatermarks
 
getCurrentWorksetPlanNode() - Method in class org.apache.flink.optimizer.dag.WorksetNode
 
getCustKey() - Method in class org.apache.flink.examples.java.relational.TPCHQuery3.Customer
 
getCustKey() - Method in class org.apache.flink.examples.java.relational.TPCHQuery3.Order
 
getCustomCommandLineList() - Static method in class org.apache.flink.client.CliFrontend
Retrieves the loaded custom command-lines.
getCustomPartitioner() - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
getCustomPartitioner() - Method in class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
 
getCustomPartitioner() - Method in class org.apache.flink.api.common.operators.base.JoinOperatorBase
 
getCustomPartitioner() - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
getCustomPartitioner() - Method in class org.apache.flink.api.common.operators.base.ReduceOperatorBase
 
getCustomPartitioner() - Method in class org.apache.flink.api.java.operators.Grouping
Gets the custom partitioner to be used for this grouping, or null, if none was defined.
getCustomPartitioner() - Method in class org.apache.flink.api.java.operators.PartitionOperator
Gets the custom partitioner from this partitioning.
getCustomPartitioner() - Method in class org.apache.flink.api.scala.GroupedDataSet
Gets the custom partitioner to be used for this grouping, or null, if none was defined.
getCustomPartitioner() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
 
getCustomPartitioner() - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
Gets the custom partitioner associated with these properties.
getData() - Method in class org.apache.flink.migration.runtime.state.memory.AbstractMemStateSnapshot
Deprecated.
 
getData() - Method in class org.apache.flink.migration.runtime.state.memory.ByteStreamStateHandle
Deprecated.
 
getData() - Method in class org.apache.flink.python.api.types.CustomTypeWrapper
 
getData() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
 
getDataDistribution() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
 
getDataDistribution() - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
Gets the data distribution.
getDataDistribution() - Method in class org.apache.flink.optimizer.plan.Channel
 
getDataExchangeMode() - Method in class org.apache.flink.optimizer.dag.DagConnection
Gets the data exchange mode to use for this connection.
getDataExchangeMode() - Method in class org.apache.flink.optimizer.plan.Channel
Gets the data exchange mode (batch / pipelined) to use for the data exchange of this channel.
getDataPort() - Method in interface org.apache.flink.runtime.io.network.ConnectionManager
 
getDataPort() - Method in class org.apache.flink.runtime.io.network.LocalConnectionManager
 
getDataPort() - Method in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager
 
getDataSet(ExecutionEnvironment) - Method in class org.apache.flink.addons.hbase.HBaseTableSource
 
getDataSet() - Method in class org.apache.flink.api.java.operators.DataSink
 
getDataSet(int) - Method in class org.apache.flink.python.api.util.SetCache
Returns the cached DataSet for the given ID.
getDataSet(ExecutionEnvironment) - Method in interface org.apache.flink.table.sources.BatchTableSource
Returns the data of the table as a DataSet.
getDataSet(ExecutionEnvironment) - Method in class org.apache.flink.table.sources.CsvTableSource
Returns the data of the table as a DataSet of Row.
getDataSinks() - Method in class org.apache.flink.api.common.Plan
Gets all the data sinks of this job.
getDataSinks() - Method in class org.apache.flink.optimizer.plan.OptimizedPlan
Gets the data sinks from this OptimizedPlan.
getDataSinks(List<SinkPlanNode>) - Method in class org.apache.flink.optimizer.plan.SinkJoinerPlanNode
 
getDataSourceNode() - Method in class org.apache.flink.optimizer.plan.SourcePlanNode
 
getDataSources() - Method in class org.apache.flink.optimizer.plan.OptimizedPlan
Gets the data sources from this OptimizedPlan.
getDataStream(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSource
NOTE: This method is for internal use only for defining a TableSource.
getDataStream(StreamExecutionEnvironment) - Method in class org.apache.flink.table.sources.CsvTableSource
Returns the data of the table as a DataStream of Row.
getDataStream(StreamExecutionEnvironment) - Method in interface org.apache.flink.table.sources.StreamTableSource
Returns the data of the table as a DataStream.
getDataType() - Method in interface org.apache.flink.api.common.typeutils.TypeSerializerFactory
 
getDataType() - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
 
getDbOptions() - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
Gets the RocksDB DBOptions to be used for all RocksDB instances.
getDbStoragePaths() - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
 
getDeclaredField(Class<?>, String) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getDecoRuleSet() - Method in class org.apache.flink.table.api.StreamTableEnvironment
Returns the decoration rule set for this environment including a custom RuleSet configuration.
getDecoRuleSet() - Method in interface org.apache.flink.table.calcite.CalciteConfig
Returns a custom decoration rule set.
getDef() - Static method in class org.apache.flink.table.plan.cost.FlinkRelMdRowCount
 
getDefault() - Method in class org.apache.flink.table.plan.nodes.datastream.AccModeTraitDef
 
getDefault() - Method in class org.apache.flink.table.plan.nodes.datastream.UpdateAsRetractionTraitDef
 
getDefaultAcl() - Method in class org.apache.flink.runtime.util.ZooKeeperUtils.SecureAclProvider
 
getDefaultAkkaConfig() - Method in class org.apache.flink.runtime.akka.AkkaUtils$
Creates the default akka configuration which listens on a random port on the local machine.
getDefaultAkkaConfig() - Static method in class org.apache.flink.runtime.akka.AkkaUtils
Creates the default akka configuration which listens on a random port on the local machine.
getDefaultBlockSize() - Method in class org.apache.flink.core.fs.FileSystem
Return the number of bytes that large input files should be optimally be split into to minimize I/O time.
getDefaultBlockSize() - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
getDefaultBlockSize() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
 
getDefaultBlockSize() - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
 
getDefaultCentroidDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.examples.java.clustering.util.KMeansData
 
getDefaultCharset() - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
getDefaultClientTimeout() - Method in class org.apache.flink.runtime.akka.AkkaUtils$
 
getDefaultClientTimeout() - Static method in class org.apache.flink.runtime.akka.AkkaUtils
 
getDefaultConfig() - Method in class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
getDefaultDataDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.examples.java.ml.util.LinearRegressionData
 
getDefaultEdgeDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.examples.java.graph.util.ConnectedComponentsData
 
getDefaultEdgeDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.examples.java.graph.util.EnumTrianglesData
 
getDefaultEdgeDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.examples.java.graph.util.PageRankData
 
getDefaultEdgeDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.CommunityDetectionData
 
getDefaultEdgeDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.ConnectedComponentsDefaultData
 
getDefaultEdgeDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.EuclideanGraphData
 
getDefaultEdgeDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.IncrementalSSSPData
 
getDefaultEdgeDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.LabelPropagationData
 
getDefaultEdgeDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.PageRankData
 
getDefaultEdgeDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.SingleSourceShortestPathsData
 
getDefaultEdgeDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.TriangleCountData
 
getDefaultEdgesInSSSP(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.IncrementalSSSPData
 
getDefaultEdgeToBeRemoved() - Static method in class org.apache.flink.graph.examples.data.IncrementalSSSPData
 
getDefaultElement() - Method in class org.apache.flink.runtime.util.EvictingBoundedList
 
getDefaultIOMode() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
getDefaultKryoSerializerClasses() - Method in class org.apache.flink.api.common.ExecutionConfig
Returns the registered default Kryo Serializer classes.
getDefaultKryoSerializers() - Method in class org.apache.flink.api.common.ExecutionConfig
Returns the registered default Kryo Serializers.
getDefaultLocalParallelism() - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Gets the default parallelism that will be used for the local execution environment created by ExecutionEnvironment.createLocalEnvironment().
getDefaultLocalParallelism() - Method in class org.apache.flink.api.scala.ExecutionEnvironment$
Gets the default parallelism that will be used for the local execution environment created by createLocalEnvironment().
getDefaultLocalParallelism() - Static method in class org.apache.flink.api.scala.ExecutionEnvironment
Gets the default parallelism that will be used for the local execution environment created by createLocalEnvironment().
getDefaultLocalParallelism() - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Gets the default parallelism that will be used for the local execution environment created by StreamExecutionEnvironment.createLocalEnvironment().
getDefaultLocalParallelism() - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment$
Gets the default parallelism that will be used for the local execution environment created by createLocalEnvironment().
getDefaultLocalParallelism() - Static method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Gets the default parallelism that will be used for the local execution environment created by createLocalEnvironment().
getDefaultLookupTimeout() - Method in class org.apache.flink.runtime.akka.AkkaUtils$
 
getDefaultLookupTimeout() - Static method in class org.apache.flink.runtime.akka.AkkaUtils
 
getDefaultMimeType() - Static method in class org.apache.flink.runtime.webmonitor.files.MimeTypes
Gets the default MIME type, which is "application/octet-stream".
getDefaultPagesDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.examples.java.graph.util.PageRankData
 
getDefaultParallelism() - Method in class org.apache.flink.api.common.Plan
Gets the default parallelism for this job.
getDefaultParallelism() - Method in class org.apache.flink.client.RemoteExecutor
Gets the parallelism that will be used when neither the program does not define any parallelism at all.
getDefaultParallelism() - Method in class org.apache.flink.optimizer.Optimizer
 
getDefaultParamsDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.examples.java.ml.util.LinearRegressionData
 
getDefaultPointDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.examples.java.clustering.util.KMeansData
 
getDefaultPrecision(SqlTypeName) - Method in class org.apache.flink.table.calcite.FlinkTypeSystem
 
getDefaultStateBackend() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
getDefaultTextLineDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.examples.java.wordcount.util.WordCountData
 
getDefaultTimeout() - Method in class org.apache.flink.runtime.akka.AkkaUtils$
 
getDefaultTimeout() - Static method in class org.apache.flink.runtime.akka.AkkaUtils
 
getDefaultTimeoutAsFiniteDuration() - Method in class org.apache.flink.runtime.akka.AkkaUtils$
 
getDefaultTimeoutAsFiniteDuration() - Static method in class org.apache.flink.runtime.akka.AkkaUtils
 
getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.BaseAlignedWindowAssigner
 
getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
 
getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
 
getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
 
getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
 
getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
 
getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
 
getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
 
getDefaultTrigger(StreamExecutionEnvironment) - Method in class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
Returns the default trigger associated with this WindowAssigner.
getDefaultValue() - Method in class org.apache.flink.api.common.state.StateDescriptor
Returns the default value.
getDefaultValue() - Method in class org.apache.flink.api.java.utils.Option
 
getDefaultVertexDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.examples.java.graph.util.ConnectedComponentsData
 
getDefaultVertexDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.EuclideanGraphData
 
getDefaultVertexDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.IncrementalSSSPData
 
getDefaultVertexSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.LabelPropagationData
 
getDegree() - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees.Degrees
 
getDegree() - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient.Result
Get the vertex degree.
getDegree() - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient.Result
Get the vertex degree.
getDegrees() - Method in class org.apache.flink.graph.Graph
Return the degree of all vertices in the graph
getDegrees() - Method in class org.apache.flink.graph.scala.Graph
Return the degree of all vertices in the graph
getDelayBetweenAttemptsInterval() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FailureRateRestartStrategyConfiguration
 
getDelayBetweenAttemptsInterval() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FixedDelayRestartStrategyConfiguration
 
getDelayMillis() - Method in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase.BulkFlushBackoffPolicy
 
getDelegateStateHandle() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
 
getDelegateStateHandle() - Method in class org.apache.flink.runtime.state.OperatorStateHandle
 
getDelimiter() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
getDelimiter() - Method in class org.apache.flink.runtime.metrics.MetricRegistry
Returns the global delimiter.
getDelimiter(int) - Method in class org.apache.flink.runtime.metrics.MetricRegistry
Returns the configured delimiter for the reporter with the given index.
getDelimiter() - Method in class org.apache.flink.runtime.metrics.MetricRegistryConfiguration
 
getDelta(DATA, DATA) - Method in interface org.apache.flink.streaming.api.functions.windowing.delta.DeltaFunction
Calculates the delta between two given data points.
getDelta(DATA, DATA) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.ExtractionAwareDeltaFunction
This method takes the two data point and runs the set extractor on it.
getDensity() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
Get the density, the ratio of actual to potential edges between vertices.
getDensity() - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics.Result
Get the density, the ratio of actual to potential edges between vertices.
getDescription() - Method in interface org.apache.flink.api.common.ProgramDescription
Returns a description of the plan that is generated by the assembler and also of the arguments if they are available.
getDescription() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FailureRateRestartStrategyConfiguration
 
getDescription() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FallbackRestartStrategyConfiguration
 
getDescription() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FixedDelayRestartStrategyConfiguration
 
getDescription() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.NoRestartStrategyConfiguration
 
getDescription() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.RestartStrategyConfiguration
Returns a description which is shown in the web interface
getDescription() - Method in class org.apache.flink.client.program.PackagedProgram
Returns the description provided by the Program class.
getDescription() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getDescription() - Method in class org.apache.flink.graph.examples.EuclideanGraphWeighing
 
getDescription() - Method in class org.apache.flink.graph.examples.GSASingleSourceShortestPaths
 
getDescription() - Method in class org.apache.flink.graph.examples.IncrementalSSSP
 
getDescription() - Method in class org.apache.flink.graph.examples.MusicProfiles
 
getDescription() - Method in class org.apache.flink.graph.examples.PregelSSSP
 
getDescription() - Method in class org.apache.flink.graph.examples.SingleSourceShortestPaths
 
getDescription() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
getDescription() - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
getDescription() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
getDescription() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
getDescription() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
getDescription() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
getDescription() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
getDescription() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
getDescription() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
getDescription() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
getDescription() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
getDescription() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
getDescription() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
getDescription() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
getDescription() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
getDescription() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getDescriptionPrefix() - Method in class org.apache.flink.api.common.operators.util.FieldList
 
getDescriptionPrefix() - Method in class org.apache.flink.api.common.operators.util.FieldSet
 
getDescriptionSuffix() - Method in class org.apache.flink.api.common.operators.util.FieldList
 
getDescriptionSuffix() - Method in class org.apache.flink.api.common.operators.util.FieldSet
 
getDeserializationSchema() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSource
Returns the deserialization schema.
getDesignatedWorkerPoolSize() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Gets the current designated worker pool size, meaning the number of workers that the resource master strives to maintain.
getDetachedMode() - Method in class org.apache.flink.client.cli.ProgramOptions
 
getDiffUrl() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
 
getDigest() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
getDigest() - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
getDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
getDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
getDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
getDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
getDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
getDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
getDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
getDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
getDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
getDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
getDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
getDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
getDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
getDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getDirection() - Method in class org.apache.flink.graph.gsa.GSAConfiguration
Gets the direction from which the neighbors are to be selected By default the neighbors who are target of the edges are selected
getDirection() - Method in class org.apache.flink.graph.spargel.ScatterFunction
Retrieves the edge direction in which messages are propagated in the scatter-gather iteration.
getDirection() - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
Gets the direction in which messages are sent in the ScatterFunction.
getDirections(Ordering, int) - Static method in class org.apache.flink.optimizer.util.Utils
 
getDirectMemory() - Method in class org.apache.flink.api.common.operators.ResourceSpec
 
getDirectMemoryInMB() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
Get the direct memory needed in MB
getDirectMemoryStatsAsString(BufferPoolMXBean) - Static method in class org.apache.flink.runtime.taskmanager.MemoryLogger
Returns a String with the direct memory footprint.
getDirectoryFileName(int) - Method in class org.apache.flink.api.common.io.FileOutputFormat
 
getDirectoryFileName(int) - Method in class org.apache.flink.api.java.io.AvroOutputFormat
 
getDiscount() - Method in class org.apache.flink.examples.java.relational.TPCHQuery3.Lineitem
 
getDiskCost() - Method in class org.apache.flink.optimizer.costs.Costs
Gets the costs for disk.
getDisplay_url() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Media
 
getDisplay_url() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.URL
 
getDisposeSavepointSuccess() - Method in class org.apache.flink.runtime.messages.JobManagerMessages$
 
getDisposeSavepointSuccess() - Static method in class org.apache.flink.runtime.messages.JobManagerMessages
 
getDistinctNeighborCount() - Method in class org.apache.flink.graph.library.similarity.JaccardIndex.Result
Get the distinct neighbor count.
getDistributedCache() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Returns the DistributedCache to get the local temporary file copies of files otherwise not locally accessible.
getDistributedCache() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getDistributedCacheEntries() - Method in interface org.apache.flink.runtime.execution.Environment
 
getDistributedCacheEntries() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getDistribution() - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
getDistribution() - Method in class org.apache.flink.table.plan.stats.FlinkStatistic
 
getDistributionMode() - Method in class org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo
 
getDistributionPattern() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
Returns the distribution pattern used for this edge.
getDocumentDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.examples.java.relational.util.WebLogData
 
getDouble(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the Double value for the given key.
getDouble(String, double) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the Double value for the given key.
getDouble(String, double) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given key as a double.
getDouble(ConfigOption<Double>) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as a double.
getDouble(String, double) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getDouble(ConfigOption<Double>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getDouble(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads a double-precision floating point value (64bit, 8 bytes) from the given position, in the system's native byte order.
getDouble(String, double) - Method in class org.apache.flink.metrics.MetricConfig
Searches for the property with the specified key in this property list.
getDouble(int) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getDoubleBigEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads a double-precision floating point value (64bit, 8 bytes) from the given position, in big endian byte order.
getDoubleByField(String) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getDoubleCounter(String) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Convenience function to create a counter object for doubles.
getDoubleCounter(String) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getDoubleLittleEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads a double-precision floating point value (64bit, 8 bytes) from the given position, in little endian byte order.
getDriver() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getDriver_strategy() - Method in class org.apache.flink.table.explain.Node
 
getDriverClass() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
 
getDriverComparator(int) - Method in class org.apache.flink.runtime.operators.BatchTask
 
getDriverComparator(int) - Method in interface org.apache.flink.runtime.operators.TaskContext
 
getDriverComparator(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getDriverStrategy() - Method in class org.apache.flink.optimizer.plan.PlanNode
Gets the driver strategy from this node.
getDriverStrategy() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getDropwizardHistogram() - Method in class org.apache.flink.dropwizard.metrics.DropwizardHistogramWrapper
 
getDropwizardMeter() - Method in class org.apache.flink.dropwizard.metrics.DropwizardMeterWrapper
 
getDualInputNodeSchema(DualInputPlanNode, T, T) - Method in class org.apache.flink.optimizer.postpass.GenericFlatTypePostPass
 
getDumpableInputs() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
getDumpableInputs() - Method in class org.apache.flink.optimizer.plan.PlanNode
 
getDumpableInputs() - Method in interface org.apache.flink.optimizer.plandump.DumpableNode
 
getDuration() - Method in class org.apache.flink.migration.runtime.checkpoint.KeyGroupState
Deprecated.
 
getDuration() - Method in class org.apache.flink.migration.runtime.checkpoint.SubtaskState
Deprecated.
 
getDuration() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
getDynamicConfiguration() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification
Get the dynamic configuration.
getDynamicParamCount() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Returns the number of dynamic parameters encountered during translation; this must only be called after SqlToRelConverter.convertQuery(org.apache.calcite.sql.SqlNode, boolean, boolean).
getDynamicParamCountInExplain(boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Returns the current count of the number of dynamic parameters in an EXPLAIN PLAN statement.
getDynamicParamType(int) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Returns the type inferred for a dynamic parameter.
getDynamicProperties() - Static method in class org.apache.flink.configuration.GlobalConfiguration
Get the dynamic properties.
getDynamicProperties(String) - Static method in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
 
getDynamicPropertiesEncoded() - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
 
getEdge() - Method in class org.apache.flink.graph.Triplet
 
getEdgeGroupCount() - Method in class org.apache.flink.graph.library.Summarization.EdgeValue
 
getEdgeGroupValue() - Method in class org.apache.flink.graph.library.Summarization.EdgeValue
 
getEdgeIds() - Method in class org.apache.flink.graph.Graph
 
getEdgeIds() - Method in class org.apache.flink.graph.scala.Graph
 
getEdges() - Method in class org.apache.flink.graph.bipartite.BipartiteGraph
Get dataset with graph edges.
getEdges(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.SummarizationData
Creates a set of edges with attached String values.
getEdges() - Method in class org.apache.flink.graph.Graph
 
getEdges() - Method in class org.apache.flink.graph.pregel.ComputeFunction
Gets an Iterable with all out-going edges.
getEdges() - Method in class org.apache.flink.graph.scala.Graph
 
getEdges() - Method in class org.apache.flink.graph.spargel.ScatterFunction
Gets an Iterable with all edges.
getEdgesAsTuple3() - Method in class org.apache.flink.graph.Graph
 
getEdgesAsTuple3() - Method in class org.apache.flink.graph.scala.Graph
 
getEdgeValue() - Method in class org.apache.flink.graph.gsa.Neighbor
 
getElement() - Method in class org.apache.flink.api.java.sampling.IntermediateSampleData
 
getElementBlocking() - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
Returns the next element in the queue.
getElementBlocking(long) - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
Returns the next element in the queue.
getElementCount() - Method in class org.apache.flink.graph.generator.random.BlockInfo
 
getElementsCollectedAndReset() - Method in class org.apache.flink.runtime.iterative.io.WorksetUpdateOutputCollector
 
getElementSerializer() - Method in class org.apache.flink.api.common.state.ListStateDescriptor
Gets the serializer for the elements contained in the list.
getElementSerializer() - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
Gets the serializer for the elements of the list.
getElementSerializer() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
getElementType(RelDataTypeFactory, List<SqlNode>) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
getElementType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
getElementType(List<Object>) - Method in class org.apache.flink.table.plan.schema.FlinkTableFunctionImpl
 
getElementTypeInfo() - Method in class org.apache.flink.api.java.typeutils.ListTypeInfo
Gets the type information for the elements contained in the list
getElemTypeInfo() - Method in class org.apache.flink.api.scala.typeutils.OptionTypeInfo
 
getEmptyCount() - Method in class org.apache.flink.api.java.summarize.StringColumnSummary
Number of empty strings e.g.
getEnd() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
Gets the end timestamp of this window.
getEndKeyGroup() - Method in class org.apache.flink.runtime.state.KeyGroupRange
 
getEndOffsetExclusive() - Method in class org.apache.flink.runtime.state.BoundedInputStream
 
getEndpointId() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
Returns the rpc endpoint's identifier.
getEndRow() - Method in class org.apache.flink.addons.hbase.TableInputSplit
Returns the end row.
getEndTime() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
 
getEndTime() - Method in class org.apache.flink.runtime.webmonitor.StackTraceSample
Returns the time stamp, when all stack traces were collected at the JobManager.
getEndTimestamp() - Method in class org.apache.flink.runtime.webmonitor.OperatorBackPressureStats
Returns the time stamp, when all stack traces were collected at the JobManager.
getEndToEndDuration() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
Returns the duration of this checkpoint calculated as the time since triggering until the latest acknowledged subtask or -1 if no subtask was acknowledged yet.
getEndToEndDuration() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
Returns the end to end duration until the checkpoint failure.
getEndToEndDuration(long) - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
Computes the duration since the given trigger timestamp.
getEndToEndDuration(long) - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
Returns the duration of this checkpoint at the task/operator calculated as the time since triggering until the latest acknowledged subtask or -1 if no subtask was acknowledged yet.
getEndToEndDurationStats() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStatsSummary
Returns the summary stats for the duration of completed checkpoints.
getEntities() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
getEntities() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getEntryIterator() - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
 
getEntryIterator() - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
 
getEntryIterator() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
Returns an iterator that can be used to iterate over all the elements in the table.
getEntryPointClassName() - Method in class org.apache.flink.client.cli.ProgramOptions
 
getEnum(GeneratedExpression) - Method in class org.apache.flink.table.codegen.CodeGenUtils$
 
getEnum(GeneratedExpression) - Static method in class org.apache.flink.table.codegen.CodeGenUtils
 
getEnumClass() - Method in class org.apache.flink.api.scala.typeutils.EnumValueSerializer.ScalaEnumSerializerConfigSnapshot
 
getEnumConstants() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot
 
getEnumConstants() - Method in class org.apache.flink.api.scala.typeutils.EnumValueSerializer.ScalaEnumSerializerConfigSnapshot
 
getEnumeratingVertices(int) - Static method in class org.apache.flink.test.testdata.ConnectedComponentsData
 
getEnvironment() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
Returns the environment of this task.
getEnvironment() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getEnvironmentVariables() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification
Get the environment variables.
getEnvironmentVariables(String, Configuration) - Static method in class org.apache.flink.yarn.Utils
Method to extract environment variables from the flinkConfiguration based on the given prefix String.
getError(ClassLoader) - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
Gets the attached exception, which is in serialized form.
getErrorState() - Method in class org.apache.flink.types.parser.FieldParser
Gets the error state of the parser, as a value of the enumeration FieldParser.ParseErrorState.
getEstimatedAvgWidthPerOutputRecord() - Method in class org.apache.flink.optimizer.dag.DagConnection
 
getEstimatedAvgWidthPerOutputRecord() - Method in interface org.apache.flink.optimizer.dag.EstimateProvider
Gets the estimated number of bytes per record.
getEstimatedAvgWidthPerOutputRecord() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
getEstimatedAvgWidthPerOutputRecord() - Method in class org.apache.flink.optimizer.plan.Channel
 
getEstimatedNumRecords() - Method in class org.apache.flink.optimizer.dag.DagConnection
 
getEstimatedNumRecords() - Method in interface org.apache.flink.optimizer.dag.EstimateProvider
Gets the estimated number of records in the output of this node.
getEstimatedNumRecords() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
getEstimatedNumRecords() - Method in class org.apache.flink.optimizer.plan.Channel
 
getEstimatedOutputSize() - Method in class org.apache.flink.optimizer.dag.DagConnection
 
getEstimatedOutputSize() - Method in interface org.apache.flink.optimizer.dag.EstimateProvider
Gets the estimated output size from this node.
getEstimatedOutputSize() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
getEstimatedOutputSize() - Method in class org.apache.flink.optimizer.plan.Channel
 
getEstimates() - Method in class org.apache.flink.table.explain.Node
 
getEvalMethodSignature(UserDefinedFunction, Seq<TypeInformation<?>>) - Method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils$
Returns signatures of eval methods matching the given signature of TypeInformation.
getEvalMethodSignature(UserDefinedFunction, Seq<TypeInformation<?>>) - Static method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils
Returns signatures of eval methods matching the given signature of TypeInformation.
getEvent() - Method in class org.apache.flink.cep.nfa.ComputationState
 
getEvent() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
getEventsForPattern(String) - Method in class org.apache.flink.cep.nfa.ComputationState.ConditionContext
 
getEventsForPattern(String) - Method in interface org.apache.flink.cep.pattern.conditions.IterativeCondition.Context
 
getEventsForPattern(String) - Method in interface org.apache.flink.cep.scala.conditions.Context
 
getEventTimeTimersPerKeyGroup() - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
 
getEvictor() - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
 
getExecutedVertex() - Method in class org.apache.flink.runtime.instance.SimpleSlot
Gets the task execution attempt currently executed in this slot.
getExecutingThread() - Method in class org.apache.flink.runtime.taskmanager.Task
 
getExecutionAttemptID() - Method in class org.apache.flink.runtime.accumulators.AccumulatorSnapshot
 
getExecutionAttemptId() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
 
getExecutionAttemptID() - Method in class org.apache.flink.runtime.messages.StackTraceSampleResponse
 
getExecutionConfig() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Returns the ExecutionConfig for the currently executing job.
getExecutionConfig() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getExecutionConfig() - Method in class org.apache.flink.api.common.Plan
Gets the execution config object.
getExecutionConfig() - Method in interface org.apache.flink.runtime.execution.Environment
Returns the job specific ExecutionConfig.
getExecutionConfig() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
Returns the global ExecutionConfig.
getExecutionConfig() - Method in interface org.apache.flink.runtime.operators.TaskContext
 
getExecutionConfig() - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
 
getExecutionConfig() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getExecutionConfig() - Method in class org.apache.flink.streaming.api.datastream.DataStream
 
getExecutionConfig() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getExecutionConfig() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
Gets the execution config defined on the execution environment of the job to which this operator belongs.
getExecutionConfig() - Method in class org.apache.flink.streaming.api.scala.DataStream
Deprecated.
Use executionConfig instead.
getExecutionContext() - Method in class org.apache.flink.runtime.query.QueryableStateClient
Returns the execution context of this client.
getExecutionEnvironment() - Method in class org.apache.flink.api.java.DataSet
Returns the ExecutionEnvironment in which this DataSet is registered.
getExecutionEnvironment() - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Creates an execution environment that represents the context in which the program is currently executed.
getExecutionEnvironment() - Static method in class org.apache.flink.api.scala.CrossDataSet
 
getExecutionEnvironment() - Method in class org.apache.flink.api.scala.DataSet
Returns the execution environment associated with the current DataSet.
getExecutionEnvironment() - Method in class org.apache.flink.api.scala.ExecutionEnvironment$
Creates an execution environment that represents the context in which the program is currently executed.
getExecutionEnvironment() - Static method in class org.apache.flink.api.scala.ExecutionEnvironment
Creates an execution environment that represents the context in which the program is currently executed.
getExecutionEnvironment() - Method in class org.apache.flink.storm.api.FlinkTopology
Returns the underlying Flink StreamExecutionEnvironment for the Storm topology.
getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
 
getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
 
getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.DataStream
Returns the StreamExecutionEnvironment that was used to create this DataStream.
getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
 
getExecutionEnvironment() - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates an execution environment that represents the context in which the program is currently executed.
getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.scala.DataStream
Deprecated.
Use executionEnvironment instead
getExecutionEnvironment() - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment$
Creates an execution environment that represents the context in which the program is currently executed.
getExecutionEnvironment() - Static method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Creates an execution environment that represents the context in which the program is currently executed.
getExecutionGraph() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getExecutionGraph(JobID, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.ExecutionGraphHolder
Retrieves the execution graph with JobID jid or null if it cannot be found.
getExecutionId() - Method in interface org.apache.flink.runtime.execution.Environment
Gets the ID of the task execution attempt.
getExecutionId() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getExecutionId() - Method in class org.apache.flink.runtime.taskmanager.Task
 
getExecutionMode() - Method in class org.apache.flink.api.common.ArchivedExecutionConfig
 
getExecutionMode() - Method in class org.apache.flink.api.common.ExecutionConfig
Gets the execution mode used to execute the program.
getExecutionPlan() - Method in class org.apache.flink.api.java.CollectionEnvironment
 
getExecutionPlan() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates the plan with which the system will execute the program, and returns it as a String using a JSON representation of the execution data flow graph.
getExecutionPlan() - Method in class org.apache.flink.api.java.LocalEnvironment
 
getExecutionPlan() - Method in class org.apache.flink.api.java.RemoteEnvironment
 
getExecutionPlan() - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Creates the plan with which the system will execute the program, and returns it as a String using a JSON representation of the execution data flow graph.
getExecutionPlan() - Method in class org.apache.flink.client.program.ContextEnvironment
 
getExecutionPlan() - Method in class org.apache.flink.client.program.OptimizerPlanEnvironment
 
getExecutionPlan() - Method in class org.apache.flink.client.program.PreviewPlanEnvironment
 
getExecutionPlan() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates the plan with which the system will execute the program, and returns it as a String using a JSON representation of the execution data flow graph.
getExecutionPlan() - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Creates the plan with which the system will execute the program, and returns it as a String using a JSON representation of the execution data flow graph.
getExecutionPlan() - Method in class org.apache.flink.test.util.TestEnvironment
 
getExecutionRetryDelay() - Method in class org.apache.flink.api.common.ExecutionConfig
Deprecated.
Should no longer be used because it is subsumed by RestartStrategyConfiguration
getExecutionState() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
Returns the current ExecutionState for this execution vertex.
getExecutionState() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
 
getExecutionState() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getExecutionState() - Method in class org.apache.flink.runtime.taskmanager.Task
Returns the current execution state of the task.
getExecutionState() - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
Returns the new execution state of the task.
getExecutor() - Method in class org.apache.flink.api.java.RemoteEnvironment
 
getExecutor() - Method in class org.apache.flink.api.java.ScalaShellRemoteEnvironment
 
getExecutor() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
getExecutor() - Method in interface org.apache.flink.runtime.rpc.RpcService
Gets the executor, provided by this RPC service.
getExpanded_url() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Media
 
getExpanded_url() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.URL
 
getExpected() - Method in exception org.apache.flink.runtime.highavailability.LeaderIdMismatchException
 
getExpectedInputRowType(int) - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
getExpectedInputRowType(int) - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
getExpectedInputRowType(int) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
getExpectedInputRowType(int) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
getExpectedInputRowType(int) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
getExpectedInputRowType(int) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
getExpectedInputRowType(int) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
getExpectedInputRowType(int) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
getExpectedInputRowType(int) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
getExpectedInputRowType(int) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
getExpectedInputRowType(int) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
getExpectedInputRowType(int) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
getExpectedInputRowType(int) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
getExpectedInputRowType(int) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
getExpectedInputRowType(int) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
getExpectedInputRowType(int) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getExpectedLeaderSessionID() - Method in exception org.apache.flink.runtime.rpc.exceptions.LeaderSessionIDException
Get expected leader session id
getExpression(SchemaPlus, String) - Method in class org.apache.flink.table.catalog.ExternalCatalogSchema
 
getExpressionString(RexNode, List<String>, Option<List<RexNode>>) - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
getExpressionString(RexNode, List<String>, Option<List<RexNode>>) - Method in interface org.apache.flink.table.plan.nodes.FlinkRelNode
 
getExpressionString(RexNode, List<String>, Option<List<RexNode>>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
getExpressionString(RexNode, List<String>, Option<List<RexNode>>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
getExpressionString(RexNode, List<String>, Option<List<RexNode>>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
getExpressionString(RexNode, List<String>, Option<List<RexNode>>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
getExpressionString(RexNode, List<String>, Option<List<RexNode>>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
getExpressionString(RexNode, List<String>, Option<List<RexNode>>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
getExpressionString(RexNode, List<String>, Option<List<RexNode>>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
getExpressionString(RexNode, List<String>, Option<List<RexNode>>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
getExpressionString(RexNode, List<String>, Option<List<RexNode>>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
getExpressionString(RexNode, List<String>, Option<List<RexNode>>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
getExpressionString(RexNode, List<String>, Option<List<RexNode>>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
getExpressionString(RexNode, List<String>, Option<List<RexNode>>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
getExpressionString(RexNode, List<String>, Option<List<RexNode>>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
getExpressionString(RexNode, List<String>, Option<List<RexNode>>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getExtendedprice() - Method in class org.apache.flink.examples.java.relational.TPCHQuery3.Lineitem
 
getExternalizedCheckpointCleanup() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
Returns the cleanup behaviour for externalized checkpoints.
getExternalizedCheckpointSettings() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
getExternalizedMetadata() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
getExternalJars() - Method in class org.apache.flink.api.scala.FlinkILoop
 
getExternalPath() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
Returns the external path if this checkpoint was persisted externally.
getExternalPath() - Method in class org.apache.flink.runtime.checkpoint.RestoredCheckpointStats
Returns the external path if this checkpoint was persisted externally.
getExternalPointer() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
getFactor(TimeUnit) - Method in class org.apache.flink.table.expressions.ExpressionUtils$
Copy of org.apache.calcite.sql2rel.StandardConvertletTable#getFactor().
getFactor(TimeUnit) - Static method in class org.apache.flink.table.expressions.ExpressionUtils
Copy of org.apache.calcite.sql2rel.StandardConvertletTable#getFactor().
getFactory() - Method in enum org.apache.flink.api.java.aggregation.Aggregations
 
getFactory() - Static method in class org.apache.flink.core.memory.MemorySegmentFactory
Gets the factory.
getFailoverRegion(ExecutionVertex) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy
Finds the failover region that contains the given execution vertex.
getFailoverStrategy() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Gets the failover strategy used by the execution graph to recover from failures of tasks.
getFailureCause() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
getFailureCause() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getFailureCause() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getFailureCause() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
 
getFailureCause() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
getFailureCause() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
 
getFailureCause() - Method in class org.apache.flink.runtime.taskmanager.Task
If the task has failed, this method gets the exception that caused this task to fail.
getFailureCauseAsString() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
Returns the exception that caused the job to fail.
getFailureCauseAsString() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns the exception that caused the job to fail.
getFailureCauseAsString() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
Returns the exception that caused the job to fail.
getFailureCauseAsString() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
 
getFailureCauseAsString() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getFailureCauseAsString() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
 
getFailureCauseAsString() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
getFailureCauseAsString() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getFailureCauseAsString() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getFailureInterval() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FailureRateRestartStrategyConfiguration
 
getFailureMessage() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
Returns the failure message or null if no cause was provided.
getFailureTimestamp() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
Returns the timestamp when this checkpoint failed.
getFalseCount() - Method in class org.apache.flink.api.java.summarize.BooleanColumnSummary
 
getFamily() - Static method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
getFavorite_count() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
getFavourites_count() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getFeedbackEdges() - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
Returns the list of feedback StreamTransformations.
getFeedbackEdges() - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
Returns the list of feedback StreamTransformations.
getFetcherName() - Method in class org.apache.flink.streaming.connectors.kafka.internal.Kafka010Fetcher
 
getFetcherName() - Method in class org.apache.flink.streaming.connectors.kafka.internal.Kafka09Fetcher
Gets the name of this fetcher, for thread naming and logging purposes.
getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple
Gets the field at the specified position.
getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple0
 
getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple1
 
getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple10
 
getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple11
 
getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple12
 
getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple13
 
getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple14
 
getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple15
 
getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple16
 
getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple17
 
getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple18
 
getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple19
 
getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple2
 
getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple20
 
getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple21
 
getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple22
 
getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple23
 
getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple24
 
getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple25
 
getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple3
 
getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple4
 
getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple5
 
getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple6
 
getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple7
 
getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple8
 
getField(int) - Method in class org.apache.flink.api.java.tuple.Tuple9
 
getField() - Method in class org.apache.flink.api.java.typeutils.PojoField
 
getField(String, boolean, boolean) - Static method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
getField(int, Class<T>) - Method in class org.apache.flink.types.Record
Gets the field at the given position from the record.
getField(int, T) - Method in class org.apache.flink.types.Record
Gets the field at the given position.
getField(int) - Method in class org.apache.flink.types.Row
Gets the field at the specified position.
getFieldAccessor(Class<?>, String) - Method in class org.apache.flink.table.codegen.CodeGenUtils$
 
getFieldAccessor(Class<?>, String) - Static method in class org.apache.flink.table.codegen.CodeGenUtils
 
getFieldCount() - Static method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
getFieldDelimiter() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
getFieldIndex(String) - Method in class org.apache.flink.api.common.typeutils.CompositeType
Returns the field index of the composite field of the given name.
getFieldIndex(String) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
getFieldIndex(String) - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
 
getFieldIndex(String) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
getFieldIndex(String) - Method in class org.apache.flink.api.scala.typeutils.CaseClassTypeInfo
 
getFieldIndex(String) - Method in class org.apache.flink.table.runtime.types.CRowTypeInfo
 
getFieldIndices(String[]) - Method in class org.apache.flink.api.scala.typeutils.CaseClassTypeInfo
 
getFieldIndices(TypeInformation<?>) - Method in class org.apache.flink.table.api.TableEnvironment$
Returns field indexes for a given TypeInformation.
getFieldIndices(TableSource<A>) - Method in class org.apache.flink.table.api.TableEnvironment$
Returns field indices for a given TableSource.
getFieldIndices(TypeInformation<?>) - Static method in class org.apache.flink.table.api.TableEnvironment
Returns field indexes for a given TypeInformation.
getFieldIndices(TableSource<A>) - Static method in class org.apache.flink.table.api.TableEnvironment
Returns field indices for a given TableSource.
getFieldIndices() - Method in interface org.apache.flink.table.sources.DefinedFieldNames
Returns the indices of the table fields.
getFieldInfo(TypeInformation<A>) - Method in class org.apache.flink.table.api.TableEnvironment
Returns field names and field positions for a given TypeInformation.
getFieldInfo(TypeInformation<A>, Expression[]) - Method in class org.apache.flink.table.api.TableEnvironment
Returns field names and field positions for a given TypeInformation and Array of Expression.
getFieldInfo(TypeInformation<?>) - Method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils$
Returns field names and field positions for a given TypeInformation.
getFieldInfo(TypeInformation<?>) - Static method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils
Returns field names and field positions for a given TypeInformation.
getFieldInto(int, Value) - Method in class org.apache.flink.types.Record
Gets the field at the given position.
getFieldList() - Static method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
getFieldName() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo.NamedFlatFieldDescriptor
 
getFieldNames() - Method in class org.apache.flink.api.common.typeutils.CompositeType
Returns the names of the composite fields of this type.
getFieldNames() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
getFieldNames() - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
 
getFieldNames() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
getFieldNames() - Method in class org.apache.flink.api.scala.typeutils.CaseClassTypeInfo
 
getFieldNames() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSink
 
getFieldNames(TypeInformation<A>) - Method in class org.apache.flink.table.api.TableEnvironment$
Returns field names for a given TypeInformation.
getFieldNames(TableSource<A>) - Method in class org.apache.flink.table.api.TableEnvironment$
Returns field names for a given TableSource.
getFieldNames(TypeInformation<A>) - Static method in class org.apache.flink.table.api.TableEnvironment
Returns field names for a given TypeInformation.
getFieldNames(TableSource<A>) - Static method in class org.apache.flink.table.api.TableEnvironment
Returns field names for a given TableSource.
getFieldNames() - Static method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
getFieldNames() - Method in class org.apache.flink.table.runtime.types.CRowTypeInfo
 
getFieldNames() - Static method in class org.apache.flink.table.sinks.CsvTableSink
 
getFieldNames() - Method in interface org.apache.flink.table.sinks.TableSink
Returns the names of the table fields.
getFieldNames() - Method in interface org.apache.flink.table.sinks.TableSinkBase
 
getFieldNames() - Method in interface org.apache.flink.table.sources.DefinedFieldNames
Returns the names of the table fields.
getFieldNotNull(int) - Method in class org.apache.flink.api.java.tuple.Tuple
Gets the field at the specified position, throws NullFieldException if the field is null.
getFieldNumber(int) - Method in class org.apache.flink.api.common.operators.Ordering
 
getFieldNumber() - Method in exception org.apache.flink.optimizer.postpass.ConflictingFieldTypeInfoException
 
getFieldNumber() - Method in exception org.apache.flink.optimizer.postpass.MissingFieldTypeInfoException
 
getFieldNumber() - Method in exception org.apache.flink.types.KeyFieldOutOfBoundsException
Gets the field number that was attempted to access.
getFieldNumber() - Method in exception org.apache.flink.types.NullKeyFieldException
Gets the field number that was attempted to access.
getFieldOrders() - Method in class org.apache.flink.api.common.operators.Ordering
 
getFieldParsers() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
getFieldPos() - Method in exception org.apache.flink.types.NullFieldException
Gets the field number that was attempted to access.
getFieldPositions() - Method in class org.apache.flink.api.common.operators.Ordering
 
getFields() - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCrossFunction
 
getFields() - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectFlatJoinFunction
 
getFields(String...) - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
Specifies the fields which are returned by the InputFormat and their order.
getFields() - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getFields() - Method in class org.apache.flink.table.plan.util.InputRefVisitor
 
getFieldSerializers() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
getFieldsInto(int[], Value[]) - Method in class org.apache.flink.types.Record
Gets the fields at the given positions into an array.
getFieldsIntoCheckingNull(int[], Value[]) - Method in class org.apache.flink.types.Record
Gets the fields at the given positions into an array.
getFieldSortDirections() - Method in class org.apache.flink.api.common.operators.Ordering
 
getFieldToSerializerConfigSnapshot() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
 
getFieldType() - Method in class org.apache.flink.streaming.util.typeutils.FieldAccessor
Gets the TypeInformation for the type of the field.
getFieldTypes() - Method in class org.apache.flink.api.java.io.CsvInputFormat
 
getFieldTypes() - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
Returns the field types of the row.
getFieldTypes() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSink
 
getFieldTypes(TypeInformation<?>) - Method in class org.apache.flink.table.api.TableEnvironment$
Returns field types for a given TypeInformation.
getFieldTypes(TypeInformation<?>) - Static method in class org.apache.flink.table.api.TableEnvironment
Returns field types for a given TypeInformation.
getFieldTypes() - Static method in class org.apache.flink.table.sinks.CsvTableSink
 
getFieldTypes() - Method in interface org.apache.flink.table.sinks.TableSink
Returns the types of the table fields.
getFieldTypes() - Method in interface org.apache.flink.table.sinks.TableSinkBase
Return the field types of the Table to emit.
getFifteenMinuteRate() - Method in class org.apache.flink.dropwizard.metrics.FlinkMeterWrapper
 
getFile(String) - Method in class org.apache.flink.api.common.cache.DistributedCache
 
getFile() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
 
getFile(BlobKey) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
 
getFile(BlobKey) - Method in class org.apache.flink.runtime.execution.librarycache.FallbackLibraryCacheManager
 
getFile(BlobKey) - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
Returns a file handle to the file identified by the blob key.
getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.flink.core.fs.FileSystem
Return an array containing hostnames, offset and size of portions of the given file.
getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
 
getFileBlockLocations(FileStatus, long, long) - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
 
getFileCache() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
 
getFileChannel() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileSegment
 
getFilehandlesDriver() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getFilehandlesInput(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getFilePath() - Method in class org.apache.flink.api.common.io.FileInputFormat
 
getFilePath() - Method in class org.apache.flink.api.java.io.CsvReader
 
getFilePath() - Method in class org.apache.flink.migration.runtime.state.filesystem.AbstractFileStateHandle
Deprecated.
Gets the path where this handle's state is stored.
getFilePath() - Method in class org.apache.flink.runtime.state.filesystem.FileStateHandle
Gets the path where this handle's state is stored.
getFiles() - Method in class org.apache.flink.api.common.io.BinaryInputFormat
 
getFileSize() - Method in class org.apache.flink.migration.runtime.state.filesystem.AbstractFileStateHandle
Deprecated.
Returns the file size in bytes.
getFileStats(FileInputFormat.FileBaseStatistics, Path, FileSystem, ArrayList<FileStatus>) - Method in class org.apache.flink.api.common.io.FileInputFormat
 
getFileStatus(Path) - Method in class org.apache.flink.core.fs.FileSystem
Return a file status object that represents the path.
getFileStatus(Path) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
getFileStatus(Path) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
getFileStatus(Path) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
 
getFileStatus(Path) - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
 
getFileSystem() - Method in class org.apache.flink.core.fs.Path
Returns the FileSystem that owns this Path.
getFileSystem() - Method in class org.apache.flink.migration.runtime.state.filesystem.AbstractFileStateHandle
Deprecated.
Gets the file system that stores the file state.
getFilter_level() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
getFilterFactor() - Method in class org.apache.flink.api.common.operators.CompilerHints
 
getFinishedJobs() - Method in class org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails
 
getFirstDegree() - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.EdgeWithDegrees
 
getFirstDegree() - Method in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
 
getFirstElement() - Method in class org.apache.flink.graph.generator.random.BlockInfo
 
getFirstIncomingConnection() - Method in class org.apache.flink.optimizer.dag.TwoInputNode
Gets the DagConnection through which this node receives its first input.
getFirstInput() - Method in class org.apache.flink.api.common.operators.DualInputOperator
Returns the first input, or null, if none is set.
getFirstInput() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
Returns the first DataStream.
getFirstInputType() - Method in class org.apache.flink.api.common.operators.BinaryOperatorInformation
 
getFirstPredecessorNode() - Method in class org.apache.flink.optimizer.dag.TwoInputNode
 
getFirstRecordStart() - Method in class org.apache.flink.api.common.io.BlockInfo
Returns the firstRecordStart.
getFirstVertex() - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Edge
 
getFirstVertex() - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.EdgeWithDegrees
 
getFirstVertex() - Method in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
 
getFirstVertex() - Method in class org.apache.flink.graph.library.TriangleEnumerator.Triad
 
getFiveMinuteRate() - Method in class org.apache.flink.dropwizard.metrics.FlinkMeterWrapper
 
getFlatComparator(List<TypeComparator>) - Method in class org.apache.flink.api.common.typeutils.CompositeTypeComparator
 
getFlatComparator(List<TypeComparator>) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
getFlatComparator(List<TypeComparator>) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
 
getFlatComparator(List<TypeComparator>) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.CompositeTypeComparator
 
getFlatComparators() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Get the field comparators.
getFlatComparators() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
getFlatComparators() - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
getFlatComparators() - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
getFlatComparators() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
getFlatComparators() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
 
getFlatComparators() - Method in class org.apache.flink.api.scala.typeutils.EnumValueComparator
 
getFlatComparators() - Method in class org.apache.flink.api.scala.typeutils.OptionTypeComparator
 
getFlatComparators() - Method in class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
 
getFlatComparators() - Method in class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
 
getFlatComparators() - Method in class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
 
getFlatComparators() - Method in class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
 
getFlatComparators() - Method in class org.apache.flink.table.runtime.types.CRowComparator
 
getFlatFieldExpr() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
getFlatFields(String) - Method in class org.apache.flink.api.common.typeutils.CompositeType
Returns the flat field descriptors for the given field expression.
getFlatFields(String, int, List<CompositeType.FlatFieldDescriptor>) - Method in class org.apache.flink.api.common.typeutils.CompositeType
Computes the flat field descriptors for the given field expression with the given offset.
getFlatFields(String, int, List<CompositeType.FlatFieldDescriptor>) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
getFlatFields(String, int, List<CompositeType.FlatFieldDescriptor>) - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
 
getFlatFields(String, int, List<CompositeType.FlatFieldDescriptor>) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
getFlatFields(String, int, List<CompositeType.FlatFieldDescriptor>) - Method in class org.apache.flink.api.scala.typeutils.CaseClassTypeInfo
 
getFlatFields(String, int, List<CompositeType.FlatFieldDescriptor>) - Method in class org.apache.flink.table.runtime.types.CRowTypeInfo
 
getFlatJoinReturnTypes(FlatJoinFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getFlatJoinReturnTypes(FlatJoinFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getFlatMapReturnTypes(FlatMapFunction<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getFlatMapReturnTypes(FlatMapFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getFlinkConfiguration() - Method in class org.apache.flink.client.program.ClusterClient
Return the Flink configuration object
getFlinkConfiguration() - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
 
getFlinkConfiguration() - Method in class org.apache.flink.yarn.YarnClusterClient
 
getFlinkConfiguration() - Method in class org.apache.flink.yarn.YarnClusterClientV2
 
getFloat(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the Float value for the given key.
getFloat(String, float) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the Float value for the given key.
getFloat(String, float) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given key as a float.
getFloat(ConfigOption<Float>) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as a float.
getFloat(String, float) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getFloat(ConfigOption<Float>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getFloat(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads a single-precision floating point value (32bit, 4 bytes) from the given position, in the system's native byte order.
getFloat(String, float) - Method in class org.apache.flink.metrics.MetricConfig
Searches for the property with the specified key in this property list.
getFloat(int) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getFloatBigEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads a single-precision floating point value (32bit, 4 bytes) from the given position, in big endian byte order.
getFloatByField(String) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getFloatLittleEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads a single-precision floating point value (32bit, 4 bytes) from the given position, in little endian byte order.
getFoldFunction() - Method in class org.apache.flink.api.common.state.FoldingStateDescriptor
Deprecated.
Returns the fold function to be used for the folding state.
getFoldingState(FoldingStateDescriptor<T, ACC>) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Deprecated.
will be removed in a future version
getFoldingState(FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getFoldingState(FoldingStateDescriptor<T, ACC>) - Method in interface org.apache.flink.api.common.state.KeyedStateStore
Deprecated.
will be removed in a future version
getFoldingState(FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
 
getFoldingState(FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
getFoldingState(FoldingStateDescriptor<T, A>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
 
getFoldingState(FoldingStateDescriptor<T, ACC>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.PerWindowStateStore
 
getFoldReturnTypes(FoldFunction<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
Deprecated.
will be removed in a future version
getFoldReturnTypes(FoldFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
Deprecated.
will be removed in a future version
getFollowers_count() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getForAggregation(AggregationFunction.AggregationType) - Static method in class org.apache.flink.streaming.api.functions.aggregation.Comparator
 
getForClass(Class<X>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
Creates type information from a given Class such as Integer, String[] or POJOs.
getForClass(Class<?>) - Static method in class org.apache.flink.streaming.api.functions.aggregation.SumFunction
 
getForForwardExchange(ExecutionMode) - Static method in enum org.apache.flink.runtime.io.network.DataExchangeMode
 
getFormat() - Method in class org.apache.flink.api.java.operators.DataSink
 
getFormat() - Method in class org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
Returns the InputFormat.
getFormatDescription() - Method in class org.apache.flink.runtime.jobgraph.InputFormatVertex
 
getFormatDescription() - Method in class org.apache.flink.runtime.jobgraph.OutputFormatVertex
 
getFormatWrapper() - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
Gets the class describing this sinks output format.
getFormatWrapper() - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
Gets the class describing the input format.
getForObject(X) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getForShuffleOrBroadcast(ExecutionMode) - Static method in enum org.apache.flink.runtime.io.network.DataExchangeMode
 
getForwardingSourceField(int, int) - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
 
getForwardingSourceField(int, int) - Method in class org.apache.flink.api.common.operators.SemanticProperties.EmptySemanticProperties
 
getForwardingSourceField(int, int) - Method in interface org.apache.flink.api.common.operators.SemanticProperties
Returns the index of the source field on the given input from which the target field has been unmodified copied by a function.
getForwardingSourceField(int, int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties.AllFieldsForwardedProperties
 
getForwardingSourceField(int, int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
 
getForwardingSourceField(int, int) - Method in class org.apache.flink.optimizer.dag.BinaryUnionNode.UnionSemanticProperties
 
getForwardingTargetFields(int, int) - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
 
getForwardingTargetFields(int, int) - Method in class org.apache.flink.api.common.operators.SemanticProperties.EmptySemanticProperties
 
getForwardingTargetFields(int, int) - Method in interface org.apache.flink.api.common.operators.SemanticProperties
Returns the indexes of all target fields to which a source field has been unmodified copied by a function.
getForwardingTargetFields(int, int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties.AllFieldsForwardedProperties
 
getForwardingTargetFields(int, int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
 
getForwardingTargetFields(int, int) - Method in class org.apache.flink.optimizer.dag.BinaryUnionNode.UnionSemanticProperties
 
getFQDNHostname() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
Returns the fully-qualified domain name the TaskManager.
getFrameworkConfig() - Method in class org.apache.flink.table.api.TableEnvironment
Returns the Calcite FrameworkConfig of this TableEnvironment.
getFrameworkID() - Method in interface org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore
Get the stored Mesos framework ID.
getFrameworkID() - Method in class org.apache.flink.mesos.runtime.clusterframework.store.StandaloneMesosWorkerStore
 
getFrameworkID() - Method in class org.apache.flink.mesos.runtime.clusterframework.store.ZooKeeperMesosWorkerStore
Get the persisted framework ID.
getFreedMemory() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
getFreeMemory() - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
 
getFreeMemory() - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
 
getFreeMemory() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
 
getFreeSlotForTask(ExecutionVertex, Iterable<TaskManagerLocation>, boolean) - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
Gets a suitable instance to schedule the vertex execution to.
getFrequency() - Method in class org.apache.flink.examples.java.wordcount.WordCountPojo.Word
 
getFrequency() - Method in class org.apache.flink.streaming.examples.wordcount.PojoExample.Word
 
getFriends_count() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getFromHTTP(String) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
getFull_name() - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Places
 
getFullSegments() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBulkBlockReader
 
getFullSegments() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BulkBlockChannelReader
 
getFullTemplateType(Type, int) - Static method in class org.apache.flink.util.ReflectionUtil
Extract the full template type information from the given type's template parameter at the given position.
getFullTemplateType(Type) - Static method in class org.apache.flink.util.ReflectionUtil
Extract the full type information from the given type.
getFullTypeString() - Static method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
getFunction() - Method in class org.apache.flink.api.java.operators.CoGroupOperator
 
getFunction() - Method in class org.apache.flink.api.java.operators.CoGroupRawOperator
 
getFunction() - Method in class org.apache.flink.api.java.operators.CrossOperator
 
getFunction() - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
 
getFunction() - Method in class org.apache.flink.api.java.operators.FilterOperator
 
getFunction() - Method in class org.apache.flink.api.java.operators.FlatMapOperator
 
getFunction() - Method in class org.apache.flink.api.java.operators.GroupCombineOperator
 
getFunction() - Method in class org.apache.flink.api.java.operators.GroupReduceOperator
 
getFunction() - Method in class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
 
getFunction() - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
 
getFunction() - Method in class org.apache.flink.api.java.operators.MapOperator
 
getFunction() - Method in class org.apache.flink.api.java.operators.MapPartitionOperator
 
getFunction() - Method in class org.apache.flink.api.java.operators.ReduceOperator
 
getFunction() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
 
getFunction() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
 
getFunction() - Method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
getFunction() - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
getFunctionCatalog() - Method in class org.apache.flink.table.api.TableEnvironment
 
getFunctionName() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
getFunctionNames() - Method in class org.apache.flink.table.catalog.ExternalCatalogSchema
 
getFunctionRuntimeContext(Function, RuntimeContext) - Static method in class org.apache.flink.api.common.functions.util.FunctionUtils
 
getFunctions(String) - Method in class org.apache.flink.table.catalog.ExternalCatalogSchema
 
getFunctionState() - Method in class org.apache.flink.migration.streaming.runtime.tasks.StreamTaskState
Deprecated.
 
getFunctionType() - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
getFunctionType() - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
getFunctionType() - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
getFunctionType() - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
getFuture() - Method in class org.apache.flink.runtime.registration.RetryingRegistration
 
getFuture() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
 
getFuture() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamRecordQueueEntry
 
getFuture() - Method in class org.apache.flink.streaming.api.operators.async.queue.WatermarkQueueEntry
 
getFutureExecutor() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Returns the ExecutionContext associated with this ExecutionGraph.
getGarbageCollectorStatsAsString(List<GarbageCollectorMXBean>) - Static method in class org.apache.flink.runtime.taskmanager.MemoryLogger
Gets the garbage collection statistics from the JVM.
getGatherBcastVars() - Method in class org.apache.flink.graph.gsa.GSAConfiguration
Get the broadcast variables of the GatherFunction.
getGatherBcastVars() - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
Get the broadcast variables of the GatherFunction.
getGenericFieldTypes() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
getGenericParameters() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
Optional method for giving Flink's type extraction system information about the mapping of a generic type parameter to the type information of a subtype.
getGenericParameters() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
 
getGenericParameters() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
getGenericParameters() - Method in class org.apache.flink.api.scala.typeutils.CaseClassTypeInfo
 
getGenericParameters() - Method in class org.apache.flink.api.scala.typeutils.EitherTypeInfo
 
getGenericParameters() - Method in class org.apache.flink.api.scala.typeutils.EnumValueTypeInfo
 
getGenericParameters() - Method in class org.apache.flink.api.scala.typeutils.OptionTypeInfo
 
getGenericParameters() - Method in class org.apache.flink.api.scala.typeutils.TraversableTypeInfo
 
getGenericParameters() - Method in class org.apache.flink.api.scala.typeutils.TryTypeInfo
 
getGenericParameters() - Method in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
 
getGenericParameters() - Static method in class org.apache.flink.table.runtime.types.CRowTypeInfo
 
getGenericParameters() - Static method in class org.apache.flink.table.typeutils.RowIntervalTypeInfo
 
getGenericParameters() - Static method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
 
getGenericParameters() - Static method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
 
getGibiBytes() - Method in class org.apache.flink.configuration.MemorySize
Gets the memory size in Gibibytes (= 1024 Mebibytes).
getGlobal_properties() - Method in class org.apache.flink.table.explain.Node
 
getGlobalClusteringCoefficientScore() - Method in class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient.Result
Get the global clustering coefficient score.
getGlobalClusteringCoefficientScore() - Method in class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient.Result
Get the global clustering coefficient score.
getGlobalJobParameters() - Method in class org.apache.flink.api.common.ArchivedExecutionConfig
 
getGlobalJobParameters() - Method in class org.apache.flink.api.common.ExecutionConfig
 
getGlobalModificationTime() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
 
getGlobalModVersion() - Method in class org.apache.flink.runtime.executiongraph.Execution
Gets the global modification version of the execution graph when this execution was created.
getGlobalProperties() - Method in class org.apache.flink.optimizer.dataproperties.InterestingProperties
Gets the interesting global properties.
getGlobalProperties() - Method in class org.apache.flink.optimizer.plan.Channel
 
getGlobalProperties() - Method in class org.apache.flink.optimizer.plan.PlanNode
Gets the global properties from this PlanNode.
getGradeSource(StreamExecutionEnvironment, long) - Method in class org.apache.flink.streaming.scala.examples.join.WindowJoinSampleData$
Continuously generates (name, grade).
getGradeSource(StreamExecutionEnvironment, long) - Static method in class org.apache.flink.streaming.scala.examples.join.WindowJoinSampleData
Continuously generates (name, grade).
getGraph() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getGroupCombineReturnTypes(GroupCombineFunction<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getGroupCombineReturnTypes(GroupCombineFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getGroupCount() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
 
getGroupCount() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
getGroupCount() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
getGroupCount() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getGroupedFields() - Method in class org.apache.flink.optimizer.dataproperties.LocalProperties
Gets the grouped fields.
getGroupedFields() - Method in class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
Gets the grouped fields.
getGroupID() - Method in class org.apache.flink.runtime.instance.Slot
Gets the ID that identifies the logical group to which this slot belongs: If the slot does not belong to any group in particular, this field is null. If this slot was allocated as a sub-slot of a SlotSharingGroupAssignment, then this ID will be the JobVertexID of the vertex whose task the slot holds in its shared slot. In case that the slot represents the shared slot of a co-location constraint, this ID will be the ID of the co-location constraint.
getGroupId() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
Gets the ID that identifies the co-location group.
getGroupings() - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupAggregate
 
getGroupings() - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
Returns the name for this group, meaning what kind of entity it represents, for example "taskmanager".
getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.GenericMetricGroup
 
getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
 
getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.JobMetricGroup
 
getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.OperatorMetricGroup
 
getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
 
getGroupName(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
getGroupOrder(int) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
Gets the value order for an input, i.e.
getGroupOrder(int) - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
Gets the value order for an input, i.e.
getGroupOrder() - Method in class org.apache.flink.api.common.operators.base.GroupCombineOperatorBase
Gets the order of elements within a reduce group.
getGroupOrder() - Method in class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
Gets the order of elements within a reduce group.
getGroupOrderForInputOne() - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
Gets the order of elements within a group for the first input.
getGroupOrderForInputOne() - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
Gets the order of elements within a group for the first input.
getGroupOrderForInputTwo() - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
Gets the order of elements within a group for the second input.
getGroupOrderForInputTwo() - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
Gets the order of elements within a group for the second input.
getGroupOrdering() - Method in class org.apache.flink.api.java.operators.SortedGrouping
 
getGroupRangeOffsets() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
 
getGroupReduceReturnTypes(GroupReduceFunction<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getGroupReduceReturnTypes(GroupReduceFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getGroupRepresentativeId() - Method in class org.apache.flink.graph.library.Summarization.VertexGroupItem
 
getGroupRepresentativeId() - Method in class org.apache.flink.graph.library.Summarization.VertexWithRepresentative
 
getGroupSet() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
getGroupSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
getGroupSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getGroupSets() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
getGroupSets() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
getGroupSets() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getGroupSize(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getGroupSortKeyPositions() - Method in class org.apache.flink.api.java.operators.SortedGrouping
 
getGroupSortOrders() - Method in class org.apache.flink.api.java.operators.SortedGrouping
 
getGroupType() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
getGroupType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
getGroupType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getGuaranteedAvailableMemory() - Method in class org.apache.flink.optimizer.plan.PlanNode
 
getHadoopConfiguration() - Static method in class org.apache.flink.api.java.hadoop.mapred.utils.HadoopUtils
Returns a new Hadoop Configuration object using the path to the hadoop conf configured in the main configuration (flink-conf.yaml).
getHadoopConfiguration() - Static method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
Returns a new Hadoop Configuration object using the path to the hadoop conf configured in the main configuration (flink-conf.yaml).
getHadoopConfiguration() - Method in class org.apache.flink.runtime.security.SecurityUtils.SecurityConfiguration
 
getHadoopFileSystem() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
Gets the underlying Hadoop FileSystem.
getHadoopInputSplit() - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopInputSplit
 
getHadoopInputSplit() - Method in class org.apache.flink.api.java.hadoop.mapreduce.wrapper.HadoopInputSplit
 
getHadoopInputStream() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
Gets the wrapped Hadoop input stream.
getHadoopOutputStream() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataOutputStream
Gets the wrapped Hadoop output stream.
getHadoopServicePrincipal() - Static method in class org.apache.flink.test.util.SecureTestEnvironment
 
getHadoopWrapperClassNameForFileSystem(String) - Method in interface org.apache.flink.core.fs.HadoopFileSystemWrapper
Test whether the HadoopWrapper can wrap the given file system scheme.
getHadoopWrapperClassNameForFileSystem(String) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
 
getHandleName() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
 
getHashJoin(TypeSerializer<BT>, TypeComparator<BT>, TypeSerializer<PT>, TypeComparator<PT>, TypePairComparator<PT, BT>, MemoryManager, IOManager, AbstractInvokable, double, boolean) - Method in class org.apache.flink.runtime.operators.hash.HashJoinIteratorBase
 
getHashJoin(TypeSerializer<BT>, TypeComparator<BT>, TypeSerializer<PT>, TypeComparator<PT>, TypePairComparator<PT, BT>, MemoryManager, IOManager, AbstractInvokable, double, boolean) - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstReOpenableHashJoinIterator
 
getHashJoin(TypeSerializer<BT>, TypeComparator<BT>, TypeSerializer<PT>, TypeComparator<PT>, TypePairComparator<PT, BT>, MemoryManager, IOManager, AbstractInvokable, double, boolean) - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondReOpenableHashJoinIterator
 
getHashJoin(TypeSerializer<BT>, TypeComparator<BT>, TypeSerializer<PT>, TypeComparator<PT>, TypePairComparator<PT, BT>, MemoryManager, IOManager, AbstractInvokable, double, boolean) - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildFirstReOpenableHashJoinIterator
 
getHashJoin(TypeSerializer<BT>, TypeComparator<BT>, TypeSerializer<PT>, TypeComparator<PT>, TypePairComparator<PT, BT>, MemoryManager, IOManager, AbstractInvokable, double, boolean) - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildSecondReOpenableHashJoinIterator
 
getHashtags() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Entities
 
getHeadOperator() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
 
getHeapMemory() - Method in class org.apache.flink.api.common.operators.ResourceSpec
 
getHeapMemoryInMB() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
Get the heap memory needed in MB
getHeartbeatInterval() - Method in class org.apache.flink.runtime.jobmaster.JobMasterRegistrationSuccess
Gets the interval in which the ResourceManager will heartbeat the JobMaster.
getHeartbeatInterval() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerConfiguration
 
getHeartbeatInterval() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
Gets the interval in which the ResourceManager will heartbeat the TaskExecutor.
getHeight() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Size
 
getHelp() - Method in class org.apache.flink.api.java.utils.RequiredParameters
Build a help text for the defined parameters.
getHelp(List<String>) - Method in class org.apache.flink.api.java.utils.RequiredParameters
Build a help text for the defined parameters and list the missing arguments at the end of the text.
getHelpText() - Method in class org.apache.flink.api.java.utils.Option
 
getHeuristicCpuCost() - Method in class org.apache.flink.optimizer.costs.Costs
Gets the heuristic cost for the CPU.
getHeuristicDiskCost() - Method in class org.apache.flink.optimizer.costs.Costs
Gets the heuristic costs for disk.
getHeuristicNetworkCost() - Method in class org.apache.flink.optimizer.costs.Costs
Gets the heuristic network cost.
getHistogram(String) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Convenience function to create a counter object for histograms.
getHistogram(String) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getHistory() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsSnapshot
Returns the snapshotted checkpoint history.
getHomeDirectory() - Method in class org.apache.flink.core.fs.FileSystem
Returns the path of the user's home directory in this file system.
getHomeDirectory() - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
getHomeDirectory() - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
getHomeDirectory() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
 
getHomeDirectory() - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
 
getHost() - Method in class org.apache.flink.metrics.datadog.DMetric
 
getHost() - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
 
getHost() - Method in class org.apache.flink.runtime.query.KvStateServerAddress
Returns the host address of the KvStateServer.
getHost() - Method in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
Gets the hostname of the master (JobManager), where the program will be executed.
getHost() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig
 
getHostname() - Method in class org.apache.flink.runtime.minicluster.StandaloneMiniCluster
 
getHostname() - Method in interface org.apache.flink.runtime.rpc.RpcGateway
Returns the fully qualified hostname under which the associated rpc endpoint is reachable.
getHostname() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
Gets the hostname of the TaskManager.
getHostnameFromFQDN(String) - Static method in class org.apache.flink.util.NetUtils
Turn a fully qualified domain name (fqdn) into a hostname.
getHostnames() - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopInputSplit
 
getHostnames() - Method in class org.apache.flink.api.java.hadoop.mapreduce.wrapper.HadoopInputSplit
 
getHostnames() - Method in class org.apache.flink.core.io.LocatableInputSplit
Returns the names of the hosts storing the data this input split refers to
getHosts() - Method in interface org.apache.flink.core.fs.BlockLocation
Get the list of hosts (hostname) hosting this block.
getHosts() - Method in class org.apache.flink.core.fs.local.LocalBlockLocation
 
getHosts() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopBlockLocation
 
getHubScore() - Method in class org.apache.flink.graph.library.link_analysis.HITS.Result
Get the hub score.
getId() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Gets the JobID by which this environment is identified.
getId() - Method in enum org.apache.flink.api.java.sca.TaggedValue.Input
 
getId() - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Gets the UUID by which this environment is identified.
getId() - Method in interface org.apache.flink.client.cli.CustomCommandLine
Gets the unique identifier of this CustomCommandLine
getId() - Method in class org.apache.flink.client.cli.DefaultCLI
 
getId() - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Places
 
getId() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Contributors
 
getId() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.CurrentUserRetweet
 
getId() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Media
 
getId() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.UserMention
 
getId() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
getId() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getId() - Method in class org.apache.flink.graph.Vertex
 
getId() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
Gets the ID of this node.
getId() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
 
getId() - Method in class org.apache.flink.runtime.instance.Instance
 
getId() - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
 
getId() - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
 
getID() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
Returns the ID of this job vertex.
getId() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
Gets the ID that identifies this co-location group.
getID() - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
Returns the ID of the task this result belongs to
getId() - Method in class org.apache.flink.streaming.api.datastream.DataStream
Returns the ID of the DataStream in the current StreamExecutionEnvironment.
getId() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getId() - Method in class org.apache.flink.streaming.api.scala.DataStream
Returns the ID of the DataStream.
getId() - Static method in class org.apache.flink.streaming.api.scala.OutputTag
 
getId() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
Returns the unique ID of this StreamTransformation.
getId() - Method in class org.apache.flink.table.explain.Node
 
getId() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
getId() - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
getId() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
getId() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
getId() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
getId() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
getId() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
getId() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
getId() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
getId() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
getId() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
getId() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
getId() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
getId() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
getId() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
getId() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getId() - Method in class org.apache.flink.util.OutputTag
 
getId() - Method in class org.apache.flink.yarn.cli.FlinkYarnCLI
 
getId() - Method in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
 
getId_str() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Contributors
 
getId_str() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.CurrentUserRetweet
 
getId_str() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Media
 
getId_str() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.UserMention
 
getId_str() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
getId_str() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getIdAlternatives() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
Returns a list of all alternative IDs of this job vertex.
getIdentifier() - Method in interface org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook
Gets the identifier of this hook.
getIdentity() - Method in class org.apache.flink.graph.drivers.input.CirculantGraph
 
getIdentity() - Method in class org.apache.flink.graph.drivers.input.CompleteGraph
 
getIdentity() - Method in class org.apache.flink.graph.drivers.input.CSV
 
getIdentity() - Method in class org.apache.flink.graph.drivers.input.CycleGraph
 
getIdentity() - Method in class org.apache.flink.graph.drivers.input.EchoGraph
 
getIdentity() - Method in class org.apache.flink.graph.drivers.input.EmptyGraph
 
getIdentity() - Method in class org.apache.flink.graph.drivers.input.GridGraph
 
getIdentity() - Method in class org.apache.flink.graph.drivers.input.HypercubeGraph
 
getIdentity() - Method in interface org.apache.flink.graph.drivers.input.Input
A human-readable identifier summarizing the input and configuration.
getIdentity() - Method in class org.apache.flink.graph.drivers.input.PathGraph
 
getIdentity() - Method in class org.apache.flink.graph.drivers.input.RMatGraph
 
getIdentity() - Method in class org.apache.flink.graph.drivers.input.SingletonEdgeGraph
 
getIdentity() - Method in class org.apache.flink.graph.drivers.input.StarGraph
 
getIdleSince() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
getIdString() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Gets the JobID by which this environment is identified, as a string.
getIdString() - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Gets the UUID by which this environment is identified, as a string.
getImplicitConvergenceCriterion(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getImplicitConvergenceCriterionAggregatorName() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getIn_reply_to_screen_name() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
getIn_reply_to_status_id() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
getIn_reply_to_status_id_str() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
getIn_reply_to_user_id() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
getIn_reply_to_user_id_str() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
getInAggregateGroupExpression(RexBuilder, RexCall) - Method in class org.apache.flink.table.plan.rules.common.LogicalWindowAggregateRule
Returns the expression that replaces the window expression before the aggregation.
getInAggregateGroupExpression(RexBuilder, RexCall) - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetLogicalWindowAggregateRule
Returns the operand of the group window function.
getInAggregateGroupExpression(RexBuilder, RexCall) - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamLogicalWindowAggregateRule
Returns a reference to the time attribute with a time indicator type
getIncomingConnection() - Method in class org.apache.flink.optimizer.dag.SingleInputNode
Gets the input of this operator.
getIncomingConnections() - Method in class org.apache.flink.optimizer.dag.AbstractPartialSolutionNode
 
getIncomingConnections() - Method in class org.apache.flink.optimizer.dag.DataSinkNode
 
getIncomingConnections() - Method in class org.apache.flink.optimizer.dag.DataSourceNode
 
getIncomingConnections() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
Gets all incoming connections of this node.
getIncomingConnections() - Method in class org.apache.flink.optimizer.dag.SingleInputNode
 
getIncomingConnections() - Method in class org.apache.flink.optimizer.dag.TwoInputNode
 
getInDegree() - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees.Degrees
 
getInDegree() - Method in class org.apache.flink.graph.spargel.GatherFunction
Retrieves the vertex in-degree (number of in-coming edges).
getInDegree() - Method in class org.apache.flink.graph.spargel.ScatterFunction
Retrieves the vertex in-degree (number of in-coming edges).
getindent(String) - Method in class org.apache.flink.table.codegen.IndentStringContext
 
getIndex() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
 
getIndexInSubtaskGroup() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
Returns the index of this subtask in the subtask group.
getIndexOfThisSubtask() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Gets the number of this parallel subtask.
getIndexOfThisSubtask() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getIndexOfThisSubtask() - Method in class org.apache.flink.api.common.TaskInfo
Gets the number of this parallel subtask.
getIndicatorCount() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
getIndicatorCount() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
getIndicatorCount() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getIndices() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.HashTags
 
getIndices() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Media
 
getIndices() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Symbol
 
getIndices() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.URL
 
getIndices() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.UserMention
 
getInEdgeIndices() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getInEdges() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getInetSockeAddressFromAkkaURL(String) - Method in class org.apache.flink.runtime.akka.AkkaUtils$
Extracts the hostname and the port of the remote actor system from the given Akka URL.
getInetSockeAddressFromAkkaURL(String) - Static method in class org.apache.flink.runtime.akka.AkkaUtils
Extracts the hostname and the port of the remote actor system from the given Akka URL.
getInfinityCount() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
Number of values that are positive or negative infinity.
getInflaterInputStreamFactory(String) - Static method in class org.apache.flink.api.common.io.FileInputFormat
 
getInfoFor(Class<X>) - Static method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
getInfoFor(Class<X>) - Static method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
getInfoFor(Class<X>) - Static method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
Tries to get the PrimitiveArrayTypeInfo for an array.
getInfoFor(Class<X>) - Static method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
getInfoFor(Class<T>, TypeInformation<C>) - Static method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
getInfoFor(TypeInformation<C>) - Static method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
Creates a new ObjectArrayTypeInfo from a TypeInformation for the component type.
getInfoSize() - Method in class org.apache.flink.api.common.io.BlockInfo
 
getInitializerExpressionFactory() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
 
getInitialRegistrationPause() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getInitialSolutionSet() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
Returns the initial solution set input, or null, if none is set.
getInitialSolutionSet() - Method in class org.apache.flink.api.java.operators.DeltaIteration
Gets the initial solution set.
getInitialSolutionSetInput() - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
 
getInitialSolutionSetPredecessorNode() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
 
getInitialTableSize(int, int, int, int) - Static method in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
getInitialWorkset() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
Returns the initial workset input, or null, if none is set.
getInitialWorkset() - Method in class org.apache.flink.api.java.operators.DeltaIteration
Gets the initial workset.
getInitialWorksetInput() - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
 
getInitialWorksetPredecessorNode() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.BooleanMaxAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.BooleanMaxWithRetractAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.BooleanMinAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.BooleanMinWithRetractAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.ByteMaxAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.ByteMaxWithRetractAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.ByteMinAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.ByteMinWithRetractAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.DecimalMaxAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.DecimalMaxWithRetractAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.DecimalMinAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.DecimalMinWithRetractAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.DoubleMaxAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.DoubleMaxWithRetractAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.DoubleMinAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.DoubleMinWithRetractAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.FloatMaxAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.FloatMaxWithRetractAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.FloatMinAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.FloatMinWithRetractAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.IntMaxAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.IntMaxWithRetractAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.IntMinAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.IntMinWithRetractAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.LongMaxAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.LongMaxWithRetractAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.LongMinAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.LongMinWithRetractAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.MaxAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.MaxWithRetractAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.MinAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.MinWithRetractAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.ShortMaxAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.ShortMaxWithRetractAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.ShortMinAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.ShortMinWithRetractAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.StringMaxAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.StringMaxWithRetractAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.StringMinAggFunction
 
getInitValue() - Method in class org.apache.flink.table.functions.aggfunctions.StringMinWithRetractAggFunction
 
getInnerConsumingStrategy() - Method in class org.apache.flink.cep.pattern.Quantifier
 
getInPhysicalEdges(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getInProgressHandler() - Method in class org.apache.flink.runtime.webmonitor.handlers.JobCancellationWithSavepointHandlers
 
getInput() - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
Returns this operator's input operator.
getInput() - Method in class org.apache.flink.api.common.operators.SingleInputOperator
Returns the input operator or data source, or null, if none is set.
getInput() - Method in class org.apache.flink.api.java.operators.NoOpOperator
 
getInput() - Method in class org.apache.flink.api.java.operators.SingleInputOperator
Gets the data set that this operation uses as its input.
getInput() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
getInput() - Method in class org.apache.flink.optimizer.plan.SingleInputPlanNode
Gets the input channel to this node.
getInput(int) - Method in class org.apache.flink.runtime.operators.BatchTask
 
getInput(int) - Method in interface org.apache.flink.runtime.operators.TaskContext
 
getInput() - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
Returns the input StreamTransformation of this FeedbackTransformation.
getInput() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
Returns the input StreamTransformation of this OneInputTransformation.
getInput() - Method in class org.apache.flink.streaming.api.transformations.PartitionTransformation
Returns the input StreamTransformation of this SinkTransformation.
getInput() - Method in class org.apache.flink.streaming.api.transformations.SelectTransformation
Returns the input StreamTransformation.
getInput() - Method in class org.apache.flink.streaming.api.transformations.SideOutputTransformation
Returns the input StreamTransformation.
getInput() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
Returns the input StreamTransformation of this SinkTransformation.
getInput() - Method in class org.apache.flink.streaming.api.transformations.SplitTransformation
Returns the input StreamTransformation.
getInput(int) - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
getInput() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
getInput(int) - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
getInput() - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
getInput(int) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
getInput() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
getInput(int) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
getInput() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
getInput(int) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
getInput(int) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
getInput(int) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
getInput(int) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
getInput(int) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
getInput(int) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
getInput() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
getInput(int) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
getInput() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
getInput(int) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
getInput(int) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
getInput(int) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
getInput(int) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
getInput(int) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getInput() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getInput() - Method in class org.apache.flink.table.runtime.TableFunctionCollector
Gets the input value from left table, which will be used to cross join with the result of table function.
getInput1() - Method in class org.apache.flink.api.java.operators.TwoInputOperator
Gets the data set that this operation uses as its first input.
getInput1() - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
Gets the first input channel to this node.
getInput1() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
Returns the first input StreamTransformation of this TwoInputTransformation.
getInput1AsTaggedValue() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
getInput1Type() - Method in class org.apache.flink.api.java.operators.TwoInputOperator
Gets the type information of the data type of the first input data set.
getInput2() - Method in class org.apache.flink.api.java.operators.TwoInputOperator
Gets the data set that this operation uses as its second input.
getInput2() - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
Gets the second input channel to this node.
getInput2() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
Returns the first input StreamTransformation of this TwoInputTransformation.
getInput2AsTaggedValue() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
getInput2Type() - Method in class org.apache.flink.api.java.operators.TwoInputOperator
Gets the type information of the data type of the second input data set.
getInputChannelDeploymentDescriptor() - Method in class org.apache.flink.runtime.executiongraph.PartitionInfo
 
getInputChannelDeploymentDescriptors() - Method in class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
 
getInputChannelId() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
getInputChannelStatus(int) - Method in class org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve
 
getInputComparator(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getInputConnection() - Method in class org.apache.flink.optimizer.dag.DataSinkNode
Gets the input of the sink.
getInputDataSet() - Method in class org.apache.flink.api.java.operators.Grouping
Returns the input DataSet of a grouping operation, that is the one before the grouping.
getInputEdges(int) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getInputFormat() - Method in class org.apache.flink.api.java.operators.DataSource
Gets the input format that is executed by this data source.
getInputFormat() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getInputFormatTypes(InputFormat<IN, ?>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getInputGate(int) - Method in interface org.apache.flink.runtime.execution.Environment
 
getInputGate(int) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getInputGateById(IntermediateDataSetID) - Method in class org.apache.flink.runtime.taskmanager.Task
 
getInputGates() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
 
getInputLocalStrategy(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getInputNum() - Method in class org.apache.flink.runtime.executiongraph.ExecutionEdge
 
getInputs() - Method in class org.apache.flink.optimizer.plan.BulkPartialSolutionPlanNode
 
getInputs() - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
 
getInputs() - Method in class org.apache.flink.optimizer.plan.NAryUnionPlanNode
 
getInputs() - Method in class org.apache.flink.optimizer.plan.PlanNode
 
getInputs() - Method in class org.apache.flink.optimizer.plan.SingleInputPlanNode
 
getInputs() - Method in class org.apache.flink.optimizer.plan.SolutionSetPlanNode
 
getInputs() - Method in class org.apache.flink.optimizer.plan.SourcePlanNode
 
getInputs() - Method in class org.apache.flink.optimizer.plan.WorksetPlanNode
 
getInputs() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getInputs() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
getInputs() - Method in class org.apache.flink.streaming.api.transformations.UnionTransformation
Returns the list of input StreamTransformations.
getInputs() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
getInputs() - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
getInputs() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
getInputs() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
getInputs() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
getInputs() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
getInputs() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
getInputs() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
getInputs() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
getInputs() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
getInputs() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
getInputs() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
getInputs() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
getInputs() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
getInputs() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
getInputs() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getInputSerializer(int) - Method in class org.apache.flink.runtime.operators.BatchTask
 
getInputSerializer(int) - Method in interface org.apache.flink.runtime.operators.TaskContext
 
getInputSerializer(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getInputSplit() - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyReporter
 
getInputSplitAssigner(TableInputSplit[]) - Method in class org.apache.flink.addons.hbase.AbstractTableInputFormat
 
getInputSplitAssigner(FileInputSplit[]) - Method in class org.apache.flink.api.common.io.FileInputFormat
 
getInputSplitAssigner(GenericInputSplit[]) - Method in class org.apache.flink.api.common.io.GenericInputFormat
 
getInputSplitAssigner(T[]) - Method in interface org.apache.flink.api.common.io.InputFormat
Gets the type of the input splits that are processed by this input format.
getInputSplitAssigner(S[]) - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
 
getInputSplitAssigner(HadoopInputSplit[]) - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
getInputSplitAssigner(HadoopInputSplit[]) - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
getInputSplitAssigner(InputSplit[]) - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat
 
getInputSplitAssigner(InputSplit[]) - Method in class org.apache.flink.batch.connectors.cassandra.CassandraInputFormat
 
getInputSplitAssigner(T[]) - Method in interface org.apache.flink.core.io.InputSplitSource
Returns the assigner for the input splits.
getInputSplitAssigner(FileCopyTaskInputSplit[]) - Method in class org.apache.flink.examples.java.distcp.FileCopyTaskInputFormat
 
getInputSplitAssigner(HadoopInputSplit[]) - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
 
getInputSplitData() - Method in class org.apache.flink.runtime.jobmaster.SerializedInputSplit
 
getInputSplitProvider() - Method in interface org.apache.flink.runtime.execution.Environment
Returns the input split provider assigned to this environment.
getInputSplitProvider() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getInputSplitProvider() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
Returns the input split provider associated with the operator.
getInputSplits() - Method in class org.apache.flink.api.common.io.BinaryInputFormat
 
getInputSplitSource() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
getInputStream() - Method in class org.apache.flink.cep.PatternStream
 
getInputStream() - Method in class org.apache.flink.cep.scala.PatternStream
 
getInputType() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
getInputType() - Method in class org.apache.flink.api.common.operators.UnaryOperatorInformation
 
getInputType() - Method in class org.apache.flink.api.java.operators.SingleInputOperator
Gets the type information of the data type of the input data set.
getInputType() - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
 
getInputType() - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
 
getInputType() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
Returns the TypeInformation for the elements of the input.
getInputType1() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
Returns the TypeInformation for the elements from the first input.
getInputType2() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
Returns the TypeInformation for the elements from the first input.
getInputView() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
 
getInstalledContext() - Static method in class org.apache.flink.runtime.security.SecurityUtils
 
getInstance() - Static method in class org.apache.flink.api.common.io.compression.Bzip2InputStreamFactory
 
getInstance() - Static method in class org.apache.flink.api.common.io.compression.DeflateInflaterInputStreamFactory
 
getInstance() - Static method in class org.apache.flink.api.common.io.compression.GzipInflaterInputStreamFactory
 
getInstance() - Static method in class org.apache.flink.api.common.io.compression.XZInputStreamFactory
 
getInstance() - Static method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
getInstance() - Static method in class org.apache.flink.runtime.clusterframework.messages.GetClusterStatus
Gets the singleton instance.
getInstance() - Static method in class org.apache.flink.runtime.clusterframework.messages.RegisterInfoMessageListener
Gets the singleton instance.
getInstance() - Static method in class org.apache.flink.runtime.clusterframework.messages.StopClusterSuccessful
 
getInstance() - Method in exception org.apache.flink.runtime.instance.InstanceDiedException
 
getInstance() - Static method in class org.apache.flink.runtime.messages.webmonitor.RequestJobsOverview
 
getInstance() - Static method in class org.apache.flink.runtime.messages.webmonitor.RequestJobsWithIDsOverview
 
getInstance() - Static method in class org.apache.flink.runtime.messages.webmonitor.RequestStatusOverview
 
getInstance() - Method in interface org.apache.flink.runtime.plugable.DeserializationDelegate
 
getInstance() - Method in class org.apache.flink.runtime.plugable.NonReusingDeserializationDelegate
 
getInstance() - Method in class org.apache.flink.runtime.plugable.ReusingDeserializationDelegate
 
getInstance() - Method in class org.apache.flink.runtime.plugable.SerializationDelegate
 
getInstance() - Static method in class org.apache.flink.runtime.util.clock.SystemClock
 
getInstance() - Static method in class org.apache.flink.types.NullValue
Returns the NullValue singleton instance.
getInstanceBasePath() - Method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
Only visible for testing, DO NOT USE.
getInstanceId() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
getInstanceId() - Method in class org.apache.flink.runtime.messages.StackTrace
 
getInstanceID() - Method in class org.apache.flink.runtime.resourcemanager.registration.TaskExecutorConnection
 
getInstanceId() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
getInstancesByHost() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
getInSubQueryThreshold() - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
Returns the inSubQueryThreshold option, default SqlToRelConverter.DEFAULT_IN_SUB_QUERY_THRESHOLD.
getInSubqueryThreshold() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Deprecated.
getInt(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the Integer value for the given key.
getInt(String, int) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the Integer value for the given key.
getInt(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads an int value (32bit, 4 bytes) from the given position, in the system's native byte order.
getInt(Properties, String, int) - Static method in class org.apache.flink.util.PropertiesUtil
Get integer from properties.
getIntBigEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads an int value (32bit, 4 bytes) from the given position, in big-endian byte order.
getIntConstant() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
getIntCounter(String) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Convenience function to create a counter object for integers.
getIntCounter(String) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getIntCounterResult(String) - Method in class org.apache.flink.api.common.JobExecutionResult
Deprecated.
Will be removed in future versions. Use JobExecutionResult.getAccumulatorResult(java.lang.String) instead.
getIntCounterResult(String) - Method in class org.apache.flink.client.program.DetachedEnvironment.DetachedJobExecutionResult
 
getInteger(String, int) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given key as an integer.
getInteger(ConfigOption<Integer>) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as an integer.
getInteger(String, int) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getInteger(ConfigOption<Integer>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getInteger(String, int) - Method in class org.apache.flink.metrics.MetricConfig
Searches for the property with the specified key in this property list.
getInteger(int) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getIntegerByField(String) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getIntegerWithDeprecatedKeys(Configuration, String, int, String...) - Static method in class org.apache.flink.util.ConfigurationUtil
Returns the value associated with the given key as an Integer in the given Configuration.
getInterestingProperties() - Method in class org.apache.flink.optimizer.dag.DagConnection
Gets the interesting properties object for this pact connection.
getInterestingProperties() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
Gets the properties that are interesting for this node to produce.
getIntermediateDataSetID() - Method in class org.apache.flink.runtime.executiongraph.PartitionInfo
 
getIntermediateResult() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
 
getIntermediateVertexId() - Method in class org.apache.flink.graph.bipartite.Projection
 
getIntermediateVertexValue() - Method in class org.apache.flink.graph.bipartite.Projection
 
getInternalFileStatus() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
 
getInternalTimerService(String, TypeSerializer<N>, Triggerable<K, N>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
Returns a InternalTimerService that can be used to query current processing time and event time and to set timers.
getInternalUdfClassName() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
getIntersection(KeyGroupRange) - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
 
getIntersection(KeyGroupRange) - Method in interface org.apache.flink.runtime.state.KeyedStateHandle
Returns a state over a range that is the intersection between this handle's key-group range and the provided key-group range.
getIntersection(KeyGroupRange) - Method in class org.apache.flink.runtime.state.KeyGroupRange
Create a range that represent the intersection between this range and the given range.
getIntersection(KeyGroupRange) - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
Returns a key-group range with offsets which is the intersection of the internal key-group range with the given key-group range.
getIntersection(KeyGroupRange) - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
 
getInterval() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
 
getInterval() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
 
getIntervalQualifier() - Static method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
getIntLittleEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads an int value (32bit, 4 bytes) from the given position, in little-endian byte order.
getInTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.BatchTableSourceScanRule
 
getInTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateRule
 
getInTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateWithNullValuesRule
 
getInTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetCalcRule
 
getInTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetCorrelateRule
 
getInTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetDistinctRule
 
getInTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetIntersectRule
 
getInTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetJoinRule
 
getInTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetMinusRule
 
getInTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetScanRule
 
getInTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetSingleRowJoinRule
 
getInTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetSortRule
 
getInTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetUnionRule
 
getInTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetValuesRule
 
getInTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetWindowAggregateRule
 
getInTrait() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamCalcRule
 
getInTrait() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamCorrelateRule
 
getInTrait() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupAggregateRule
 
getInTrait() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupWindowAggregateRule
 
getInTrait() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamOverAggregateRule
 
getInTrait() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamScanRule
 
getInTrait() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamUnionRule
 
getInTrait() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamValuesRule
 
getInTrait() - Static method in class org.apache.flink.table.plan.rules.datastream.StreamTableSourceScanRule
 
getInvokableClass(ClassLoader) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
Returns the invokable class which represents the task of this vertex
getInvokableClassName() - Method in class org.apache.flink.runtime.executiongraph.TaskInformation
 
getInvokableClassName() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
Returns the name of the invokable class which represents the task of this vertex.
getInvolvedIndexes() - Method in class org.apache.flink.api.common.operators.Ordering
 
getIo() - Method in class org.apache.flink.table.plan.cost.DataSetCost
 
getIoHandle() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncIOCallable
Returns the IO handle.
getIOManager() - Method in interface org.apache.flink.runtime.execution.Environment
Returns the current IOManager.
getIOManager() - Method in class org.apache.flink.runtime.operators.BatchTask
 
getIOManager() - Method in interface org.apache.flink.runtime.operators.TaskContext
 
getIOManager() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
 
getIOManager() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getIOMetricGroup() - Method in class org.apache.flink.runtime.metrics.groups.OperatorMetricGroup
Returns the OperatorIOMetricGroup for this operator.
getIOMetricGroup() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
Returns the TaskIOMetricGroup for this task.
getIOMetrics() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
 
getIOMetrics() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
 
getIOMetrics() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
getIOMetrics() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
getIOMetrics() - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
 
getIsAutoCommitEnabled() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer08
 
getIsAutoCommitEnabled() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
 
getIsAutoCommitEnabled() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
 
getIsFromFirst() - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCrossFunction
 
getIsFromFirst() - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectFlatJoinFunction
 
getIso3() - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Attributes
 
getIsSolutionSetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getIsSolutionSetUpdateWithoutReprobe() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getIsWorksetIteration() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getIsWorksetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getIterationAggregator(String) - Method in interface org.apache.flink.api.common.functions.IterationRuntimeContext
 
getIterationAggregator(String) - Method in class org.apache.flink.graph.gsa.ApplyFunction
Gets the iteration aggregator registered under the given name.
getIterationAggregator(String) - Method in class org.apache.flink.graph.gsa.GatherFunction
Gets the iteration aggregator registered under the given name.
getIterationAggregator(String) - Method in class org.apache.flink.graph.gsa.SumFunction
Gets the iteration aggregator registered under the given name.
getIterationAggregator(String) - Method in class org.apache.flink.graph.pregel.ComputeFunction
Gets the iteration aggregator registered under the given name.
getIterationAggregator(String) - Method in class org.apache.flink.graph.spargel.GatherFunction
Gets the iteration aggregator registered under the given name.
getIterationAggregator(String) - Method in class org.apache.flink.graph.spargel.ScatterFunction
Gets the iteration aggregator registered under the given name.
getIterationAggregators() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
getIterationAggregators(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getIterationConfiguration() - Method in class org.apache.flink.graph.gsa.GatherSumApplyIteration
 
getIterationConfiguration() - Method in class org.apache.flink.graph.pregel.VertexCentricIteration
 
getIterationConfiguration() - Method in class org.apache.flink.graph.spargel.ScatterGatherIteration
 
getIterationContract() - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
 
getIterationContract() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
 
getIterationHead() - Method in class org.apache.flink.api.java.operators.BulkIterationResultSet
 
getIterationHead() - Method in class org.apache.flink.api.java.operators.DeltaIterationResultSet
 
getIterationHeadFinalOutputConfig() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getIterationHeadIndexOfSyncOutput() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getIterationHeadPartialSolutionOrWorksetInputIndex() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getIterationHeadSolutionSetInputIndex() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getIterationId() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getIterationId() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getIterationNode() - Method in class org.apache.flink.optimizer.dag.AbstractPartialSolutionNode
 
getIterationNode() - Method in class org.apache.flink.optimizer.dag.BulkPartialSolutionNode
 
getIterationNode() - Method in class org.apache.flink.optimizer.dag.SolutionSetNode
 
getIterationNode() - Method in class org.apache.flink.optimizer.dag.WorksetNode
 
getIterationNode() - Method in class org.apache.flink.optimizer.plan.BulkIterationPlanNode
 
getIterationNode() - Method in interface org.apache.flink.optimizer.plan.IterationPlanNode
 
getIterationNode() - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
 
getIterationRuntimeContext() - Method in class org.apache.flink.api.common.functions.AbstractRichFunction
 
getIterationRuntimeContext() - Method in interface org.apache.flink.api.common.functions.RichFunction
Gets a specialized version of the RuntimeContext, which has additional information about the iteration in which the function is executed.
getIterationRuntimeContext() - Method in class org.apache.flink.streaming.api.scala.function.util.ScalaAllWindowFunctionWrapper
 
getIterationRuntimeContext() - Method in class org.apache.flink.streaming.api.scala.function.util.ScalaWindowFunctionWrapper
 
getIterationRuntimeContext() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
This method is used for approach (a) (see above)
getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
 
getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
 
getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
 
getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
 
getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
 
getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
 
getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
 
getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
 
getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
 
getIterationRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
 
getIterationSourceSinkPairs() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getIterationWaitTime() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getIterator() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
Gets an iterator over all records in this buffer in their logical order.
getIterator() - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
Gets an iterator over all records in this buffer in their logical order.
getIterator() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
Gets an iterator over all records in this buffer in their logical order.
getIterator() - Method in interface org.apache.flink.runtime.operators.sort.Sorter
 
getIterator() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
 
getIterator() - Method in class org.apache.flink.runtime.operators.TempBarrier
This method resets the input!
getIterator() - Method in interface org.apache.flink.runtime.operators.util.CloseableInputProvider
Gets the iterator over this input.
getIterator() - Method in class org.apache.flink.runtime.operators.util.SimpleCloseableInputProvider
 
getJaccardIndexScore() - Method in class org.apache.flink.graph.library.similarity.JaccardIndex.Result
Get the Jaccard Index score, equal to the number of shared neighbors of the source and target vertices divided by the number of distinct neighbors.
getJarFilePath() - Method in class org.apache.flink.client.cli.ProgramOptions
 
getJarFilePath() - Method in class org.apache.flink.client.cli.SavepointOptions
 
getJarFiles() - Method in class org.apache.flink.client.program.JobWithJars
Returns list of jar files that need to be submitted with the plan.
getJars() - Method in class org.apache.flink.client.program.ContextEnvironment
 
getJavaClass(RelDataType) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
getJavaEnv() - Method in class org.apache.flink.api.scala.ExecutionEnvironment
 
getJavaEnv() - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
 
getJdbcTableType() - Static method in class org.apache.flink.table.plan.schema.DataSetTable
 
getJdbcTableType() - Static method in class org.apache.flink.table.plan.schema.DataStreamTable
 
getJdbcTableType() - Method in class org.apache.flink.table.plan.schema.RelTable
 
getJdbcTableType() - Static method in class org.apache.flink.table.plan.schema.StreamTableSourceTable
 
getJdbcTableType() - Static method in class org.apache.flink.table.plan.schema.TableSourceTable
 
getJob() - Method in class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
 
getJobCheckpointingSettings() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns the JobCheckpointingSettings or null if checkpointing is disabled.
getJobCheckpointingSettings() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getJobCheckpointingSettings() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getJobClientActor() - Method in class org.apache.flink.runtime.client.JobListeningContext
 
getJobConf() - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
getJobConf() - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
 
getJobConf() - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopInputSplit
 
getJobConfiguration() - Method in interface org.apache.flink.runtime.execution.Environment
Returns the job-wide configuration object that was attached to the JobGraph.
getJobConfiguration() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getJobConfiguration() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
 
getJobConfiguration() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Returns the configuration object for this job.
getJobConfiguration() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
Returns the job configuration object which was attached to the original JobGraph.
getJobConfiguration() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getJobConfiguration() - Method in class org.apache.flink.runtime.taskmanager.Task
 
getJobExecutionResult() - Method in class org.apache.flink.api.common.JobSubmissionResult
Returns the JobExecutionResult if available.
getJobGraph(PackagedProgram, FlinkPlan, SavepointRestoreSettings) - Method in class org.apache.flink.client.program.ClusterClient
 
getJobGraph() - Method in class org.apache.flink.optimizer.plan.StreamingPlan
 
getJobGraph() - Method in class org.apache.flink.runtime.jobmanager.SubmittedJobGraph
Returns the submitted JobGraph.
getJobGraph() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
Gets the assembled JobGraph.
getJobGraphAndClassLoader(JarActionHandler.JarActionHandlerConfig) - Method in class org.apache.flink.runtime.webmonitor.handlers.JarActionHandler
 
getJobID() - Method in class org.apache.flink.api.common.JobSubmissionResult
Returns the JobID assigned to the job by the Flink runtime.
getJobId() - Method in class org.apache.flink.api.common.Plan
Gets the ID of the job that the dataflow plan belongs to.
getJobID() - Method in class org.apache.flink.client.program.DetachedEnvironment.DetachedJobExecutionResult
 
getJobID() - Method in class org.apache.flink.runtime.accumulators.AccumulatorSnapshot
 
getJobId() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
getJobId() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
getJobID() - Method in exception org.apache.flink.runtime.client.JobExecutionException
 
getJobID() - Method in class org.apache.flink.runtime.client.JobListeningContext
 
getJobId() - Method in class org.apache.flink.runtime.client.JobStatusMessage
 
getJobId() - Method in class org.apache.flink.runtime.client.SerializedJobExecutionResult
 
getJobID() - Method in interface org.apache.flink.runtime.execution.Environment
Returns the ID of the job that the task belongs to.
getJobID() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns the JobID for this execution graph.
getJobID() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getJobID() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getJobId() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getJobId() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getJobId() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
 
getJobID() - Method in class org.apache.flink.runtime.instance.Slot
Returns the ID of the job this allocated slot belongs to.
getJobId() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
 
getJobID() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Returns the ID of the job.
getJobID() - Method in class org.apache.flink.runtime.jobmanager.slots.AllocatedSlot
Returns the ID of the job this allocated slot belongs to.
getJobId() - Method in class org.apache.flink.runtime.jobmanager.SubmittedJobGraph
Returns the JobID of the submitted JobGraph.
getJobId() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
 
getJobId() - Method in class org.apache.flink.runtime.query.KvStateLocation
Returns the JobID the KvState instances belong to.
getJobId() - Method in class org.apache.flink.runtime.query.KvStateMessage.LookupKvStateLocation
Returns the JobID the KvState instance belongs to.
getJobId() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
Returns the JobID the KvState instance belongs to.
getJobId() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateUnregistered
Returns the JobID the KvState instance belongs to.
getJobID() - Method in class org.apache.flink.runtime.resourcemanager.registration.JobManagerRegistration
 
getJobId() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
getJobId() - Method in class org.apache.flink.runtime.resourcemanager.SlotRequest
Get the JobID of the slot requested for.
getJobID() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
getJobId() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
 
getJobID() - Method in class org.apache.flink.runtime.taskexecutor.SlotStatus
Get the job id of the slot allocated for
getJobID() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getJobID() - Method in class org.apache.flink.runtime.taskmanager.Task
 
getJobID() - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
The ID of the job the task belongs to
getJobIds() - Method in class org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
 
getJobIds() - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
Get all job ids of submitted job graphs to the submitted job graph store.
getJobIds() - Method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
 
getJobInfo() - Method in class org.apache.flink.runtime.jobmanager.SubmittedJobGraph
Returns the JobInfo of the client who submitted the JobGraph.
getJobLeaderIdService() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServices
 
getJobLeaderService() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
 
getJobManagerAddress() - Method in class org.apache.flink.client.cli.CommandLineOptions
 
getJobManagerAddress() - Method in class org.apache.flink.client.program.ClusterClient
Gets the current JobManager address (may change in case of a HA setup).
getJobManagerAddress(Configuration) - Static method in class org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils
Returns the JobManager's hostname and port extracted from the given Configuration.
getJobManagerAddress() - Method in class org.apache.flink.yarn.YarnClusterClientV2
 
getJobManagerAkkaConfig(int) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
getJobManagerBindAddress() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
getJobManagerClass() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosApplicationMasterRunner
 
getJobManagerClass() - Method in class org.apache.flink.yarn.YarnApplicationMasterRunner
 
getJobManagerFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
 
getJobManagerGateway(CommandLineOptions) - Method in class org.apache.flink.client.CliFrontend
Retrieves the ActorGateway for the JobManager.
getJobManagerGateway() - Method in class org.apache.flink.client.program.ClusterClient
Returns the ActorGateway of the current job manager leader using the LeaderRetrievalService.
getJobManagerGateway() - Method in class org.apache.flink.runtime.resourcemanager.registration.JobManagerRegistration
 
getJobManagerGateway() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
getJobManagerGatewayAndWebPort() - Method in class org.apache.flink.runtime.webmonitor.JobManagerRetriever
Returns the currently known leading job manager gateway and its web monitor port.
getJobManagerJobFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
 
getJobManagerLeaderElectionService(JobID) - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
Gets the leader election service for the given job.
getJobManagerLeaderElectionService(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
 
getJobManagerLeaderElectionService(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
 
getJobManagerLeaderElectionService(JobID) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
getJobManagerLeaderElectionService(JobID) - Method in class org.apache.flink.yarn.highavailability.YarnIntraNonHaMasterServices
 
getJobManagerLeaderElectionService(JobID) - Method in class org.apache.flink.yarn.highavailability.YarnPreConfiguredMasterNonHaServices
 
getJobManagerLeaderRetriever(JobID) - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
Gets the leader retriever for the job JobMaster which is responsible for the given job
getJobManagerLeaderRetriever(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
 
getJobManagerLeaderRetriever(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
 
getJobManagerLeaderRetriever(JobID) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
getJobManagerLeaderRetriever(JobID) - Method in class org.apache.flink.yarn.highavailability.YarnIntraNonHaMasterServices
 
getJobManagerLeaderRetriever(JobID) - Method in class org.apache.flink.yarn.highavailability.YarnPreConfiguredMasterNonHaServices
 
getJobManagerMetricStore() - Method in class org.apache.flink.runtime.webmonitor.metrics.MetricStore
getJobManagerMode() - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
 
getJobManagerName(int) - Method in class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
getJobManagerProps(Class<? extends JobManager>, Configuration, ScheduledExecutorService, Executor, InstanceManager, Scheduler, LibraryCacheManager, ActorRef, RestartStrategyFactory, FiniteDuration, LeaderElectionService, SubmittedJobGraphStore, CheckpointRecoveryFactory, FiniteDuration, Option<MetricRegistry>) - Method in class org.apache.flink.runtime.jobmanager.JobManager$
 
getJobManagerProps(Class<? extends JobManager>, Configuration, ScheduledExecutorService, Executor, InstanceManager, Scheduler, LibraryCacheManager, ActorRef, RestartStrategyFactory, FiniteDuration, LeaderElectionService, SubmittedJobGraphStore, CheckpointRecoveryFactory, FiniteDuration, Option<MetricRegistry>) - Static method in class org.apache.flink.runtime.jobmanager.JobManager
 
getJobManagerProps(Class<? extends JobManager>, Configuration, ScheduledExecutorService, Executor, InstanceManager, Scheduler, BlobLibraryCacheManager, ActorRef, RestartStrategyFactory, FiniteDuration, LeaderElectionService, SubmittedJobGraphStore, CheckpointRecoveryFactory, FiniteDuration, Option<MetricRegistry>) - Method in class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
getJobManagerResourceID() - Method in class org.apache.flink.runtime.resourcemanager.registration.JobManagerRegistration
 
getJobManagersAsJava() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
getJobManagerStatusAlive() - Method in class org.apache.flink.runtime.messages.JobManagerMessages$
 
getJobManagerStatusAlive() - Static method in class org.apache.flink.runtime.messages.JobManagerMessages
 
getJobManagerTable() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
 
getJobMetricStore(String) - Method in class org.apache.flink.runtime.webmonitor.metrics.MetricStore
Returns the MetricStore.JobMetricStore for the given job ID.
getJobName() - Method in class org.apache.flink.api.common.Plan
Gets the name of this job.
getJobName() - Method in class org.apache.flink.optimizer.plan.OptimizedPlan
Returns the name of the program.
getJobName() - Method in class org.apache.flink.runtime.client.JobStatusMessage
 
getJobName() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns the job name for thie execution graph.
getJobName() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getJobName() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getJobName() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
 
getJobName() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
 
getJobName() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getJobParameter(String, String) - Method in class org.apache.flink.table.functions.FunctionContext
Gets the global job parameter value associated with the given key as a string.
getJobResultFuture() - Method in class org.apache.flink.runtime.client.JobListeningContext
 
getJobsCancelled() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsWithIDsOverview
 
getJobSchedulingStatus(JobID) - Method in class org.apache.flink.runtime.highavailability.FsNegativeRunningJobsRegistry
 
getJobSchedulingStatus(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneRunningJobsRegistry
 
getJobSchedulingStatus(JobID) - Method in interface org.apache.flink.runtime.highavailability.RunningJobsRegistry
Gets the scheduling status of a job.
getJobSchedulingStatus(JobID) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperRunningJobsRegistry
 
getJobsFailed() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsWithIDsOverview
 
getJobsFinished() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsWithIDsOverview
 
getJobsRunningOrPending() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsWithIDsOverview
 
getJobState() - Method in class org.apache.flink.runtime.client.JobStatusMessage
 
getJobTimeout() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServicesConfiguration
 
getJobVertex(JobVertexID) - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns the job vertex for the given JobVertexID.
getJobVertex(JobVertexID) - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getJobVertex(JobVertexID) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getJobVertex() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getJobVertex() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getJobVertexClass() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getJobVertexID() - Method in class org.apache.flink.migration.runtime.checkpoint.TaskState
Deprecated.
 
getJobVertexID() - Method in class org.apache.flink.runtime.checkpoint.TaskState
Deprecated.
 
getJobVertexId() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
Returns the ID of the operator the statistics belong to.
getJobVertexId() - Method in interface org.apache.flink.runtime.execution.Environment
Gets the ID of the JobVertex for which this task executes a parallel subtask.
getJobVertexId() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
Returns the JobVertexID for this job vertex.
getJobVertexId() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
 
getJobVertexId() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getJobvertexId() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getJobVertexId() - Method in class org.apache.flink.runtime.executiongraph.TaskInformation
 
getJobVertexId() - Method in class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
 
getJobVertexId() - Method in class org.apache.flink.runtime.query.KvStateLocation
Returns the JobVertexID the KvState instances belong to.
getJobVertexId() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
Returns the JobVertexID the KvState instance belongs to
getJobVertexId() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateUnregistered
Returns the JobVertexID the KvState instance belongs to
getJobVertexId() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getJobVertexId() - Method in class org.apache.flink.runtime.taskmanager.Task
 
getJobVertexIds() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
 
getJoinedPathsVector() - Method in class org.apache.flink.optimizer.dag.OptimizerNode.UnclosedBranchDescriptor
 
getJoinHint() - Method in class org.apache.flink.api.common.operators.base.JoinOperatorBase
 
getJoinHint() - Method in class org.apache.flink.api.java.operators.JoinOperator
Gets the JoinHint that describes how the join is executed.
getJoinReturnTypes(JoinFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getJoinReturnTypes(JoinFunction<IN1, IN2, OUT>, TypeInformation<IN1>, TypeInformation<IN2>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getJoinType() - Method in class org.apache.flink.api.java.operators.JoinOperator
Gets the JoinType that describes this join operation (e.g.
getJoinType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
getJoinType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
getJson() - Method in class org.apache.flink.runtime.webmonitor.history.ArchivedJson
 
getJSON() - Method in class org.apache.flink.streaming.api.graph.JSONGenerator
 
getJsonArchivists() - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorUtils
 
getJsonArchivists() - Static method in class org.apache.flink.runtime.webmonitor.WebRuntimeMonitor
Returns an array of all JsonArchivists that are relevant for the history server.
getJsonPlan() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns the job plan as a JSON string.
getJsonPlan() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getJsonPlan() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getJvmStartupOptions() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
Gets the system parameters and environment parameters that were passed to the JVM on startup.
getJvmStartupOptionsArray() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
Gets the system parameters and environment parameters that were passed to the JVM on startup.
getJvmVersion() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
Gets the version of the JVM in the form "VM_Name - Vendor - Spec/Version".
getKafkaPartitionHandle() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionState
Gets Kafka's descriptor for the Kafka Partition.
getKafkaPartitions(List<String>) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer08
 
getKafkaPartitions(List<String>) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
 
getKafkaPartitions(List<String>) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
 
getKafkaProducer(Properties) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
Used for testing only
getKafkaTopicPartition() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionState
Gets Flink's descriptor for the Kafka Partition.
getKey(IN) - Method in interface org.apache.flink.api.java.functions.KeySelector
User-defined function that deterministically extracts the key from an object.
getKey(T) - Method in class org.apache.flink.api.java.functions.NullByteKeySelector
 
getKey() - Method in interface org.apache.flink.runtime.state.heap.StateEntry
Returns the key of this entry.
getKey() - Method in class org.apache.flink.streaming.api.operators.InternalTimer
 
getKey(IN) - Method in class org.apache.flink.streaming.api.scala.KeySelectorWithType
 
getKey() - Method in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter.AvroKeyValue
 
getKey(Type) - Method in class org.apache.flink.streaming.examples.windowing.GroupedProcessingTimeWindowExample.FirstFieldKeyExtractor
 
getKey() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap.Entry
 
getKey(IN) - Method in class org.apache.flink.streaming.util.keys.KeySelectorUtil.ArrayKeySelector
 
getKey(IN) - Method in class org.apache.flink.streaming.util.keys.KeySelectorUtil.ComparableKeySelector
 
getKey(IN) - Method in class org.apache.flink.streaming.util.keys.KeySelectorUtil.OneKeySelector
 
getKeyColumns(int) - Method in class org.apache.flink.api.common.operators.AbstractUdfOperator
Gets the column numbers of the key fields in the input records for the given input.
getKeyColumns(int) - Method in class org.apache.flink.api.common.operators.DualInputOperator
 
getKeyColumns(int) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
 
getKeyedStateBackend() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getKeyedStateHandles(Collection<? extends KeyedStateHandle>, KeyGroupRange) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
Determine the subset of KeyGroupsStateHandles with correct key group index for the given subtask KeyGroupRange.
getKeyedStateManagedFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotResult
 
getKeyedStateRawFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotResult
 
getKeyedStateStore() - Method in interface org.apache.flink.runtime.state.ManagedInitializationContext
Returns an interface that allows for registering keyed state with the backend.
getKeyedStateStore() - Method in class org.apache.flink.runtime.state.StateInitializationContextImpl
 
getKeyedStateStore() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getKeyedStateStreamFuture() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
 
getKeyExtractor() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
getKeyFields() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
getKeyFieldTypes() - Method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
getKeyFieldTypes() - Method in class org.apache.flink.api.common.operators.Keys
 
getKeyFieldTypes() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
getKeyGroupId(int) - Method in class org.apache.flink.runtime.state.KeyGroupRange
 
getKeyGroupId(int) - Method in interface org.apache.flink.runtime.state.KeyGroupsList
Returns the id of the keygroup at the given index, where index in interval [0, KeyGroupsList.getNumberOfKeyGroups()[.
getKeyGroupId() - Method in class org.apache.flink.runtime.state.KeyGroupStatePartitionStreamProvider
Returns the key group that corresponds to the data in the provided stream.
getKeyGroupList() - Method in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
Returns a list of all key-groups which can be written to this stream.
getKeyGroupOffset(int) - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
Returns the offset for the given key-group.
getKeyGroupPrefixBytes() - Method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
 
getKeyGroupRange() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
Returns the key group index the KvState instance belongs to.
getKeyGroupRange() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateUnregistered
Returns the key group index the KvState instance belongs to.
getKeyGroupRange() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
getKeyGroupRange() - Method in interface org.apache.flink.runtime.state.heap.InternalKeyContext
Returns the key groups for this backend.
getKeyGroupRange() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
 
getKeyGroupRange() - Method in interface org.apache.flink.runtime.state.KeyedStateHandle
Returns the range of the key groups contained in the state.
getKeyGroupRange() - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
 
getKeyGroupRange() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
 
getKeyGroupsStateHandles() - Method in class org.apache.flink.runtime.state.StateInitializationContextImpl
 
getKeyGroupState() - Method in class org.apache.flink.migration.runtime.checkpoint.KeyGroupState
Deprecated.
 
getKeyPositions() - Method in class org.apache.flink.api.java.operators.DeltaIterationResultSet
 
getKeyPositions() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
getKeys() - Method in class org.apache.flink.api.java.operators.Grouping
 
getKeys(int) - Method in class org.apache.flink.optimizer.plan.SingleInputPlanNode
Gets the key field indexes for the specified driver comparator.
getKeys1() - Method in class org.apache.flink.api.java.operators.CoGroupOperator
 
getKeys1() - Method in class org.apache.flink.api.java.operators.CoGroupRawOperator
 
getKeys1() - Method in class org.apache.flink.api.java.operators.JoinOperator
 
getKeys2() - Method in class org.apache.flink.api.java.operators.CoGroupOperator
 
getKeys2() - Method in class org.apache.flink.api.java.operators.CoGroupRawOperator
 
getKeys2() - Method in class org.apache.flink.api.java.operators.JoinOperator
 
getKeySelector() - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Gets the key selector that can get the key by which the stream if partitioned from the elements.
getKeySelector() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
getKeySelectorTypes(KeySelector<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getKeySelectorTypes(KeySelector<IN, OUT>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getKeySerializer() - Method in class org.apache.flink.api.common.state.MapStateDescriptor
Gets the serializer for the keys in the state.
getKeySerializer() - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
getKeySerializer() - Method in class org.apache.flink.migration.runtime.state.filesystem.AbstractFsStateSnapshot
Deprecated.
 
getKeySerializer() - Method in class org.apache.flink.migration.runtime.state.memory.AbstractMemStateSnapshot
Deprecated.
 
getKeySerializer() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
getKeySerializer() - Method in class org.apache.flink.runtime.state.HashMapSerializer
 
getKeySerializer() - Method in interface org.apache.flink.runtime.state.heap.InternalKeyContext
TypeSerializer for the state backend key type.
getKeySerializer() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
 
getKeySerializer() - Method in class org.apache.flink.streaming.api.datastream.QueryableStateStream
Returns the key serializer for the queryable state instance.
getKeySerializerConfigSnapshot() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
 
getKeysForInput1() - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
 
getKeysForInput2() - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
 
getKeyString() - Method in class org.apache.flink.util.StringBasedID
 
getKeytab() - Method in class org.apache.flink.runtime.security.SecurityUtils.SecurityConfiguration
 
getKeytab() - Method in class org.apache.flink.test.util.TestingSecurityContext.ClientSecurityConfiguration
 
getKeyType() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
getKeyType() - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Gets the type of the key by which the stream is partitioned.
getKeyType() - Method in class org.apache.flink.streaming.api.scala.KeyedStream
Gets the type of the key by which this stream is keyed.
getKeyType() - Static method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
getKeyTypeInfo() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
Gets the type information for the keys in the map
getKeyTypes() - Method in interface org.apache.flink.api.common.distributions.DataDistribution
Gets the type of the key by which the dataSet is partitioned.
getKeyValueState(String, Class<S>, S) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
getKeyValueState(String, TypeInformation<S>, S) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
getKeyValueState(String, Class<S>, S) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
getKeyValueState(String, TypeInformation<S>, S) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
getKibiBytes() - Method in class org.apache.flink.configuration.MemorySize
Gets the memory size in Kibibytes (= 1024 bytes).
getKind() - Method in class org.apache.flink.core.fs.FileSystem
Gets a description of the characteristics of this file system.
getKind() - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
getKind() - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
getKind() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
 
getKind() - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
 
getKind() - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
getKind() - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
getKind() - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
getKind() - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
getKryo() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
getKryoRegistrations() - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot
 
getKvState(int) - Method in class org.apache.flink.migration.runtime.checkpoint.TaskState
Deprecated.
 
getKvState(KvStateID) - Method in class org.apache.flink.runtime.query.KvStateRegistry
Returns the KvState instance identified by the given KvStateID or null if none is registered.
getKvState(KvStateServerAddress, KvStateID, byte[]) - Method in class org.apache.flink.runtime.query.netty.KvStateClient
Returns a future holding the serialized request result.
getKvState(JobID, String, int, byte[]) - Method in class org.apache.flink.runtime.query.QueryableStateClient
Returns a future holding the serialized request result.
getKvStateID(int) - Method in class org.apache.flink.runtime.query.KvStateLocation
Returns the registered KvStateID for the key group index or null if none is registered yet.
getKvStateId() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
Returns the ID of the registered KvState instance.
getKvStateId() - Method in class org.apache.flink.runtime.query.netty.message.KvStateRequest
Returns the ID of the requested KvState instance.
getKvStateLocation(String) - Method in class org.apache.flink.runtime.query.KvStateLocationRegistry
Returns the KvStateLocation for the registered KvState instance or null if no location information is available.
getKvStateLocationRegistry() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getKvStateLookupInfo(JobID, String) - Method in interface org.apache.flink.runtime.query.KvStateLocationLookupService
Returns a future holding the KvStateLocation for the given job and KvState registration name.
getKvStateRegistry() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
getKvStates() - Method in class org.apache.flink.migration.streaming.runtime.tasks.StreamTaskState
Deprecated.
 
getKvStateServer() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
getKvStateServerAddress(int) - Method in class org.apache.flink.runtime.query.KvStateLocation
Returns the registered KvStateServerAddress for the key group index or null if none is registered yet.
getKvStateServerAddress() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
Returns the server address where to find the KvState instance.
getLang() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
getLang() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getLast() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
Returns the last checkpoint ID (current - 10.
getLastEnvCreated() - Method in class org.apache.flink.client.program.ContextEnvironmentFactory
 
getLastGroupKey() - Method in class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
 
getLastHeartBeat() - Method in class org.apache.flink.runtime.instance.Instance
Gets the timestamp of the last heartbeat.
getLastJobExecutionResult() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Returns the JobExecutionResult of the last executed job.
getLastJobExecutionResult() - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Gets the JobExecutionResult of the last executed job.
getLastJobExecutionResult() - Method in class org.apache.flink.test.util.CollectionTestEnvironment
 
getLastJobExecutionResult() - Method in class org.apache.flink.test.util.TestEnvironment
 
getLastKey() - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
 
getLastModificationTime() - Method in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
Gets the timestamp of the last modification.
getLastOffset() - Method in class org.apache.flink.graph.generator.CirculantGraph.OffsetRange
Get the offset of the last index in the range
getLastOutputCollector() - Method in class org.apache.flink.runtime.operators.BatchTask
 
getLastResult() - Method in class org.apache.flink.types.parser.BigDecParser
 
getLastResult() - Method in class org.apache.flink.types.parser.BigIntParser
 
getLastResult() - Method in class org.apache.flink.types.parser.BooleanParser
 
getLastResult() - Method in class org.apache.flink.types.parser.BooleanValueParser
 
getLastResult() - Method in class org.apache.flink.types.parser.ByteParser
 
getLastResult() - Method in class org.apache.flink.types.parser.ByteValueParser
 
getLastResult() - Method in class org.apache.flink.types.parser.DoubleParser
 
getLastResult() - Method in class org.apache.flink.types.parser.DoubleValueParser
 
getLastResult() - Method in class org.apache.flink.types.parser.FieldParser
Gets the parsed field.
getLastResult() - Method in class org.apache.flink.types.parser.FloatParser
 
getLastResult() - Method in class org.apache.flink.types.parser.FloatValueParser
 
getLastResult() - Method in class org.apache.flink.types.parser.IntParser
 
getLastResult() - Method in class org.apache.flink.types.parser.IntValueParser
 
getLastResult() - Method in class org.apache.flink.types.parser.LongParser
 
getLastResult() - Method in class org.apache.flink.types.parser.LongValueParser
 
getLastResult() - Method in class org.apache.flink.types.parser.ShortParser
 
getLastResult() - Method in class org.apache.flink.types.parser.ShortValueParser
 
getLastResult() - Method in class org.apache.flink.types.parser.SqlDateParser
 
getLastResult() - Method in class org.apache.flink.types.parser.SqlTimeParser
 
getLastResult() - Method in class org.apache.flink.types.parser.SqlTimestampParser
 
getLastResult() - Method in class org.apache.flink.types.parser.StringParser
 
getLastResult() - Method in class org.apache.flink.types.parser.StringValueParser
 
getLastSortKey() - Method in class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
 
getLastTasksConfig() - Method in class org.apache.flink.runtime.operators.BatchTask
 
getLastUpdateTime() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
 
getLatencyTrackingInterval() - Method in class org.apache.flink.api.common.ExecutionConfig
Returns the latency tracking interval.
getLatestAcknowledgedSubtaskStats() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
Returns the latest acknowledged subtask stats or null if none was acknowledged yet.
getLatestAcknowledgedSubtaskStats() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
 
getLatestAcknowledgedSubtaskStats() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
 
getLatestAcknowledgedSubtaskStats() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpointStats
 
getLatestAcknowledgedSubtaskStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
Returns the latest acknowledged subtask stats or null if none was acknowledged yet.
getLatestAckTimestamp() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
Returns the ack timestamp of the latest acknowledged subtask or -1 if none was acknowledged yet.
getLatestAckTimestamp() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
Returns the ack timestamp of the latest acknowledged subtask or -1 if none was acknowledged yet.
getLatestCheckpoint() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
Returns the latest CompletedCheckpoint instance or null if none was added.
getLatestCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
 
getLatestCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
 
getLatestCompletedCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
 
getLatestExecutionResult() - Method in class org.apache.flink.test.util.JavaProgramTestBase
 
getLatestFailedCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
 
getLatestPriorLocation() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
Gets the location where the latest completed/canceled/failed execution of the vertex's task happened.
getLatestRestoredCheckpoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsSnapshot
Returns the latest restored checkpoint.
getLatestSavepoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsHistory
 
getLeader() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionLeader
 
getLeaderConnectionInfoFuture() - Method in class org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderConnectionInfoListener
 
getLeaderGateway(FiniteDuration) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
getLeaderGatewayFuture() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
getLeaderId(JobID) - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
 
getLeaderID() - Method in class org.apache.flink.runtime.resourcemanager.registration.JobManagerRegistration
 
getLeaderID() - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerServices
Gets the current leader id assigned at the ResourceManager.
getLeaderId() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
getLeaderIndex(FiniteDuration) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
getLeaderIndexFuture() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
getLeaderRPCPort() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
getLeaderSessionID() - Method in class org.apache.flink.runtime.akka.FlinkUntypedActor
Returns the current leader session ID associcated with this actor.
getLeaderSessionID() - Method in class org.apache.flink.runtime.client.JobClientActor
 
getLeaderSessionID() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
 
getLeaderSessionID() - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
Returns the current leader session ID or null, if the contender is not the leader.
getLeaderSessionID() - Method in class org.apache.flink.runtime.util.LeaderConnectionInfo
 
getLeft() - Method in class org.apache.flink.cep.pattern.AndFilterFunction
Deprecated.
 
getLeft() - Method in class org.apache.flink.cep.pattern.conditions.AndCondition
 
getLeft() - Method in class org.apache.flink.cep.pattern.conditions.OrCondition
 
getLeft() - Method in class org.apache.flink.cep.pattern.OrFilterFunction
Deprecated.
 
getLeft() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
getLeft() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
getLeftPrec() - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
getLeftPrec() - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
getLeftPrec() - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
getLeftPrec() - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
getLeftType() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
 
getLegacyOperatorState() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
Deprecated.
Non-repartitionable operator state that has been deprecated. Can be removed when we remove the APIs for non-repartitionable operator state.
getLegacyOperatorState() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
Deprecated.
Non-repartitionable operator state that has been deprecated. Can be removed when we remove the APIs for non-repartitionable operator state.
getLegacyOperatorState() - Method in class org.apache.flink.runtime.state.TaskStateHandles
Deprecated.
Non-repartitionable operator state that has been deprecated. Can be removed when we remove the APIs for non-repartitionable operator state.
getLegacyOperatorState() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorStateHandles
 
getLen() - Method in interface org.apache.flink.core.fs.FileStatus
Return the length of this file
getLen() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
 
getLen() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
getLength() - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
 
getLength() - Method in interface org.apache.flink.api.common.typeutils.TypeDeserializer
Gets the length of the data type, if it is a fix length data type.
getLength() - Method in class org.apache.flink.api.common.typeutils.TypeDeserializerAdapter
 
getLength() - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
Gets the length of the data type, if it is a fix length data type.
getLength() - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
 
getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
getLength() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
 
getLength() - Method in class org.apache.flink.api.scala.typeutils.EitherSerializer
 
getLength() - Method in class org.apache.flink.api.scala.typeutils.EnumValueSerializer
 
getLength() - Method in class org.apache.flink.api.scala.typeutils.NothingSerializer
 
getLength() - Method in class org.apache.flink.api.scala.typeutils.OptionSerializer
 
getLength() - Method in class org.apache.flink.api.scala.typeutils.TraversableSerializer
 
getLength() - Method in class org.apache.flink.api.scala.typeutils.TrySerializer
 
getLength() - Method in class org.apache.flink.api.scala.typeutils.UnitSerializer
 
getLength() - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
 
getLength() - Method in class org.apache.flink.cep.nfa.NFA.NFASerializer
 
getLength() - Method in class org.apache.flink.cep.nfa.NFA.Serializer
 
getLength() - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
 
getLength() - Method in class org.apache.flink.cep.NonDuplicatingTypeSerializer
 
getLength() - Method in interface org.apache.flink.core.fs.BlockLocation
Get the length of the block.
getLength() - Method in class org.apache.flink.core.fs.FileInputSplit
Returns the number of bytes in the file to process.
getLength() - Method in class org.apache.flink.core.fs.local.LocalBlockLocation
 
getLength() - Method in class org.apache.flink.graph.generator.CirculantGraph.OffsetRange
Get the range length
getLength() - Method in class org.apache.flink.graph.types.valuearray.IntValueArraySerializer
 
getLength() - Method in class org.apache.flink.graph.types.valuearray.LongValueArraySerializer
 
getLength() - Method in class org.apache.flink.graph.types.valuearray.NullValueArraySerializer
 
getLength() - Method in class org.apache.flink.graph.types.valuearray.StringValueArraySerializer
 
getLength() - Method in class org.apache.flink.migration.MigrationNamespaceSerializerProxy
Deprecated.
 
getLength() - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer
 
getLength() - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.StreamRecordSerializer
 
getLength() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopBlockLocation
 
getLength() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileSegment
 
getLength() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
getLength() - Method in class org.apache.flink.runtime.state.ChainedStateHandle
Returns the length of the operator chain.
getLength() - Method in class org.apache.flink.runtime.state.HashMapSerializer
 
getLength() - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
 
getLength() - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
 
getLength() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
 
getLength() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
getLength() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
getLength() - Method in class org.apache.flink.table.runtime.types.CRowSerializer
 
getLibraryCacheManager() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
getLimitForSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.FileChannelInputView
 
getLimitForSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
 
getLimitForSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.iomanager.HeaderlessChannelReaderInputView
 
getLimitForSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.RandomAccessInputView
 
getLimitForSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
 
getLimitForSegment(MemorySegment) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
Gets the limit for reading bytes from the given memory segment.
getLimitForSegment(MemorySegment) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
 
getLineLengthLimit() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
getListed_count() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getListOfInputs() - Method in class org.apache.flink.optimizer.plan.NAryUnionPlanNode
 
getListOfTriangles() - Static method in class org.apache.flink.graph.examples.data.TriangleCountData
 
getListState(ListStateDescriptor<T>) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Gets a handle to the system's key/value list state.
getListState(ListStateDescriptor<T>) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getListState(ListStateDescriptor<T>) - Method in interface org.apache.flink.api.common.state.KeyedStateStore
Gets a handle to the system's key/value list state.
getListState(ListStateDescriptor<S>) - Method in interface org.apache.flink.api.common.state.OperatorStateStore
Creates (or restores) a list state.
getListState(ListStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
 
getListState(ListStateDescriptor<S>) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
 
getListState(ListStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
getListState(ListStateDescriptor<T>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
 
getListState(ListStateDescriptor<T>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.PerWindowStateStore
 
getLocal_properties() - Method in class org.apache.flink.table.explain.Node
 
getLocalAkkaURL(String) - Method in class org.apache.flink.runtime.akka.AkkaUtils$
Returns the local akka url for the given actor name.
getLocalAkkaURL(String) - Static method in class org.apache.flink.runtime.akka.AkkaUtils
Returns the local akka url for the given actor name.
getLocalCluster() - Static method in class org.apache.flink.storm.api.FlinkLocalCluster
Returns a FlinkLocalCluster that should be used for execution.
getLocalClusteringCoefficientScore() - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient.Result
Get the local clustering coefficient score.
getLocalClusteringCoefficientScore() - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient.Result
Get the local clustering coefficient score.
getLocalFileSystem() - Static method in class org.apache.flink.core.fs.FileSystem
Returns a reference to the FileSystem instance for accessing the local file system.
getLocalGetYarnMessage() - Method in class org.apache.flink.yarn.YarnMessages$
 
getLocalGetYarnMessage() - Static method in class org.apache.flink.yarn.YarnMessages
 
getLocality() - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Attributes
 
getLocality() - Method in class org.apache.flink.runtime.instance.SimpleSlot
Gets the locality information attached to this slot.
getLocalizedMessage() - Static method in exception org.apache.flink.table.api.AmbiguousTableSourceConverterException
 
getLocalizedMessage() - Static method in exception org.apache.flink.table.api.CatalogAlreadyExistException
 
getLocalizedMessage() - Static method in exception org.apache.flink.table.api.CatalogNotExistException
 
getLocalizedMessage() - Static method in exception org.apache.flink.table.api.ExpressionParserException
 
getLocalizedMessage() - Static method in exception org.apache.flink.table.api.ExternalCatalogAlreadyExistException
 
getLocalizedMessage() - Static method in exception org.apache.flink.table.api.ExternalCatalogNotExistException
 
getLocalizedMessage() - Static method in exception org.apache.flink.table.api.NoMatchedTableSourceConverterException
 
getLocalizedMessage() - Static method in exception org.apache.flink.table.api.SqlParserException
 
getLocalizedMessage() - Static method in exception org.apache.flink.table.api.TableAlreadyExistException
 
getLocalizedMessage() - Static method in exception org.apache.flink.table.api.TableException
 
getLocalizedMessage() - Static method in exception org.apache.flink.table.api.TableNotExistException
 
getLocalizedMessage() - Static method in exception org.apache.flink.table.api.UnresolvedException
 
getLocalizedMessage() - Static method in exception org.apache.flink.table.api.ValidationException
 
getLocalKeyGroupRangeStartIdx() - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
 
getLocalOrder() - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
Gets the order, in which the data sink writes its data locally.
getLocalProperties() - Method in class org.apache.flink.optimizer.dataproperties.InterestingProperties
Gets the interesting local properties.
getLocalProperties() - Method in class org.apache.flink.optimizer.plan.Channel
 
getLocalProperties() - Method in class org.apache.flink.optimizer.plan.PlanNode
Gets the local properties from this PlanNode.
getLocalStrategy() - Method in class org.apache.flink.optimizer.plan.Channel
 
getLocalStrategyComparator() - Method in class org.apache.flink.optimizer.plan.Channel
Gets the local strategy comparator from this Channel.
getLocalStrategyKeys() - Method in class org.apache.flink.optimizer.plan.Channel
 
getLocalStrategySortOrder() - Method in class org.apache.flink.optimizer.plan.Channel
 
getLocalStrategyString(LocalStrategy) - Static method in class org.apache.flink.optimizer.plantranslate.JsonMapper
 
getLocalValue() - Method in interface org.apache.flink.api.common.accumulators.Accumulator
 
getLocalValue() - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
 
getLocalValue() - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
 
getLocalValue() - Method in class org.apache.flink.api.common.accumulators.DoubleMaximum
 
getLocalValue() - Method in class org.apache.flink.api.common.accumulators.DoubleMinimum
 
getLocalValue() - Method in class org.apache.flink.api.common.accumulators.Histogram
 
getLocalValue() - Method in class org.apache.flink.api.common.accumulators.IntCounter
 
getLocalValue() - Method in class org.apache.flink.api.common.accumulators.IntMaximum
 
getLocalValue() - Method in class org.apache.flink.api.common.accumulators.IntMinimum
 
getLocalValue() - Method in class org.apache.flink.api.common.accumulators.ListAccumulator
 
getLocalValue() - Method in class org.apache.flink.api.common.accumulators.LongCounter
 
getLocalValue() - Method in class org.apache.flink.api.common.accumulators.LongMaximum
 
getLocalValue() - Method in class org.apache.flink.api.common.accumulators.LongMinimum
 
getLocalValue() - Method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
getLocalValue() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
 
getLocalValue() - Method in class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator.VectorAccumulator
 
getLocalValue() - Method in class org.apache.flink.graph.asm.dataset.ChecksumHashCode.Checksum
 
getLocalValuePrimitive() - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
 
getLocalValuePrimitive() - Method in class org.apache.flink.api.common.accumulators.DoubleMaximum
 
getLocalValuePrimitive() - Method in class org.apache.flink.api.common.accumulators.DoubleMinimum
 
getLocalValuePrimitive() - Method in class org.apache.flink.api.common.accumulators.IntCounter
 
getLocalValuePrimitive() - Method in class org.apache.flink.api.common.accumulators.IntMaximum
 
getLocalValuePrimitive() - Method in class org.apache.flink.api.common.accumulators.IntMinimum
 
getLocalValuePrimitive() - Method in class org.apache.flink.api.common.accumulators.LongCounter
 
getLocalValuePrimitive() - Method in class org.apache.flink.api.common.accumulators.LongMaximum
 
getLocalValuePrimitive() - Method in class org.apache.flink.api.common.accumulators.LongMinimum
 
getLocation() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getLocation() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
Gets the location assigned to this slot.
getLocationConstraint() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getLocationConstraint(int) - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
 
getLocationConstraint() - Method in class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
 
getLockPath(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Returns the path for the lock node relative to the given path.
getLog2TableCapacity() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
Gets the base-2 logarithm of the hash table capacity, as returned by KeyMap.getCurrentTableCapacity().
getLogicalOptRuleSet() - Method in class org.apache.flink.table.api.TableEnvironment
Returns the logical optimization rule set for this environment including a custom RuleSet configuration.
getLogicalOptRuleSet() - Method in interface org.apache.flink.table.calcite.CalciteConfig
Returns a custom logical optimization rule set.
getLogicalScope(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
Returns the logical scope of this group, for example "taskmanager.job.task"
getLogicalScope(CharacterFilter, char) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
Returns the logical scope of this group, for example "taskmanager.job.task"
getLogicalScope(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
 
getLogicalScope(CharacterFilter, char) - Method in class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
 
getLogicalSourceRowType(RelDataType, SqlInsert) - Method in class org.apache.flink.table.calcite.FlinkCalciteSqlValidator
 
getLogicalTargetRowType(RelDataType, SqlInsert) - Method in class org.apache.flink.table.calcite.FlinkCalciteSqlValidator
 
getLoginContextNames() - Method in class org.apache.flink.runtime.security.SecurityUtils.SecurityConfiguration
 
getLogLevel() - Method in class org.apache.flink.runtime.akka.AkkaUtils$
 
getLogLevel() - Static method in class org.apache.flink.runtime.akka.AkkaUtils
 
getLong(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the Long value for the given key.
getLong(String, long) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the Long value for the given key.
getLong(String, long) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given key as a long.
getLong(ConfigOption<Long>) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as a long integer.
getLong(String, long) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getLong(ConfigOption<Long>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getLong(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads a long value (64bit, 8 bytes) from the given position, in the system's native byte order.
getLong(String, long) - Method in class org.apache.flink.metrics.MetricConfig
Searches for the property with the specified key in this property list.
getLong(int) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getLong(Properties, String, long) - Static method in class org.apache.flink.util.PropertiesUtil
Get long from properties.
getLong(Properties, String, long, Logger) - Static method in class org.apache.flink.util.PropertiesUtil
Get long from properties.
getLongBigEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads a long integer value (64bit, 8 bytes) from the given position, in big endian byte order.
getLongByField(String) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getLongCounter(String) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Convenience function to create a counter object for longs.
getLongCounter(String) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getLongDescription() - Method in class org.apache.flink.graph.drivers.AdamicAdar
 
getLongDescription() - Method in class org.apache.flink.graph.drivers.ClusteringCoefficient
 
getLongDescription() - Method in class org.apache.flink.graph.drivers.ConnectedComponents
 
getLongDescription() - Method in interface org.apache.flink.graph.drivers.Driver
A multi-line description, presented in the algorithm usage.
getLongDescription() - Method in class org.apache.flink.graph.drivers.EdgeList
 
getLongDescription() - Method in class org.apache.flink.graph.drivers.GraphMetrics
 
getLongDescription() - Method in class org.apache.flink.graph.drivers.HITS
 
getLongDescription() - Method in class org.apache.flink.graph.drivers.JaccardIndex
 
getLongDescription() - Method in class org.apache.flink.graph.drivers.PageRank
 
getLongDescription() - Method in class org.apache.flink.graph.drivers.TriangleListing
 
getLongLittleEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads a long integer value (64bit, 8 bytes) from the given position, in little endian byte order.
getLookupTimeout(Configuration) - Method in class org.apache.flink.runtime.akka.AkkaUtils$
 
getLookupTimeout(Configuration) - Static method in class org.apache.flink.runtime.akka.AkkaUtils
 
getLoopTimeout(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getLowerBoundary(Window, Window.Group, RelNode) - Method in interface org.apache.flink.table.plan.nodes.OverAggregate
 
getLowerPart() - Method in class org.apache.flink.util.AbstractID
Gets the lower 64 bits of the ID.
getLRU() - Method in class org.apache.flink.runtime.util.LRUCache
 
getLRU() - Method in class org.apache.flink.runtime.util.LRUCacheMap
 
getMainClassName() - Method in class org.apache.flink.client.program.PackagedProgram
 
getMainThreadExecutor() - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerServices
Gets the executor which executes in the main thread of the ResourceManager
getMainThreadExecutor() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
Gets the main thread execution context.
getManagedKeyedState() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
 
getManagedKeyedState() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
 
getManagedKeyedState() - Method in class org.apache.flink.runtime.state.TaskStateHandles
 
getManagedKeyedState() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorStateHandles
 
getManagedKeyedStateHandles(OperatorState, KeyGroupRange) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
Collect managedKeyedStateHandles which have intersection with given KeyGroupRange from operatorState
getManagedMemoryPerTaskManager() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
getManagedOperatorState() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
 
getManagedOperatorState() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
 
getManagedOperatorState() - Method in class org.apache.flink.runtime.state.TaskStateHandles
 
getManagedOperatorState() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorStateHandles
 
getMapConvertedNonCorrSubqs() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
 
getMapFor(Map<String, String>, MetricStore) - Method in class org.apache.flink.runtime.webmonitor.metrics.AbstractMetricsHandler
Returns a Map containing the metrics belonging to the entity pointed to by the path parameters.
getMapFor(Map<String, String>, MetricStore) - Method in class org.apache.flink.runtime.webmonitor.metrics.JobManagerMetricsHandler
 
getMapFor(Map<String, String>, MetricStore) - Method in class org.apache.flink.runtime.webmonitor.metrics.JobMetricsHandler
 
getMapFor(Map<String, String>, MetricStore) - Method in class org.apache.flink.runtime.webmonitor.metrics.JobVertexMetricsHandler
 
getMapFor(Map<String, String>, MetricStore) - Method in class org.apache.flink.runtime.webmonitor.metrics.TaskManagerMetricsHandler
 
getMapPartitionReturnTypes(MapPartitionFunction<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getMapPartitionReturnTypes(MapPartitionFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getMapReturnTypes(MapFunction<IN, OUT>, TypeInformation<IN>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getMapReturnTypes(MapFunction<IN, OUT>, TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getMapState(MapStateDescriptor<UK, UV>) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Gets a handle to the system's key/value map state.
getMapState(MapStateDescriptor<UK, UV>) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getMapState(MapStateDescriptor<UK, UV>) - Method in interface org.apache.flink.api.common.state.KeyedStateStore
Gets a handle to the system's key/value map state.
getMapState(MapStateDescriptor<UK, UV>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
 
getMapState(MapStateDescriptor<UK, UV>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
getMapState(MapStateDescriptor<UK, UV>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
 
getMapState(MapStateDescriptor<UK, UV>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.PerWindowStateStore
 
getMarkedTime() - Method in class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
Returns the timestamp marked by the LatencyMarker.
getMasterHooks() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
getMasterHookStates() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
getMasterStates() - Method in class org.apache.flink.migration.runtime.checkpoint.savepoint.SavepointV0
 
getMasterStates() - Method in interface org.apache.flink.runtime.checkpoint.savepoint.Savepoint
Gets the checkpointed states generated by the master.
getMasterStates() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
 
getMasterStates() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
 
getMatchesFor(PT) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
getMatchFor(PT, BT) - Method in class org.apache.flink.runtime.operators.hash.AbstractHashTableProber
 
getMatchFor(PT) - Method in class org.apache.flink.runtime.operators.hash.AbstractHashTableProber
 
getMatchFor(PT, T) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable.HashTableProber
 
getMatchFor(PT) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable.HashTableProber
 
getMatchFor(PT, T) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.HashTableProber
Searches the hash table for the record with the given key.
getMatchFor(PT) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.HashTableProber
 
getMaterializationMode() - Method in class org.apache.flink.optimizer.dag.DagConnection
 
getMax() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
 
getMax() - Method in class org.apache.flink.metrics.HistogramStatistics
Returns the maximum value of the histogram.
getMax() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxHistogramMBean
 
getMaxBackPressureRatio() - Method in class org.apache.flink.runtime.webmonitor.OperatorBackPressureStats
Returns the maximum back pressure ratio of all sub tasks.
getMaxConcurrentCheckpoints() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
getMaxConcurrentCheckpoints() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
Gets the maximum number of checkpoint attempts that may be in progress at the same time.
getMaxDepth() - Method in class org.apache.flink.optimizer.dag.DagConnection
 
getMaxDepth() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
getMaxDepth() - Method in class org.apache.flink.optimizer.plan.Channel
 
getMaxDepth(int) - Static method in class org.apache.flink.runtime.operators.sort.QuickSort
Deepest recursion before giving up and doing a heapsort.
getMaxFailureRate() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FailureRateRestartStrategyConfiguration
 
getMaxFlinkTupleSize() - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
 
getMaxFlinkTupleSize() - Method in class org.apache.flink.hcatalog.java.HCatInputFormat
 
getMaxFlinkTupleSize() - Method in class org.apache.flink.hcatalog.scala.HCatInputFormat
 
getMaxIdleStateRetentionTime() - Method in class org.apache.flink.table.api.StreamQueryConfig
 
getMaximum() - Method in class org.apache.flink.runtime.checkpoint.MinMaxAvgStats
Returns the maximum seen value.
getMaximumDegree() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
Get the maximum degree.
getMaximumDegree() - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics.Result
Get the maximum degree.
getMaximumInDegree() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
Get the maximum in degree.
getMaximumNumberOfIterations() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
 
getMaximumNumberOfIterations() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
 
getMaximumNumberOfSplits() - Method in class org.apache.flink.util.LongValueSequenceIterator
 
getMaximumNumberOfSplits() - Method in class org.apache.flink.util.NumberSequenceIterator
 
getMaximumNumberOfSplits() - Method in class org.apache.flink.util.SplittableIterator
The maximum number of splits into which this iterator can be split up.
getMaximumOutDegree() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
Get the maximum out degree.
getMaximumParallelism() - Method in class org.apache.flink.api.common.Plan
 
getMaximumParallelism() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Gets the maximum parallelism of all operations in this job graph.
getMaximumRectangleTriplets() - Method in class org.apache.flink.graph.library.metric.directed.EdgeMetrics.Result
Get the maximum rectangle triplets.
getMaximumRectangleTriplets() - Method in class org.apache.flink.graph.library.metric.undirected.EdgeMetrics.Result
Get the maximum rectangle triplets.
getMaximumTriangleTriplets() - Method in class org.apache.flink.graph.library.metric.directed.EdgeMetrics.Result
Get the maximum triangle triplets.
getMaximumTriangleTriplets() - Method in class org.apache.flink.graph.library.metric.undirected.EdgeMetrics.Result
Get the maximum triangle triplets.
getMaximumTriplets() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
Get the maximum triplets.
getMaximumTriplets() - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics.Result
Get the maximum triplets.
getMaxIterations() - Method in class org.apache.flink.api.java.operators.DeltaIterationResultSet
 
getMaxIterations() - Method in class org.apache.flink.api.java.operators.IterativeDataSet
Gets the maximum number of iterations.
getMaxJvmHeapMemory() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
The maximum JVM heap size, in bytes.
getMaxLength() - Method in class org.apache.flink.api.java.summarize.StringColumnSummary
Longest String length
getMaxNormalizedKeyLen() - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
 
getMaxNormalizedKeyLen() - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
 
getMaxNormalizedKeyLen() - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
 
getMaxNormalizedKeyLen() - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
 
getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.BooleanValue
 
getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.ByteValue
 
getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.CharValue
 
getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.IntValue
 
getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.LongValue
 
getMaxNormalizedKeyLen() - Method in interface org.apache.flink.types.NormalizableKey
Gets the maximal length of normalized keys that the data type would produce to determine the order of instances solely by the normalized key.
getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.NullValue
 
getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.ShortValue
 
getMaxNormalizedKeyLen() - Method in class org.apache.flink.types.StringValue
 
getMaxNumberOfMemorySegments() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
Returns the maximum number of memory segments this buffer pool should use
getMaxNumberOfParallelSubtasks() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Gets the number of max-parallelism with which the parallel task runs.
getMaxNumberOfParallelSubtasks() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getMaxNumberOfParallelSubtasks() - Method in class org.apache.flink.api.common.TaskInfo
Gets the max parallelism aka the max number of subtasks.
getMaxNumberOfRetainedCheckpoints() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
Returns the max number of retained checkpoints.
getMaxNumberOfRetainedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
 
getMaxNumberOfRetainedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
 
getMaxNumberOfSubtaks() - Method in class org.apache.flink.runtime.executiongraph.TaskInformation
 
getMaxNumericPrecision() - Method in class org.apache.flink.table.calcite.FlinkTypeSystem
 
getMaxNumericScale() - Method in class org.apache.flink.table.calcite.FlinkTypeSystem
 
getMaxOutOfOrdernessInMillis() - Method in class org.apache.flink.streaming.api.functions.timestamps.BoundedOutOfOrdernessTimestampExtractor
 
getMaxParallelism() - Method in class org.apache.flink.api.common.ExecutionConfig
Gets the maximum degree of parallelism defined for the program.
getMaxParallelism() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
 
getMaxParallelism() - Method in class org.apache.flink.runtime.checkpoint.TaskState
Deprecated.
 
getMaxParallelism() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
 
getMaxParallelism() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
Returns the max parallelism for this job vertex.
getMaxParallelism() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
 
getMaxParallelism() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getMaxParallelism() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getMaxParallelism() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
Gets the maximum parallelism for the task.
getMaxParallelism() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Gets the maximum degree of parallelism defined for the program.
getMaxParallelism() - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Returns the maximum degree of parallelism defined for the program.
getMaxParallelism() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
Gets the maximum parallelism for this stream transformation.
getMaxParallelism() - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
 
getMaxRegistrationDuration() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getMaxRegistrationPause() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getMaxRetryCount() - Method in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase.BulkFlushBackoffPolicy
 
getMaxSlots() - Method in class org.apache.flink.client.program.ClusterClient
The client may define an upper limit on the number of slots to use
getMaxSlots() - Method in class org.apache.flink.client.program.StandaloneClusterClient
 
getMaxSlots() - Method in class org.apache.flink.yarn.YarnClusterClient
 
getMaxSlots() - Method in class org.apache.flink.yarn.YarnClusterClientV2
 
getMean() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
Null, NaN, and Infinite values are ignored in this calculation.
getMean() - Method in class org.apache.flink.metrics.HistogramStatistics
Returns the mean of the histogram values.
getMean() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxHistogramMBean
 
getMeanLength() - Method in class org.apache.flink.api.java.summarize.StringColumnSummary
 
getMeanRate() - Method in class org.apache.flink.dropwizard.metrics.FlinkMeterWrapper
 
getMebiBytes() - Method in class org.apache.flink.configuration.MemorySize
Gets the memory size in Mebibytes (= 1024 Kibibytes).
getMedia() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Entities
 
getMedia_url() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Media
 
getMedia_url_https() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Media
 
getMedian() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxHistogramMBean
 
getMemoryConsumerWeight() - Method in class org.apache.flink.optimizer.plan.BinaryUnionPlanNode
 
getMemoryConsumerWeight() - Method in class org.apache.flink.optimizer.plan.BulkIterationPlanNode
 
getMemoryConsumerWeight() - Method in class org.apache.flink.optimizer.plan.PlanNode
 
getMemoryConsumerWeight() - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
 
getMemoryFraction() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
getMemoryInMB() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
Get the total memory needed in MB
getMemoryManager() - Method in interface org.apache.flink.runtime.execution.Environment
Returns the current MemoryManager.
getMemoryManager() - Method in class org.apache.flink.runtime.operators.BatchTask
 
getMemoryManager() - Method in interface org.apache.flink.runtime.operators.TaskContext
 
getMemoryManager() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
 
getMemoryManager() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getMemoryPoolStatsAsString(List<MemoryPoolMXBean>) - Static method in class org.apache.flink.runtime.taskmanager.MemoryLogger
Gets the memory pool statistics from the JVM.
getMemorySegment() - Method in class org.apache.flink.runtime.io.network.buffer.Buffer
 
getMemorySegment() - Method in class org.apache.flink.runtime.operators.util.BloomFilter.BitSet
 
getMemorySegmentSize() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
Returns the size of the underlying memory segments.
getMemorySegmentSize() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
getMemorySize() - Method in class org.apache.flink.runtime.memory.MemoryManager
Returns the total size of memory handled by this memory manager.
getMemoryType() - Method in class org.apache.flink.runtime.memory.MemoryManager
Gets the type of memory (heap / off-heap) managed by this memory manager.
getMemoryUsageStatsAsString(MemoryMXBean) - Static method in class org.apache.flink.runtime.taskmanager.MemoryLogger
Gets the memory footprint of the JVM in a string representation.
getMergingIterator(List<UnilateralSortMerger.ChannelWithBlockCount>, List<List<MemorySegment>>, List<FileIOChannel>, MutableObjectIterator<E>) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Returns an iterator that iterates over the merged result from all given channels.
getMergingWindowSet() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
Retrieves the MergingWindowSet for the currently active key.
getMessage() - Method in exception org.apache.flink.runtime.io.network.partition.PartitionNotFoundException
 
getMessage() - Static method in exception org.apache.flink.table.api.AmbiguousTableSourceConverterException
 
getMessage() - Static method in exception org.apache.flink.table.api.CatalogAlreadyExistException
 
getMessage() - Static method in exception org.apache.flink.table.api.CatalogNotExistException
 
getMessage() - Static method in exception org.apache.flink.table.api.ExpressionParserException
 
getMessage() - Static method in exception org.apache.flink.table.api.ExternalCatalogAlreadyExistException
 
getMessage() - Static method in exception org.apache.flink.table.api.ExternalCatalogNotExistException
 
getMessage() - Static method in exception org.apache.flink.table.api.NoMatchedTableSourceConverterException
 
getMessage() - Static method in exception org.apache.flink.table.api.SqlParserException
 
getMessage() - Static method in exception org.apache.flink.table.api.TableAlreadyExistException
 
getMessage() - Static method in exception org.apache.flink.table.api.TableException
 
getMessage() - Static method in exception org.apache.flink.table.api.TableNotExistException
 
getMessage() - Static method in exception org.apache.flink.table.api.UnresolvedException
 
getMessage() - Static method in exception org.apache.flink.table.api.ValidationException
 
getMessageId() - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getMetaInfo() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
getMetaInfo() - Method in class org.apache.flink.runtime.state.heap.StateTable
 
getMetaStateHandle() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
 
getMethodName() - Method in class org.apache.flink.runtime.rpc.akka.messages.LocalRpcInvocation
 
getMethodName() - Method in class org.apache.flink.runtime.rpc.akka.messages.RemoteRpcInvocation
 
getMethodName() - Method in interface org.apache.flink.runtime.rpc.akka.messages.RpcInvocation
Returns the method's name.
getMethodSignatures(UserDefinedFunction, String) - Method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils$
 
getMethodSignatures(UserDefinedFunction, String) - Static method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils
 
getMetric() - Method in class org.apache.flink.metrics.datadog.DMetric
 
getMetricGroup() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Returns the metric group for this parallel subtask.
getMetricGroup() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getMetricGroup() - Method in interface org.apache.flink.runtime.execution.Environment
Returns the task specific metric group.
getMetricGroup() - Method in class org.apache.flink.runtime.operators.BatchTask
 
getMetricGroup() - Method in interface org.apache.flink.runtime.operators.TaskContext
 
getMetricGroup() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getMetricGroup() - Method in class org.apache.flink.runtime.taskmanager.Task
 
getMetricGroup() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getMetricGroup() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
 
getMetricGroup() - Method in interface org.apache.flink.streaming.api.windowing.evictors.Evictor.EvictorContext
Returns the metric group for this Evictor.
getMetricGroup() - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
Returns the metric group for this Trigger.
getMetricGroup() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
getMetricGroup() - Method in class org.apache.flink.table.functions.FunctionContext
Returns the metric group for this parallel subtask.
getMetricIdentifier(String) - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
 
getMetricIdentifier(String, CharacterFilter) - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
 
getMetricIdentifier(String) - Method in interface org.apache.flink.metrics.MetricGroup
Returns the fully qualified metric name, for example "host-7.taskmanager-2.window_word_count.my-mapper.metricName"
getMetricIdentifier(String, CharacterFilter) - Method in interface org.apache.flink.metrics.MetricGroup
Returns the fully qualified metric name, for example "host-7.taskmanager-2.window_word_count.my-mapper.metricName"
getMetricIdentifier(String) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
Returns the fully qualified metric name, for example "host-7.taskmanager-2.window_word_count.my-mapper.metricName"
getMetricIdentifier(String, CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
Returns the fully qualified metric name, for example "host-7.taskmanager-2.window_word_count.my-mapper.metricName"
getMetricIdentifier(String, CharacterFilter, int) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
Returns the fully qualified metric name using the configured delimiter for the reporter with the given index, for example "host-7.taskmanager-2.window_word_count.my-mapper.metricName"
getMetricIdentifier(String) - Method in class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
 
getMetricIdentifier(String, CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
 
getMetricIdentifier(String) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
getMetricIdentifier(String, CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
getMetricRegistry() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
 
getMetricRegistryConfiguration() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
getMetricStore() - Method in class org.apache.flink.runtime.webmonitor.metrics.MetricFetcher
Returns the MetricStore containing all stored metrics.
getMetricValue() - Method in class org.apache.flink.metrics.datadog.DCounter
Visibility of this method must not be changed since we deliberately not map it to json object in a Datadog-defined format
getMetricValue() - Method in class org.apache.flink.metrics.datadog.DGauge
Visibility of this method must not be changed since we deliberately not map it to json object in a Datadog-defined format
getMetricValue() - Method in class org.apache.flink.metrics.datadog.DMeter
 
getMetricValue() - Method in class org.apache.flink.metrics.datadog.DMetric
 
getMimeTypeForExtension(String) - Static method in class org.apache.flink.runtime.webmonitor.files.MimeTypes
Gets the MIME type for the file with the given extension.
getMimeTypeForFileName(String) - Static method in class org.apache.flink.runtime.webmonitor.files.MimeTypes
Gets the MIME type for the file with the given name, by extension.
getMin() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
 
getMin() - Method in class org.apache.flink.metrics.HistogramStatistics
Returns the minimum value of the histogram.
getMin() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxHistogramMBean
 
getMinFileSizeThreshold() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
Gets the threshold below which state is stored as part of the metadata, rather than in files.
getMinIdleStateRetentionTime() - Method in class org.apache.flink.table.api.StreamQueryConfig
 
getMinimalMemoryAcrossAllSubTasks() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
Gets the amount of memory that all subtasks of this task have jointly available.
getMinimum() - Method in class org.apache.flink.runtime.checkpoint.MinMaxAvgStats
Returns the minimum seen value.
getMinimumCyclesPerBlock() - Method in class org.apache.flink.graph.generator.random.AbstractGeneratorFactory
 
getMinimumCyclesPerBlock() - Method in class org.apache.flink.graph.generator.random.JDKRandomGeneratorFactory
 
getMinimumCyclesPerBlock() - Method in class org.apache.flink.graph.generator.random.MersenneTwisterFactory
 
getMinLength() - Method in class org.apache.flink.api.java.summarize.StringColumnSummary
Shortest String length
getMinPauseBetweenCheckpoints() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
getMinPauseBetweenCheckpoints() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
Gets the minimal pause between checkpointing attempts.
getMinResources() - Method in class org.apache.flink.api.common.operators.Operator
Gets the minimum resources for this operator.
getMinResources() - Method in class org.apache.flink.api.java.operators.DataSink
Returns the minimum resources of this data sink.
getMinResources() - Method in class org.apache.flink.api.java.operators.DeltaIteration
Gets the minimum resources from this iteration.
getMinResources() - Method in class org.apache.flink.api.java.operators.Operator
Returns the minimum resource of this operator.
getMinResources() - Method in class org.apache.flink.optimizer.plan.PlanNode
 
getMinResources() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
Gets the minimum resource for the task.
getMinResources() - Method in class org.apache.flink.streaming.api.datastream.DataStream
Gets the minimum resources for this operator.
getMinResources() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getMinResources() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
Gets the minimum resource of this stream transformation.
getMinSplitSize() - Method in class org.apache.flink.api.common.io.FileInputFormat
 
getMismatches(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.MusicProfilesData
 
getMissingArguments() - Method in exception org.apache.flink.api.java.utils.RequiredParametersException
 
getMissingCount() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
The number of "missing" values where "missing" is defined as null, NaN, or Infinity.
getMktsegment() - Method in class org.apache.flink.examples.java.relational.TPCHQuery3.Customer
 
getModel(Instance, ParameterMap) - Method in interface org.apache.flink.ml.pipeline.PredictOperation
Defines how to retrieve the model of the type for which this operation was defined
getModel(Instance, ParameterMap) - Method in interface org.apache.flink.ml.pipeline.TransformOperation
Retrieves the model of the Transformer for which this operation has been defined.
getModel(StandardScaler, ParameterMap) - Method in class org.apache.flink.ml.preprocessing.StandardScaler.StandardScalerTransformOperation
 
getModificationTime() - Method in interface org.apache.flink.core.fs.FileStatus
Get the modification time of the file.
getModificationTime() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
 
getModificationTime() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
 
getModificationTime() - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
 
getMonotonicity(SqlOperatorBinding) - Method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction$
 
getMonotonicity(SqlOperatorBinding) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
getMonotonicity(SqlCall, SqlValidatorScope) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
getMonotonicity(SqlOperatorBinding) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
getMonotonicity(SqlCall, SqlValidatorScope) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
getMonotonicity(SqlOperatorBinding) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
getMonotonicity(SqlCall, SqlValidatorScope) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
getMonotonicity(SqlOperatorBinding) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
getMutableObjectMode() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getName() - Method in class org.apache.flink.api.common.aggregators.AggregatorWithName
Gets the name that the aggregator is registered under.
getName() - Method in class org.apache.flink.api.common.operators.Operator
Gets the name of the contract instance.
getName() - Method in class org.apache.flink.api.common.state.StateDescriptor
Returns the name of this StateDescriptor.
getName() - Method in class org.apache.flink.api.java.operators.DeltaIteration
Gets the name from this iteration.
getName() - Method in class org.apache.flink.api.java.operators.Operator
Returns the name of the operator.
getName() - Method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils.LambdaExecutable
 
getName() - Method in class org.apache.flink.api.java.utils.Option
 
getName() - Method in class org.apache.flink.cep.nfa.State
 
getName() - Method in class org.apache.flink.cep.pattern.Pattern
 
getName() - Method in class org.apache.flink.cep.scala.pattern.Pattern
 
getName() - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Places
 
getName() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.UserMention
 
getName() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getName() - Method in class org.apache.flink.core.fs.Path
Returns the final component of this path, i.e., everything that follows the last separator.
getName() - Method in class org.apache.flink.graph.drivers.AdamicAdar
 
getName() - Method in class org.apache.flink.graph.drivers.ClusteringCoefficient
 
getName() - Method in class org.apache.flink.graph.drivers.ConnectedComponents
 
getName() - Method in class org.apache.flink.graph.drivers.EdgeList
 
getName() - Method in class org.apache.flink.graph.drivers.GraphMetrics
 
getName() - Method in class org.apache.flink.graph.drivers.HITS
 
getName() - Method in class org.apache.flink.graph.drivers.input.CirculantGraph
 
getName() - Method in class org.apache.flink.graph.drivers.input.CompleteGraph
 
getName() - Method in class org.apache.flink.graph.drivers.input.CSV
 
getName() - Method in class org.apache.flink.graph.drivers.input.CycleGraph
 
getName() - Method in class org.apache.flink.graph.drivers.input.EchoGraph
 
getName() - Method in class org.apache.flink.graph.drivers.input.EmptyGraph
 
getName() - Method in class org.apache.flink.graph.drivers.input.GridGraph
 
getName() - Method in class org.apache.flink.graph.drivers.input.HypercubeGraph
 
getName() - Method in class org.apache.flink.graph.drivers.input.PathGraph
 
getName() - Method in class org.apache.flink.graph.drivers.input.RMatGraph
 
getName() - Method in class org.apache.flink.graph.drivers.input.SingletonEdgeGraph
 
getName() - Method in class org.apache.flink.graph.drivers.input.StarGraph
 
getName() - Method in class org.apache.flink.graph.drivers.JaccardIndex
 
getName() - Method in class org.apache.flink.graph.drivers.PageRank
 
getName() - Method in interface org.apache.flink.graph.drivers.parameter.Parameterized
A unique, human-readable identifier.
getName() - Method in class org.apache.flink.graph.drivers.TriangleListing
 
getName(String) - Method in class org.apache.flink.graph.IterationConfiguration
Gets the name of the iteration.
getName() - Method in class org.apache.flink.optimizer.plan.NamedChannel
 
getName() - Method in class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
 
getName() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableKey
 
getName() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
Returns the name for this job vertex.
getName() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
 
getName() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getName() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Returns the name assigned to the job graph.
getName() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
Returns the name of the vertex.
getName() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo
 
getName() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo.Snapshot
 
getName() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo
 
getName() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo.Snapshot
 
getName() - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Gets the name of the current data stream.
getName() - Method in class org.apache.flink.streaming.api.scala.DataStream
Deprecated.
Use name instead
getName() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
Returns the name of this StreamTransformation.
getName() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
Gets the name of the task, in the form "taskname (2/5)".
getName() - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
getName() - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
getName() - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
getName() - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
getNameAsId() - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
getNameAsId() - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
getNameAsId() - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
getNameAsId() - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
getNamedAggCalls() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
getNamedAggCalls() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
getNamedAggCalls() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getNamedProperties() - Method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
getNamedProperties() - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getNamespace() - Method in interface org.apache.flink.runtime.state.heap.StateEntry
Returns the namespace of this entry.
getNamespace() - Method in class org.apache.flink.streaming.api.operators.InternalTimer
 
getNamespaceSerializer() - Method in class org.apache.flink.migration.runtime.state.filesystem.AbstractFsStateSnapshot
Deprecated.
 
getNamespaceSerializer() - Method in class org.apache.flink.migration.runtime.state.memory.AbstractMemStateSnapshot
Deprecated.
 
getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.heap.StateTable
 
getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo
 
getNamespaceSerializer() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo.Snapshot
 
getNamespaceSerializerConfigSnapshot() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo.Snapshot
 
getNanCount() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
Number of values that are NaN.
getNativeMemory() - Method in class org.apache.flink.api.common.operators.ResourceSpec
 
getNativeMemoryInMB() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
Get the native memory needed in MB
getNeighborValue() - Method in class org.apache.flink.graph.gsa.Neighbor
 
getNestedDelta(double[], double[]) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.CosineDistance
 
getNestedDelta(double[], double[]) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.EuclideanDistance
 
getNestedDelta(TO, TO) - Method in class org.apache.flink.streaming.api.functions.windowing.delta.ExtractionAwareDeltaFunction
This method is exactly the same as DeltaFunction.getDelta(Object, Object) except that it gets the result of the previously done extractions as input.
getNestedFileEnumeration() - Method in class org.apache.flink.api.common.io.FileInputFormat
 
getNestedSerializersAndConfigs() - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
 
getNestedTrigger() - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
 
getNetRuntime() - Method in class org.apache.flink.api.common.JobExecutionResult
Gets the net execution time of the job, i.e., the execution time in the parallel system, without the pre-flight steps like the optimizer.
getNetRuntime(TimeUnit) - Method in class org.apache.flink.api.common.JobExecutionResult
Gets the net execution time of the job, i.e., the execution time in the parallel system, without the pre-flight steps like the optimizer in a desired time unit.
getNetRuntime() - Method in class org.apache.flink.client.program.DetachedEnvironment.DetachedJobExecutionResult
 
getNetRuntime() - Method in class org.apache.flink.runtime.client.SerializedJobExecutionResult
 
getNetRuntime(TimeUnit) - Method in class org.apache.flink.runtime.client.SerializedJobExecutionResult
Gets the net execution time of the job, i.e., the execution time in the parallel system, without the pre-flight steps like the optimizer in a desired time unit.
getNetworkBufferPool() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
getNetworkConfig() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
getNetworkCost() - Method in class org.apache.flink.optimizer.costs.Costs
Gets the network cost.
getNetworkEnvironment() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
 
getNetworkRecoveryInterval() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig
Returns automatic connection recovery interval in milliseconds.
getNewInMemoryPartition(int, int) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
Returns a new inMemoryPartition object.
getNewInMemoryPartition(int, int) - Method in class org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
 
getNewIterationNodeId() - Static method in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
getNewMessages() - Method in class org.apache.flink.client.program.ClusterClient
May return new messages from the cluster.
getNewMessages() - Method in class org.apache.flink.client.program.StandaloneClusterClient
 
getNewMessages() - Method in class org.apache.flink.yarn.YarnClusterClient
 
getNewMessages() - Method in class org.apache.flink.yarn.YarnClusterClientV2
 
getNewNodeId() - Static method in class org.apache.flink.streaming.api.transformations.StreamTransformation
 
getNewSlotForSharingGroup(ExecutionVertex, Iterable<TaskManagerLocation>, SlotSharingGroupAssignment, CoLocationConstraint, boolean) - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
Tries to allocate a new slot for a vertex that is part of a slot sharing group.
getNewType() - Method in exception org.apache.flink.optimizer.postpass.ConflictingFieldTypeInfoException
 
getNext() - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller.SpilledBufferOrEventSequence
Gets the next BufferOrEvent from the spilled sequence, or null, if the sequence is exhausted.
getNextBucketPath(Path) - Method in interface org.apache.flink.streaming.connectors.fs.Bucketer
Deprecated.
Returns the Path of a new bucket file.
getNextBucketPath(Path) - Method in class org.apache.flink.streaming.connectors.fs.DateTimeBucketer
Deprecated.
 
getNextBucketPath(Path) - Method in class org.apache.flink.streaming.connectors.fs.NonRollingBucketer
Deprecated.
 
getNextBuffer() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
Returns the next Buffer instance of this queue iterator.
getNextBufferOrEvent() - Method in interface org.apache.flink.runtime.io.network.partition.consumer.InputGate
 
getNextBufferOrEvent() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
getNextBufferOrEvent() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
 
getNextEvaluationTime() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
Deprecated.
 
getNextInputSplit(String, int) - Method in class org.apache.flink.api.common.io.DefaultInputSplitAssigner
 
getNextInputSplit(String, int) - Method in class org.apache.flink.api.common.io.LocatableInputSplitAssigner
 
getNextInputSplit(String, int) - Method in class org.apache.flink.api.common.io.ReplicatingInputSplitAssigner
 
getNextInputSplit(String, int) - Method in interface org.apache.flink.core.io.InputSplitAssigner
Returns the next input split that shall be consumed.
getNextInputSplit(ClassLoader) - Method in interface org.apache.flink.runtime.jobgraph.tasks.InputSplitProvider
Requests the next input split to be consumed by the calling task.
getNextInputSplit(ClassLoader) - Method in class org.apache.flink.runtime.taskexecutor.rpc.RpcInputSplitProvider
 
getNextInputSplit(ClassLoader) - Method in class org.apache.flink.runtime.taskmanager.TaskInputSplitProvider
 
getNextNonBlocked() - Method in class org.apache.flink.streaming.runtime.io.BarrierBuffer
 
getNextNonBlocked() - Method in class org.apache.flink.streaming.runtime.io.BarrierTracker
 
getNextNonBlocked() - Method in interface org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
Returns the next BufferOrEvent that the operator may consume.
getNextPartialSolution() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
 
getNextPartialSolution() - Method in class org.apache.flink.api.java.operators.BulkIterationResultSet
 
getNextPartialSolution() - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
Gets the nextPartialSolution from this BulkIterationNode.
getNextPathNum() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
 
getNextRecord(T) - Method in class org.apache.flink.runtime.io.network.api.serialization.AdaptiveSpanningRecordDeserializer
 
getNextRecord(T) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
 
getNextRecord(T) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
 
getNextReturnedBlock() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockReader
Gets the next memory segment that has been filled with data by the reader.
getNextReturnedBlock() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockWriter
Gets the next memory segment that has been written and is available again.
getNextReturnedBlock() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BlockChannelReader
Gets the next memory segment that has been filled with data by the reader.
getNextReturnedBlock() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BlockChannelWriter
Gets the next memory segment that has been written and is available again.
getNextSlideTime() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
Deprecated.
 
getNextSolutionSet() - Method in class org.apache.flink.api.java.operators.DeltaIterationResultSet
 
getNextWorkset() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
Gets the contract that has been set as the next workset.
getNextWorkset() - Method in class org.apache.flink.api.java.operators.DeltaIterationResultSet
 
getNextWorkset() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
 
getNextWorkSetPlanNode() - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
 
getNioBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.Buffer
 
getNioFileChannel() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
 
getNioFileChannel() - Method in interface org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
 
getNodeCosts() - Method in class org.apache.flink.optimizer.plan.PlanNode
Gets the costs incurred by this node.
getNodeName() - Method in class org.apache.flink.optimizer.operators.AbstractSortMergeJoinDescriptor
 
getNodeName() - Method in class org.apache.flink.optimizer.operators.SortMergeFullOuterJoinDescriptor
 
getNodeName() - Method in class org.apache.flink.optimizer.operators.SortMergeInnerJoinDescriptor
 
getNodeName() - Method in class org.apache.flink.optimizer.operators.SortMergeLeftOuterJoinDescriptor
 
getNodeName() - Method in class org.apache.flink.optimizer.operators.SortMergeRightOuterJoinDescriptor
 
getNodeName() - Method in class org.apache.flink.optimizer.plan.PlanNode
Gets the name of the plan node.
getNonChainedOutputs(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getNonMissingCount() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
The number of values that are not null, NaN, or Infinity.
getNonNullCount() - Method in class org.apache.flink.api.java.summarize.BooleanColumnSummary
The number of non-null values in this column
getNonNullCount() - Method in class org.apache.flink.api.java.summarize.ColumnSummary
The number of non-null values in this column
getNonNullCount() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
The number of non-null values in this column
getNonNullCount() - Method in class org.apache.flink.api.java.summarize.ObjectColumnSummary
The number of non-null values in this column
getNonNullCount() - Method in class org.apache.flink.api.java.summarize.StringColumnSummary
 
getNonRegisteredSubclassesToSerializerConfigSnapshots() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
 
getNonReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
getNonReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.FullOuterJoinDriver
 
getNonReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.LeftOuterJoinDriver
 
getNonReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.RightOuterJoinDriver
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.BigDecComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.BigIntComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.BooleanComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.ByteComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.CharComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.DateComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.DoubleComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.EnumComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.FloatComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.IntComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.LongComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.ShortComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Gets the number of bytes that the normalized key would maximally take.
getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.scala.typeutils.EnumValueComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.api.scala.typeutils.OptionTypeComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
 
getNormalizeKeyLen() - Method in class org.apache.flink.table.runtime.types.CRowComparator
 
getNormRuleSet() - Method in class org.apache.flink.table.api.TableEnvironment
Returns the normalization rule set for this environment including a custom RuleSet configuration.
getNormRuleSet() - Method in interface org.apache.flink.table.calcite.CalciteConfig
Returns a custom normalization rule set.
getNotifyWhenRegisteredAtJobManagerMessage() - Method in class org.apache.flink.runtime.messages.TaskManagerMessages$
Accessor for the case object instance, to simplify Java interoperability.
getNotifyWhenRegisteredAtJobManagerMessage() - Static method in class org.apache.flink.runtime.messages.TaskManagerMessages
Accessor for the case object instance, to simplify Java interoperability.
getNow(T) - Method in interface org.apache.flink.runtime.concurrent.Future
Gets the value of the future.
getNow(T) - Method in class org.apache.flink.runtime.concurrent.impl.FlinkFuture
 
getNullCheck() - Method in class org.apache.flink.table.api.TableConfig
Returns the NULL check.
getNullCount() - Method in class org.apache.flink.api.java.summarize.BooleanColumnSummary
 
getNullCount() - Method in class org.apache.flink.api.java.summarize.ColumnSummary
The number of null values in this column
getNullCount() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
 
getNullCount() - Method in class org.apache.flink.api.java.summarize.ObjectColumnSummary
 
getNullCount() - Method in class org.apache.flink.api.java.summarize.StringColumnSummary
 
getNumActiveTimers() - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
getNumberCollectedKvStates() - Method in class org.apache.flink.migration.runtime.checkpoint.TaskState
Deprecated.
 
getNumberCollectedStates() - Method in class org.apache.flink.migration.runtime.checkpoint.TaskState
Deprecated.
 
getNumberCollectedStates() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
 
getNumberCollectedStates() - Method in class org.apache.flink.runtime.checkpoint.TaskState
Deprecated.
 
getNumberCPUCores() - Static method in class org.apache.flink.runtime.util.Hardware
Gets the number of CPU cores (hardware contexts) that the JVM has access to.
getNumberLeaves() - Method in class org.apache.flink.runtime.instance.SharedSlot
 
getNumberLeaves() - Method in class org.apache.flink.runtime.instance.SimpleSlot
 
getNumberLeaves() - Method in class org.apache.flink.runtime.instance.Slot
Gets the number of simple slots that are at the leaves of the tree of slots.
getNumberOfAcknowledgedSubtasks() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
Returns the number of acknowledged subtasks.
getNumberOfAcknowledgedSubtasks() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
 
getNumberOfAcknowledgedSubtasks() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
 
getNumberOfAcknowledgedSubtasks() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpointStats
 
getNumberOfAcknowledgedSubtasks() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
Returns the number of acknowledged subtasks.
getNumberOfAcknowledgedTasks() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
getNumberOfActiveConnections() - Method in interface org.apache.flink.runtime.io.network.ConnectionManager
 
getNumberOfActiveConnections() - Method in class org.apache.flink.runtime.io.network.LocalConnectionManager
 
getNumberOfActiveConnections() - Method in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager
 
getNumberOfAllocatedBytes() - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
Returns the number of currently allocated bytes.
getNumberOfAllocatedSlots() - Method in class org.apache.flink.runtime.instance.Instance
 
getNumberOfArenas() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
getNumberOfAssignedPartitions() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
 
getNumberOfAvailableInstances() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
getNumberOfAvailableMemorySegments() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
Returns the number memory segments, which are currently held by this buffer pool.
getNumberOfAvailableMemorySegments() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
getNumberOfAvailableSlots() - Method in class org.apache.flink.runtime.instance.Instance
 
getNumberOfAvailableSlots() - Method in class org.apache.flink.runtime.instance.InstanceManager
 
getNumberOfAvailableSlots() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
NOTE: In the presence of multi-threaded operations, this number may be inexact.
getNumberOfAvailableSlotsForGroup(AbstractID) - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
Gets the number of shared slots into which the given group can place subtasks or nested task groups.
getNumberOfChainedStubs() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getNumberOfCompletedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsCounts
Returns the number of completed checkpoints.
getNumberOfCPUCores() - Method in class org.apache.flink.runtime.instance.HardwareDescription
Returns the number of CPU cores available to the JVM on the compute node.
getNumberOfDirectedEdges() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
Get the number of unidirectional edges.
getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
 
getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
 
getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.AllReduceDriver
 
getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.CoGroupDriver
 
getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
 
getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
 
getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
 
getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.CrossDriver
 
getNumberOfDriverComparators() - Method in interface org.apache.flink.runtime.operators.Driver
Gets the number of comparators required for this driver.
getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.FlatMapDriver
 
getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
 
getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
 
getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.JoinDriver
 
getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
 
getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
 
getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.MapDriver
 
getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
 
getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.NoOpDriver
 
getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
 
getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.ReduceDriver
 
getNumberOfDriverComparators() - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
 
getNumberOfEdges() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
Get the number of edges.
getNumberOfEdges() - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics.Result
Get the number of edges.
getNumberOfEventsUntilInterruptInIterativeBroadcastGate(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getNumberOfEventsUntilInterruptInIterativeGate(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getNumberOfExecutionJobVertices() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Gets the number of job vertices currently held by this execution graph.
getNumberOfExecutionRetries() - Method in class org.apache.flink.api.common.ExecutionConfig
Deprecated.
Should no longer be used because it is subsumed by RestartStrategyConfiguration
getNumberOfExecutionRetries() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
This method will be replaced by ExecutionEnvironment.getRestartStrategy(). The RestartStrategies.FixedDelayRestartStrategyConfiguration contains the number of execution retries.
getNumberOfExecutionRetries() - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Deprecated.
This method will be replaced by getRestartStrategy. The FixedDelayRestartStrategyConfiguration contains the number of execution retries.
getNumberOfExecutionRetries() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Deprecated.
This method will be replaced by StreamExecutionEnvironment.getRestartStrategy().
getNumberOfExecutionRetries() - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Deprecated.
This method will be replaced by getRestartStrategy. The FixedDelayRestartStrategyConfiguration contains the number of execution retries.
getNumberOfFailedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsCounts
Returns the number of failed checkpoints.
getNumberOfFields() - Method in interface org.apache.flink.api.common.distributions.DataDistribution
The number of fields in the (composite) key.
getNumberOfFields() - Method in class org.apache.flink.api.common.operators.Ordering
 
getNumberOfFieldsTotal() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
getNumberOfFullRestarts() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Gets the number of full restarts that the execution graph went through.
getNumberOfInProgressCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsCounts
Returns the number of in progress checkpoints.
getNumberOfInputChannels() - Method in interface org.apache.flink.runtime.io.network.partition.consumer.InputGate
 
getNumberOfInputChannels() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
getNumberOfInputChannels() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
Returns the total number of input channels across all unioned input gates.
getNumberOfInputs() - Method in class org.apache.flink.api.common.operators.AbstractUdfOperator
Gets the number of inputs for this operator.
getNumberOfInputs() - Method in class org.apache.flink.api.common.operators.DualInputOperator
 
getNumberOfInputs() - Method in class org.apache.flink.api.common.operators.SingleInputOperator
 
getNumberOfInputs() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getNumberOfInputs() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
Returns the number of inputs.
getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
 
getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
 
getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.AllReduceDriver
 
getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.CoGroupDriver
 
getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
 
getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
 
getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
 
getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.CrossDriver
 
getNumberOfInputs() - Method in interface org.apache.flink.runtime.operators.Driver
Gets the number of inputs that the task has.
getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.FlatMapDriver
 
getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
 
getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
 
getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.JoinDriver
 
getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
 
getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
 
getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.MapDriver
 
getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
 
getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.NoOpDriver
 
getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
 
getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.ReduceDriver
 
getNumberOfInputs() - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
 
getNumberOfInputs() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getNumberOfInstancesWithAvailableSlots() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
getNumberOfIterations() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getNumberOfJobManagers() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
getNumberOfKeyFields() - Method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
getNumberOfKeyFields() - Method in class org.apache.flink.api.common.operators.Keys
 
getNumberOfKeyFields() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
getNumberOfKeyGroups() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
getNumberOfKeyGroups() - Method in interface org.apache.flink.runtime.state.heap.InternalKeyContext
Returns the number of key-groups aka max parallelism.
getNumberOfKeyGroups() - Method in class org.apache.flink.runtime.state.KeyGroupRange
 
getNumberOfKeyGroups() - Method in interface org.apache.flink.runtime.state.KeyGroupsList
Returns the number of key group ids in the list.
getNumberOfLocalAssignments() - Method in class org.apache.flink.api.common.io.LocatableInputSplitAssigner
 
getNumberOfLocalizedAssignments() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
getNumberOfNonAcknowledgedTasks() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
getNumberOfNonLocalizedAssignments() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
getNumberOfNonNullFields() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
getNumberOfOutputChannels() - Method in class org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
 
getNumberOfOutputs() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getNumberOfOutstandingRequests() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileWriter
 
getNumberOfOutstandingRequests() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BufferFileWriter
Returns the number of outstanding requests.
getNumberOfPages() - Static method in class org.apache.flink.examples.java.graph.util.PageRankData
 
getNumberOfParallelSubtasks() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Gets the parallelism with which the parallel task runs.
getNumberOfParallelSubtasks() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getNumberOfParallelSubtasks() - Method in class org.apache.flink.api.common.TaskInfo
Gets the parallelism with which the parallel task runs.
getNumberOfParameters() - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns number of parameters in ParameterTool.
getNumberOfPartitions() - Method in class org.apache.flink.runtime.state.OperatorStateCheckpointOutputStream
 
getNumberOfPendingCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
getNumberOfProducedIntermediateDataSets() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
Returns the number of produced intermediate data sets.
getNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
getNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
getNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
 
getNumberOfRecords() - Method in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
Gets the estimates number of records in the file, computed as the file size divided by the average record width, rounded up.
getNumberOfRecords() - Method in interface org.apache.flink.api.common.io.statistics.BaseStatistics
Gets the number of records in the input (= base cardinality).
getNumberOfRectangleTriplets() - Method in class org.apache.flink.graph.library.metric.directed.EdgeMetrics.Result
Get the number of rectangle triplets.
getNumberOfRectangleTriplets() - Method in class org.apache.flink.graph.library.metric.undirected.EdgeMetrics.Result
Get the number of rectangle triplets.
getNumberOfReferenceHolders(JobID) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
 
getNumberOfRegisteredBufferPools() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
getNumberOfRegisteredMasterHooks() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Gets the number of currently register master hooks.
getNumberOfRegisteredTaskManagers() - Method in class org.apache.flink.runtime.instance.InstanceManager
 
getNumberOfRegisteredTaskManagers(UUID) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
getNumberOfRegisteredTaskManagers(UUID) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Gets the currently registered number of TaskManagers.
getNumberOfRemoteAssignments() - Method in class org.apache.flink.api.common.io.LocatableInputSplitAssigner
 
getNumberOfRequiredMemorySegments() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
Returns the number of guaranteed (minimum number of) memory segments of this buffer pool.
getNumberOfResourceManagers() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
getNumberOfRestoredCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsCounts
Returns the number of restored checkpoints.
getNumberOfRetainedCheckpoints() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
Returns the current number of retained checkpoints.
getNumberOfRetainedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
 
getNumberOfRetainedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
 
getNumberOfRetainedSuccessfulCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
getNumberOfSlots() - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
Gets the number of slots that are currently governed by this assignment group.
getNumberOfSlots() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
getNumberOfSlots() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
getNumberOfSpillingDirectories() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
Gets the number of directories across which the I/O manager rotates its files.
getNumberOfStartedTaskManagers() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Gets the number of currently started TaskManagers.
getNumberOfSubpartitions() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
 
getNumberOfSubpartitions() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
 
getNumberOfSubtasks() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
Returns the total number of subtasks involved in this checkpoint.
getNumberOfSubtasks() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
Returns the number of subtasks.
getNumberOfSubtasks() - Method in class org.apache.flink.runtime.executiongraph.TaskInformation
 
getNumberOfSubTasks() - Method in class org.apache.flink.runtime.webmonitor.OperatorBackPressureStats
Returns the number of sub tasks.
getNumberOfTriangles() - Method in class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient.Result
Get the number of triangles.
getNumberOfTriangles() - Method in class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient.Result
Get the number of triangles.
getNumberOfTriangleTriplets() - Method in class org.apache.flink.graph.library.metric.directed.EdgeMetrics.Result
Get the number of triangle triplets.
getNumberOfTriangleTriplets() - Method in class org.apache.flink.graph.library.metric.undirected.EdgeMetrics.Result
Get the number of triangle triplets.
getNumberOfTriplets() - Method in class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient.Result
Get the number of triplets.
getNumberOfTriplets() - Method in class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient.Result
Get the number of triplets.
getNumberOfTriplets() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
Get the number of triplets.
getNumberOfTriplets() - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics.Result
Get the number of triplets.
getNumberOfUnconstrainedAssignments() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
getNumberOfUndirectedEdges() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
Get the number of bidirectional edges.
getNumberOfVariablesWithReferences() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableManager
 
getNumberOfVertices() - Method in class org.apache.flink.graph.gsa.ApplyFunction
Retrieves the number of vertices in the graph.
getNumberOfVertices() - Method in class org.apache.flink.graph.gsa.GatherFunction
Retrieves the number of vertices in the graph.
getNumberOfVertices() - Method in class org.apache.flink.graph.gsa.SumFunction
Retrieves the number of vertices in the graph.
getNumberOfVertices() - Method in class org.apache.flink.graph.library.clustering.directed.AverageClusteringCoefficient.Result
Get the number of vertices.
getNumberOfVertices() - Method in class org.apache.flink.graph.library.clustering.undirected.AverageClusteringCoefficient.Result
Get the number of vertices.
getNumberOfVertices() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
Get the number of vertices.
getNumberOfVertices() - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics.Result
Get the number of vertices.
getNumberOfVertices() - Method in class org.apache.flink.graph.spargel.GatherFunction
Retrieves the number of vertices in the graph.
getNumberOfVertices() - Method in class org.apache.flink.graph.spargel.ScatterFunction
Retrieves the number of vertices in the graph.
getNumberOfVertices() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Returns the number of all vertices.
getNumberSlots() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getNumBroadcastInputs() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getNumBuffers() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
Returns the current size of this buffer pool.
getNumBytesInLocal() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumBytesInLocalCounter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
getNumBytesInLocalPerSecond() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumBytesInLocalRateMeter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
getNumBytesInRemote() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumBytesInRemoteCounter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
getNumBytesInRemotePerSecond() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumBytesInRemoteRateMeter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
getNumBytesInTotal() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumBytesOut() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumBytesOutCounter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
getNumBytesOutPerSecond() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumBytesOutRateMeter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
getNumConnections() - Method in class org.apache.flink.runtime.query.netty.AtomicKvStateRequestStats
 
getNumConnectionsThatContributed() - Method in class org.apache.flink.optimizer.postpass.AbstractSchema
 
getNumElements() - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
Gets the number of elements produced in total by this function.
getNumElementsEmitted() - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
Gets the number of elements emitted so far.
getNumFailed() - Method in class org.apache.flink.runtime.query.netty.AtomicKvStateRequestStats
 
getNumFields() - Method in class org.apache.flink.types.Record
Gets the number of fields currently in the record.
getNumFuturesCompleted() - Method in interface org.apache.flink.runtime.concurrent.FutureUtils.ConjunctFuture
Gets the number of Futures in the conjunction that are already complete.
getNumFuturesTotal() - Method in interface org.apache.flink.runtime.concurrent.FutureUtils.ConjunctFuture
Gets the total number of Futures in the conjunction.
getNumIds() - Method in class org.apache.flink.runtime.state.SerializedCheckpointData
Gets the number of IDs in the checkpoint.
getNumInputs() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
 
getNumInputs() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getNumJobManagers() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
getNumJobsCancelled() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
 
getNumJobsFailed() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
 
getNumJobsFinished() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
 
getNumJobsRunningOrPending() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
 
getNumKeyGroups() - Method in class org.apache.flink.runtime.query.KvStateLocation
Returns the number of key groups of the operator the KvState instances belong to.
getNumLineSamples() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
getNumOccupiedMemorySegments() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
Gets the number of memory segments used by this partition, which includes build side memory buffers and overflow memory segments.
getNumOutputs() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getNumPanes() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
 
getNumPanesPerWindow() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
Deprecated.
 
getNumRecordsIn() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumRecordsInCounter() - Method in class org.apache.flink.runtime.metrics.groups.OperatorIOMetricGroup
 
getNumRecordsInCounter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
getNumRecordsInPerSecond() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumRecordsInRateMeter() - Method in class org.apache.flink.runtime.metrics.groups.OperatorIOMetricGroup
 
getNumRecordsOut() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumRecordsOutCounter() - Method in class org.apache.flink.runtime.metrics.groups.OperatorIOMetricGroup
 
getNumRecordsOutCounter() - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
getNumRecordsOutPerSecond() - Method in class org.apache.flink.runtime.executiongraph.IOMetrics
 
getNumRecordsOutRate() - Method in class org.apache.flink.runtime.metrics.groups.OperatorIOMetricGroup
 
getNumRegisteredKeyGroups() - Method in class org.apache.flink.runtime.query.KvStateLocation
Returns the current number of registered key groups.
getNumRequests() - Method in class org.apache.flink.runtime.query.netty.AtomicKvStateRequestStats
 
getNumRequiredComparators() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
 
getNumResourceManagers() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
getNumSlotsAvailable() - Method in class org.apache.flink.runtime.messages.webmonitor.StatusOverview
 
getNumSlotsPerTaskManager() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
getNumSlotsTotal() - Method in class org.apache.flink.runtime.messages.webmonitor.StatusOverview
 
getNumSplits() - Method in class org.apache.flink.api.common.io.FileInputFormat
 
getNumSuccessful() - Method in class org.apache.flink.runtime.query.netty.AtomicKvStateRequestStats
 
getNumTargetKeyGroups() - Method in class org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
 
getNumTargetKeyGroups() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
 
getNumTaskInputs() - Method in class org.apache.flink.runtime.iterative.task.IterationHeadTask
 
getNumTaskInputs() - Method in class org.apache.flink.runtime.operators.BatchTask
 
getNumTaskManagers() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
getNumTaskManagers() - Method in class org.apache.flink.test.util.AbstractTestBase
 
getNumTaskManagersConnected() - Method in class org.apache.flink.runtime.messages.webmonitor.StatusOverview
 
getNumTasks() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
 
getNumVerticesPerExecutionState() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
 
getNumWorkerRequestsPending() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
 
getNumWorkerRequestsPending() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Gets the number of requested workers that have not yet been granted.
getNumWorkerRequestsPending() - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
 
getNumWorkerRequestsPending() - Method in class org.apache.flink.yarn.YarnFlinkResourceManager
 
getNumWorkersPendingRegistration() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
 
getNumWorkersPendingRegistration() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Gets the number of containers that have been started, but where the TaskManager has not yet registered at the job manager.
getNumWorkersPendingRegistration() - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
 
getNumWorkersPendingRegistration() - Method in class org.apache.flink.yarn.YarnFlinkResourceManager
 
getNumWriteBehindBuffers(int) - Static method in class org.apache.flink.runtime.operators.hash.MutableHashTable
Determines the number of buffers to be used for asynchronous write behind.
getObjectReuseEnabled() - Method in class org.apache.flink.api.common.ArchivedExecutionConfig
 
getOccupancy() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
Gets the number of bytes currently occupied in this hash table.
getOccupancy() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
getOccupancy() - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
Gets the number of bytes currently occupied in this sorter, records and sort index.
getOccupancy() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
getOffHeapBuffer() - Method in class org.apache.flink.core.memory.HybridMemorySegment
Gets the buffer that owns the memory of this memory segment.
getOffset() - Method in interface org.apache.flink.core.fs.BlockLocation
Get the start offset of the file associated with this block.
getOffset() - Method in class org.apache.flink.core.fs.local.LocalBlockLocation
 
getOffset() - Method in class org.apache.flink.graph.generator.CirculantGraph.OffsetRange
Get the range offset
getOffset() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopBlockLocation
 
getOffset() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionState
The current offset in the partition.
getOffsetForKeyGroup(int) - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
 
getOffsetFromZooKeeper(CuratorFramework, String, String, int) - Static method in class org.apache.flink.streaming.connectors.kafka.internals.ZookeeperOffsetHandler
 
getOffsets() - Method in class org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo
 
getOldTaskStates() - Method in class org.apache.flink.migration.runtime.checkpoint.savepoint.SavepointV0
 
getOne() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
 
getOneMinuteRate() - Method in class org.apache.flink.dropwizard.metrics.FlinkMeterWrapper
 
getOpenBranches() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
getOpenFileHandlesLimit() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
Tries to retrieve the maximum number of open file handles.
getOpenTimeout() - Method in class org.apache.flink.api.common.io.FileInputFormat
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.dataSet.BatchTableSourceScanRule
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateRule
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateWithNullValuesRule
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetCalcRule
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetCorrelateRule
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetDistinctRule
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetIntersectRule
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetJoinRule
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetLogicalWindowAggregateRule
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetMinusRule
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetScanRule
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetSingleRowJoinRule
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetSortRule
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetUnionRule
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetValuesRule
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetWindowAggregateRule
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamCalcRule
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamCorrelateRule
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupAggregateRule
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupWindowAggregateRule
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamLogicalWindowAggregateRule
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamOverAggregateRule
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamScanRule
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamUnionRule
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamValuesRule
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.datastream.StreamTableSourceScanRule
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.logical.EnumerableToLogicalTableScan
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.logical.LogicalUnnestRule
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.logical.PushFilterIntoTableSourceScanRule
 
getOperand() - Static method in class org.apache.flink.table.plan.rules.logical.PushProjectIntoTableSourceScanRule
 
getOperandCountRange() - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
getOperandCountRange() - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
getOperandCountRange() - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
getOperandCountRange() - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.dataSet.BatchTableSourceScanRule
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateRule
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateWithNullValuesRule
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetCalcRule
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetCorrelateRule
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetDistinctRule
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetIntersectRule
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetJoinRule
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetLogicalWindowAggregateRule
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetMinusRule
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetScanRule
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetSingleRowJoinRule
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetSortRule
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetUnionRule
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetValuesRule
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetWindowAggregateRule
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamCalcRule
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamCorrelateRule
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupAggregateRule
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupWindowAggregateRule
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamLogicalWindowAggregateRule
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamOverAggregateRule
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamScanRule
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamUnionRule
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamValuesRule
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.datastream.StreamTableSourceScanRule
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.logical.EnumerableToLogicalTableScan
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.logical.LogicalUnnestRule
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.logical.PushFilterIntoTableSourceScanRule
 
getOperands() - Static method in class org.apache.flink.table.plan.rules.logical.PushProjectIntoTableSourceScanRule
 
getOperandTypeChecker() - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
getOperandTypeChecker() - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
getOperandTypeChecker() - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
getOperandTypeChecker() - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
getOperandTypeInference() - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
getOperandTypeInference() - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
getOperandTypeInference() - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
getOperandTypeInference() - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
getOperandTypeInfo(SqlCallBinding) - Method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils$
 
getOperandTypeInfo(SqlCallBinding) - Static method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils
 
getOperator() - Method in class org.apache.flink.optimizer.dag.BulkPartialSolutionNode
Gets the operator (here the BulkIterationBase.PartialSolutionPlaceHolder) that is represented by this optimizer node.
getOperator() - Method in class org.apache.flink.optimizer.dag.CoGroupNode
Gets the operator for this CoGroup node.
getOperator() - Method in class org.apache.flink.optimizer.dag.CoGroupRawNode
Gets the operator for this CoGroup node.
getOperator() - Method in class org.apache.flink.optimizer.dag.CrossNode
 
getOperator() - Method in class org.apache.flink.optimizer.dag.DataSinkNode
Gets the operator for which this optimizer sink node was created.
getOperator() - Method in class org.apache.flink.optimizer.dag.DataSourceNode
Gets the contract object for this data source node.
getOperator() - Method in class org.apache.flink.optimizer.dag.FilterNode
 
getOperator() - Method in class org.apache.flink.optimizer.dag.FlatMapNode
 
getOperator() - Method in class org.apache.flink.optimizer.dag.GroupCombineNode
Gets the operator represented by this optimizer node.
getOperator() - Method in class org.apache.flink.optimizer.dag.GroupReduceNode
Gets the operator represented by this optimizer node.
getOperator() - Method in class org.apache.flink.optimizer.dag.JoinNode
Gets the contract object for this match node.
getOperator() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
Gets the operator represented by this optimizer node.
getOperator() - Method in class org.apache.flink.optimizer.dag.OuterJoinNode
 
getOperator() - Method in class org.apache.flink.optimizer.dag.PartitionNode
 
getOperator() - Method in class org.apache.flink.optimizer.dag.ReduceNode
 
getOperator() - Method in class org.apache.flink.optimizer.dag.SingleInputNode
 
getOperator() - Method in class org.apache.flink.optimizer.dag.SolutionSetNode
Gets the contract object for this data source node.
getOperator() - Method in class org.apache.flink.optimizer.dag.SortPartitionNode
 
getOperator() - Method in class org.apache.flink.optimizer.dag.TwoInputNode
 
getOperator() - Method in class org.apache.flink.optimizer.dag.WorksetNode
Gets the contract object for this data source node.
getOperator() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getOperator() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
Returns the TwoInputStreamOperator of this Transformation.
getOperator() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
Returns the StreamSink that is the operator of this SinkTransformation.
getOperator() - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
Returns the StreamSource, the operator of this SourceTransformation.
getOperator() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
Returns the TwoInputStreamOperator of this Transformation.
getOperatorBackPressureStats(ExecutionJobVertex) - Method in class org.apache.flink.runtime.webmonitor.BackPressureStatsTracker
Returns back pressure statistics for a operator.
getOperatorChainIndex() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorStateHandles
 
getOperatorConfig() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getOperatorDescription() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
getOperatorFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
 
getOperatorID() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
 
getOperatorIDs() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
Returns a list containing the IDs of all operators contained in this execution job vertex.
getOperatorIDs() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
getOperatorInfo() - Method in class org.apache.flink.api.common.operators.DualInputOperator
Gets the information about the operators input/output types.
getOperatorInfo() - Method in class org.apache.flink.api.common.operators.Operator
Gets the information about the operators input/output types.
getOperatorInfo() - Method in class org.apache.flink.api.common.operators.SingleInputOperator
Gets the information about the operators input/output types.
getOperatorInfo() - Method in class org.apache.flink.optimizer.util.NoOpUnaryUdfOp
 
getOperatorLevelCachingDescription() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
Gets the operator-level caching description for this input.
getOperatorName() - Method in class org.apache.flink.optimizer.dag.BinaryUnionNode
 
getOperatorName() - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
 
getOperatorName() - Method in class org.apache.flink.optimizer.dag.BulkPartialSolutionNode
 
getOperatorName() - Method in class org.apache.flink.optimizer.dag.CoGroupNode
 
getOperatorName() - Method in class org.apache.flink.optimizer.dag.CoGroupRawNode
 
getOperatorName() - Method in class org.apache.flink.optimizer.dag.CrossNode
 
getOperatorName() - Method in class org.apache.flink.optimizer.dag.DataSinkNode
 
getOperatorName() - Method in class org.apache.flink.optimizer.dag.DataSourceNode
 
getOperatorName() - Method in class org.apache.flink.optimizer.dag.FilterNode
 
getOperatorName() - Method in class org.apache.flink.optimizer.dag.FlatMapNode
 
getOperatorName() - Method in class org.apache.flink.optimizer.dag.GroupCombineNode
 
getOperatorName() - Method in class org.apache.flink.optimizer.dag.GroupReduceNode
 
getOperatorName() - Method in class org.apache.flink.optimizer.dag.JoinNode
 
getOperatorName() - Method in class org.apache.flink.optimizer.dag.MapNode
 
getOperatorName() - Method in class org.apache.flink.optimizer.dag.MapPartitionNode
 
getOperatorName() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
Gets the name of this node, which is the name of the function/operator, or data source / data sink.
getOperatorName() - Method in class org.apache.flink.optimizer.dag.OuterJoinNode
 
getOperatorName() - Method in class org.apache.flink.optimizer.dag.PartitionNode
 
getOperatorName() - Method in class org.apache.flink.optimizer.dag.ReduceNode
 
getOperatorName() - Method in class org.apache.flink.optimizer.dag.SinkJoiner
 
getOperatorName() - Method in class org.apache.flink.optimizer.dag.SolutionSetNode
 
getOperatorName() - Method in class org.apache.flink.optimizer.dag.SortPartitionNode
 
getOperatorName() - Method in class org.apache.flink.optimizer.dag.UnaryOperatorNode
 
getOperatorName() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
 
getOperatorName() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode.SingleRootJoiner
 
getOperatorName() - Method in class org.apache.flink.optimizer.dag.WorksetNode
 
getOperatorName() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
getOperatorName() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getOperatorName() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getOperatorName() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
Return the operator name.
getOperatorPrettyName() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
getOperators() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getOperatorState(ListStateDescriptor<S>) - Method in interface org.apache.flink.api.common.state.OperatorStateStore
Deprecated.
since 1.3.0. This was deprecated as part of a refinement to the function names. Please use OperatorStateStore.getListState(ListStateDescriptor) instead.
getOperatorState() - Method in class org.apache.flink.migration.streaming.runtime.tasks.StreamTaskState
Deprecated.
 
getOperatorState(ListStateDescriptor<S>) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
Deprecated.
This was deprecated as part of a refinement to the function names. Please use DefaultOperatorStateBackend.getListState(ListStateDescriptor) instead.
getOperatorStateBackend() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getOperatorStateHandles() - Method in class org.apache.flink.runtime.state.StateInitializationContextImpl
 
getOperatorStateManagedFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotResult
 
getOperatorStateRawFuture() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotResult
 
getOperatorStates() - Method in class org.apache.flink.migration.runtime.checkpoint.savepoint.SavepointV0
 
getOperatorStates() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
getOperatorStates() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
getOperatorStates() - Method in interface org.apache.flink.runtime.checkpoint.savepoint.Savepoint
Returns the snapshotted operator states.
getOperatorStates() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
 
getOperatorStates() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
 
getOperatorStateStore() - Method in interface org.apache.flink.runtime.state.ManagedInitializationContext
Returns an interface that allows for registering operator state with the backend.
getOperatorStateStore() - Method in class org.apache.flink.runtime.state.StateInitializationContextImpl
 
getOperatorStateStreamFuture() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
 
getOperatorStrategyString(DriverStrategy) - Static method in class org.apache.flink.optimizer.plantranslate.JsonMapper
 
getOperatorStrategyString(DriverStrategy, String, String) - Static method in class org.apache.flink.optimizer.plantranslate.JsonMapper
 
getOptimizedPlan(Optimizer, PackagedProgram, int) - Static method in class org.apache.flink.client.program.ClusterClient
 
getOptimizedPlan(Optimizer, Plan, int) - Static method in class org.apache.flink.client.program.ClusterClient
 
getOptimizedPlan(PackagedProgram) - Method in class org.apache.flink.client.program.OptimizerPlanEnvironment
 
getOptimizedPlanAsJson(Optimizer, PackagedProgram, int) - Static method in class org.apache.flink.client.program.ClusterClient
 
getOptimizerNode() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
getOptimizerNode() - Method in class org.apache.flink.optimizer.plan.BinaryUnionPlanNode
 
getOptimizerNode() - Method in class org.apache.flink.optimizer.plan.PlanNode
 
getOptimizerNode() - Method in interface org.apache.flink.optimizer.plandump.DumpableNode
 
getOptimizerPlanAsJSON(Plan) - Method in class org.apache.flink.api.common.PlanExecutor
Gets the programs execution plan in a JSON format.
getOptimizerPlanAsJSON(Plan) - Method in class org.apache.flink.client.LocalExecutor
Creates a JSON representation of the given dataflow's execution plan.
getOptimizerPlanAsJSON(Plan) - Method in class org.apache.flink.client.RemoteExecutor
 
getOptimizerPlanAsJSON(OptimizedPlan) - Method in class org.apache.flink.optimizer.plandump.PlanJSONDumpGenerator
 
getOptimizerPropertiesJson(JsonFactory, PlanNode) - Static method in class org.apache.flink.optimizer.plantranslate.JsonMapper
 
getOptions() - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
Gets the options factory that lazily creates the RocksDB options.
getOrCreateKeyedState(TypeSerializer<N>, StateDescriptor<S, V>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
getOrCreateKeyedState(TypeSerializer<N>, StateDescriptor<S, T>) - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
Creates or retrieves a keyed state backed by this state backend.
getOrCreateKeyedState(TypeSerializer<N>, StateDescriptor<S, T>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getOrder(int) - Method in class org.apache.flink.api.common.operators.Ordering
 
getOrderdate() - Method in class org.apache.flink.examples.java.relational.TPCHQuery3.Order
 
getOrderdate() - Method in class org.apache.flink.examples.java.relational.TPCHQuery3.ShippingPriorityItem
 
getOrdering() - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
getOrdering() - Method in class org.apache.flink.optimizer.dataproperties.LocalProperties
Gets the key order.
getOrdering() - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
Gets the key order.
getOrdering() - Method in class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
Gets the key order.
getOrderkey() - Method in class org.apache.flink.examples.java.relational.TPCHQuery3.Lineitem
 
getOrderKey() - Method in class org.apache.flink.examples.java.relational.TPCHQuery3.Order
 
getOrderkey() - Method in class org.apache.flink.examples.java.relational.TPCHQuery3.ShippingPriorityItem
 
getOriginalErrorClassName() - Method in exception org.apache.flink.runtime.util.SerializedThrowable
 
getOriginalKeyFieldTypes() - Method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
getOriginalKeyFieldTypes() - Method in class org.apache.flink.api.common.operators.Keys
 
getOriginalKeyFieldTypes() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
getOriginalNameFromInternal(String) - Static method in class org.apache.flink.cep.nfa.compiler.NFAStateNameHandler
Implements the reverse process of the NFAStateNameHandler.getUniqueInternalName(String).
getOriginalOptimizerNode() - Method in class org.apache.flink.optimizer.plan.PlanNode
Gets the node from the optimizer DAG for which this plan candidate node was created.
getOriginalPlan() - Method in class org.apache.flink.optimizer.plan.OptimizedPlan
Gets the original program's dataflow plan from which this optimized plan was created.
getOutAggregateGroupExpression(RexBuilder, RexCall) - Method in class org.apache.flink.table.plan.rules.common.LogicalWindowAggregateRule
Returns the expression that replaces the window expression after the aggregation.
getOutAggregateGroupExpression(RexBuilder, RexCall) - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetLogicalWindowAggregateRule
Returns a zero literal of the correct type.
getOutAggregateGroupExpression(RexBuilder, RexCall) - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamLogicalWindowAggregateRule
Returns a zero literal of a timestamp type
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.dataSet.BatchTableSourceScanRule
 
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateRule
 
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateWithNullValuesRule
 
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetCalcRule
 
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetCorrelateRule
 
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetDistinctRule
 
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetIntersectRule
 
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetJoinRule
 
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetLogicalWindowAggregateRule
 
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetMinusRule
 
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetScanRule
 
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetSingleRowJoinRule
 
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetSortRule
 
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetUnionRule
 
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetValuesRule
 
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetWindowAggregateRule
 
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamCalcRule
 
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamCorrelateRule
 
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupAggregateRule
 
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupWindowAggregateRule
 
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamLogicalWindowAggregateRule
 
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamOverAggregateRule
 
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamScanRule
 
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamUnionRule
 
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamValuesRule
 
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.datastream.StreamTableSourceScanRule
 
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.logical.EnumerableToLogicalTableScan
 
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.logical.LogicalUnnestRule
 
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.logical.PushFilterIntoTableSourceScanRule
 
getOutConvention() - Static method in class org.apache.flink.table.plan.rules.logical.PushProjectIntoTableSourceScanRule
 
getOutDegree() - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees.Degrees
 
getOutDegree() - Method in class org.apache.flink.graph.spargel.GatherFunction
Retrieve the vertex out-degree (number of out-going edges).
getOutDegree() - Method in class org.apache.flink.graph.spargel.ScatterFunction
Retrieve the vertex out-degree (number of out-going edges).
getOutEdgeIndices() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getOutEdges(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getOutEdges() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getOutEdgesInOrder(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getOuterJoinType() - Method in class org.apache.flink.api.common.operators.base.OuterJoinOperatorBase
 
getOutgoingChannels() - Method in class org.apache.flink.optimizer.plan.PlanNode
Gets a list of all outgoing channels leading to successors.
getOutgoingConnections() - Method in class org.apache.flink.optimizer.dag.DataSinkNode
Gets all outgoing connections, which is an empty set for the data sink.
getOutgoingConnections() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
The list of outgoing connections from this node to succeeding tasks.
getOutgoingConnections() - Method in class org.apache.flink.optimizer.dag.SinkJoiner
 
getOutputCardinality() - Method in class org.apache.flink.api.common.operators.CompilerHints
 
getOutputCollector() - Method in class org.apache.flink.runtime.operators.BatchTask
 
getOutputCollector(AbstractInvokable, TaskConfig, ClassLoader, List<RecordWriter<?>>, int, int) - Static method in class org.apache.flink.runtime.operators.BatchTask
Creates the Collector for the given task, as described by the given configuration.
getOutputCollector() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
getOutputCollector() - Method in interface org.apache.flink.runtime.operators.TaskContext
 
getOutputComparator(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getOutputDataDistribution(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getOutputDirectoryMode() - Method in class org.apache.flink.api.common.io.FileOutputFormat
 
getOutputFilePath() - Method in class org.apache.flink.api.common.io.FileOutputFormat
 
getOutputPartitioner(int, ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getOutputSchema() - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
Returns the HCatSchema of the HCatRecord returned by this InputFormat.
getOutputSelector() - Method in class org.apache.flink.streaming.api.transformations.SplitTransformation
Returns the OutputSelector.
getOutputSelectors(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getOutputSelectors() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getOutputSerializer(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getOutputShipStrategy(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getOutputSize() - Method in class org.apache.flink.api.common.operators.CompilerHints
 
getOutputTag() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
 
getOutputTag() - Method in class org.apache.flink.streaming.api.transformations.SideOutputTransformation
 
getOutputType() - Method in class org.apache.flink.api.common.operators.OperatorInformation
Gets the return type of the user code function.
getOutputType() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
Returns the output type of this StreamTransformation as a TypeInformation.
getOutputType() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSink
 
getOutputType() - Method in class org.apache.flink.table.sinks.CsvTableSink
 
getOutputType() - Method in interface org.apache.flink.table.sinks.RetractStreamTableSink
 
getOutputType() - Method in interface org.apache.flink.table.sinks.TableSink
Return the type expected by this TableSink.
getOutputType() - Method in interface org.apache.flink.table.sinks.UpsertStreamTableSink
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.BatchTableSourceScanRule
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateRule
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateWithNullValuesRule
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetCalcRule
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetCorrelateRule
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetDistinctRule
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetIntersectRule
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetJoinRule
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetLogicalWindowAggregateRule
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetMinusRule
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetScanRule
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetSingleRowJoinRule
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetSortRule
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetUnionRule
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetValuesRule
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetWindowAggregateRule
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamCalcRule
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamCorrelateRule
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupAggregateRule
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupWindowAggregateRule
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamLogicalWindowAggregateRule
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamOverAggregateRule
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamScanRule
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamUnionRule
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamValuesRule
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.datastream.StreamTableSourceScanRule
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.logical.EnumerableToLogicalTableScan
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.logical.LogicalUnnestRule
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.logical.PushFilterIntoTableSourceScanRule
 
getOutTrait() - Static method in class org.apache.flink.table.plan.rules.logical.PushProjectIntoTableSourceScanRule
 
getOversizedRecordCount() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
Gets the number of oversized records handled by this combiner.
getOwner() - Method in class org.apache.flink.core.memory.MemorySegment
Gets the owner of this memory segment.
getOwner() - Method in class org.apache.flink.runtime.instance.Slot
Gets the owner of this slot.
getPackages() - Method in class org.apache.flink.runtime.util.DependencyVisitor
 
getPact() - Method in class org.apache.flink.table.explain.Node
 
getPactPlanAsJSON(List<DataSinkNode>) - Method in class org.apache.flink.optimizer.plandump.PlanJSONDumpGenerator
 
getPageRankScore() - Method in class org.apache.flink.graph.library.link_analysis.PageRank.Result
Get the PageRank score.
getPageSize() - Method in interface org.apache.flink.runtime.io.network.partition.consumer.InputGate
 
getPageSize() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
getPageSize() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
 
getPageSize() - Method in class org.apache.flink.runtime.memory.MemoryManager
Gets the size of the pages handled by the memory manager.
getPairComparator() - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
 
getPairComparatorFactory(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getPaneSize() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
Deprecated.
 
getParallelism() - Method in class org.apache.flink.api.common.ArchivedExecutionConfig
 
getParallelism() - Method in class org.apache.flink.api.common.ExecutionConfig
Gets the parallelism with which operation are executed by default.
getParallelism() - Method in class org.apache.flink.api.common.operators.Operator
Gets the parallelism for this contract instance.
getParallelism() - Method in class org.apache.flink.api.java.CollectionEnvironment
 
getParallelism() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Gets the parallelism with which operation are executed by default.
getParallelism() - Method in class org.apache.flink.api.java.operators.DataSink
Returns the parallelism of this data sink.
getParallelism() - Method in class org.apache.flink.api.java.operators.DeltaIteration
Gets the iteration's parallelism.
getParallelism() - Method in class org.apache.flink.api.java.operators.Operator
Returns the parallelism of this operator.
getParallelism() - Static method in class org.apache.flink.api.scala.CrossDataSet
 
getParallelism() - Method in class org.apache.flink.api.scala.DataSet
Returns the parallelism of this operation.
getParallelism() - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Returns the default parallelism for this execution environment.
getParallelism() - Method in class org.apache.flink.client.cli.ProgramOptions
 
getParallelism() - Method in class org.apache.flink.graph.IterationConfiguration
Gets the iteration's parallelism.
getParallelism() - Method in class org.apache.flink.migration.runtime.checkpoint.TaskState
Deprecated.
 
getParallelism() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
Gets the parallelism for the operator represented by this optimizer node.
getParallelism() - Method in class org.apache.flink.optimizer.plan.PlanNode
 
getParallelism() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
 
getParallelism() - Method in class org.apache.flink.runtime.checkpoint.TaskState
Deprecated.
 
getParallelism() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
Returns the parallelism for this job vertex.
getParallelism() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
 
getParallelism() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getParallelism() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
Gets the parallelism of the task.
getParallelism() - Method in class org.apache.flink.streaming.api.datastream.DataStream
Gets the parallelism for this operator.
getParallelism() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Gets the parallelism with which operation are executed by default.
getParallelism() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getParallelism() - Method in class org.apache.flink.streaming.api.scala.DataStream
Deprecated.
Use parallelism instead.
getParallelism() - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Returns the default parallelism for this execution environment.
getParallelism() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
Returns the parallelism of this StreamTransformation.
getParallelism() - Method in class org.apache.flink.streaming.util.StreamingProgramTestBase
 
getParallelism() - Method in class org.apache.flink.table.explain.Node
 
getParallelism() - Method in class org.apache.flink.test.util.JavaProgramTestBase
 
getParallelSubtaskIndex() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
Returns the subtask index of this execution.
getParallelSubtaskIndex() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
Returns the subtask index of this execution vertex.
getParallelSubtaskIndex() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
 
getParallelSubtaskIndex() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
 
getParallelSubtaskIndex() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
getParallelSubtaskIndex() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getParameters() - Method in class org.apache.flink.api.common.operators.Operator
Gets the stub parameters of this contract.
getParameters() - Method in class org.apache.flink.api.java.operators.DataSink
 
getParameters() - Method in class org.apache.flink.api.java.operators.DataSource
 
getParameters() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
 
getParameters() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
 
getParameters() - Method in interface org.apache.flink.api.java.operators.UdfOperator
Gets the configuration parameters that will be passed to the UDF's open method AbstractRichFunction.open(Configuration).
getParameterType(Class<?>, Class<?>, int) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getParameterTypes(RelDataTypeFactory) - Method in class org.apache.calcite.sql.validate.SqlUserDefinedAggFunction
 
getParameterTypes() - Method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils.LambdaExecutable
 
getParameterTypes() - Method in class org.apache.flink.runtime.rpc.akka.messages.LocalRpcInvocation
 
getParameterTypes() - Method in class org.apache.flink.runtime.rpc.akka.messages.RemoteRpcInvocation
 
getParameterTypes() - Method in interface org.apache.flink.runtime.rpc.akka.messages.RpcInvocation
Returns the method's parameter types
getParameterTypes(Class<?>[]) - Method in class org.apache.flink.table.functions.ScalarFunction
Returns TypeInformation about the operands of the evaluation method with a given signature.
getParameterTypes(RelDataTypeFactory) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
getParameterTypes(UserDefinedFunction, Class<?>[]) - Method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils$
 
getParameterTypes(UserDefinedFunction, Class<?>[]) - Static method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils
 
getParameterValues() - Method in class org.apache.flink.api.java.io.jdbc.split.GenericParameterValuesProvider
 
getParameterValues() - Method in class org.apache.flink.api.java.io.jdbc.split.NumericBetweenParametersProvider
 
getParameterValues() - Method in interface org.apache.flink.api.java.io.jdbc.split.ParameterValuesProvider
Returns the necessary parameters array to use for query in parallel a table
getParamNames() - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
getParamNames() - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
getParamNames() - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
getParamNames() - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
getParamTypes() - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
getParamTypes() - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
getParamTypes() - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
getParamTypes() - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
getParent() - Method in class org.apache.flink.core.fs.Path
Returns the parent of a path, i.e., everything that precedes the last separator or null if at root.
getParent() - Method in class org.apache.flink.runtime.instance.Slot
Gets the parent slot of this slot.
getParserForType(Class<T>) - Static method in class org.apache.flink.types.parser.FieldParser
Gets the parser for the type specified by the given class.
getPartialSolution() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
 
getPartialSolution() - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
Gets the partialSolution from this BulkIterationNode.
getPartialSolutionNode() - Method in class org.apache.flink.optimizer.plan.BulkPartialSolutionPlanNode
 
getPartialSolutionPlanNode() - Method in class org.apache.flink.optimizer.plan.BulkIterationPlanNode
 
getPartition() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartition
 
getPartition() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionState
 
getPartitionById(IntermediateResultPartitionID) - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
Returns the partition with the given ID.
getPartitionedFields() - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
Gets the fields on which the data is partitioned.
getPartitionedState(N, TypeSerializer<N>, StateDescriptor<S, ?>) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
TODO: NOTE: This method does a lot of work caching / retrieving states just to update the namespace.
getPartitionedState(N, TypeSerializer<N>, StateDescriptor<S, ?>) - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
Creates or retrieves a partitioned state backed by this state backend.
getPartitionedState(StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
Creates a partitioned state handle, using the state backend configured for this task.
getPartitionedState(N, TypeSerializer<N>, StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
Creates a partitioned state handle, using the state backend configured for this task.
getPartitionedState(StateDescriptor<S, ?>) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
Retrieves a State object that can be used to interact with fault-tolerant state that is scoped to the window and key of the current trigger invocation.
getPartitionedState(StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
getPartitioner() - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
Gets the custom partitioner used by this join, or null, if none is set.
getPartitioner() - Method in class org.apache.flink.api.java.operators.CoGroupOperator
Gets the custom partitioner used by this join, or null, if none is set.
getPartitioner() - Method in class org.apache.flink.api.java.operators.JoinOperator
Gets the custom partitioner used by this join, or null, if none is set.
getPartitioner() - Method in class org.apache.flink.api.scala.CoGroupDataSet
Gets the custom partitioner used by this join, or null, if none is set.
getPartitioner() - Method in class org.apache.flink.api.scala.JoinDataSet
Gets the custom partitioner used by this join, or null, if none is set.
getPartitioner() - Method in class org.apache.flink.optimizer.plan.Channel
 
getPartitioner() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
 
getPartitioner() - Method in class org.apache.flink.streaming.api.transformations.PartitionTransformation
Returns the StreamPartitioner that must be used for partitioning the elements of the input StreamTransformation.
getPartitionerTypes(Partitioner<T>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getPartitionerTypes(Partitioner<T>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
 
getPartitionId() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
 
getPartitionId() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
 
getPartitionId() - Method in class org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
 
getPartitionId() - Method in exception org.apache.flink.runtime.io.network.partition.PartitionNotFoundException
 
getPartitionId() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
 
getPartitionId() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionID
 
getPartitioning() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
 
getPartitioning() - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
Gets the partitioning property.
getPartitioningFanOutNoEstimates(int) - Static method in class org.apache.flink.runtime.operators.hash.MutableHashTable
Gets the number of partitions to be used for an initial hash-table, when no estimates are available.
getPartitioningFields() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
 
getPartitioningOrdering() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
 
getPartitionMethod() - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
getPartitionNumber() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
 
getPartitionNumber() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
Gets the partition number of this partition.
getPartitionNumber() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
Gets the partition number of this partition.
getPartitionOrdering() - Method in class org.apache.flink.api.common.operators.base.SortPartitionOperatorBase
 
getPartitionRequestInitialBackoff() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
getPartitionRequestMaxBackoff() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
getPartitions() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
 
getPartitionsByTopic(String, KafkaProducer<byte[], byte[]>) - Static method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
 
getPartitionsForTopic(List<String>, Properties) - Static method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer08
Send request to Kafka to get partitions for topic.
getPartitionStateChecker() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
getPartitionStateSerializer() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo
 
getPartitionStateSerializer() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo.Snapshot
 
getPartitionStateSerializerConfigSnapshot() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo.Snapshot
 
getPartitionType() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
 
getPartitionType() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
Returns the type of this result partition.
getPassword() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig
Retrieve the password.
getPath() - Method in class org.apache.flink.core.fs.FileInputSplit
Returns the path of the file containing this split's data.
getPath() - Method in interface org.apache.flink.core.fs.FileStatus
Returns the corresponding Path to the FileStatus.
getPath() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
 
getPath() - Method in class org.apache.flink.core.fs.Path
Return full path.
getPath() - Method in class org.apache.flink.examples.java.distcp.FileCopyTask
 
getPath() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
 
getPath() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
Returns the path to the underlying temporary file.
getPath() - Method in class org.apache.flink.runtime.webmonitor.history.ArchivedJson
 
getPathFile() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
Returns the path to the underlying temporary file as a File.
getPathForJob(JobID) - Static method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
Returns the JobID as a String (with leading slash).
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.checkpoints.CheckpointConfigHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.checkpoints.CheckpointStatsDetailsHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.checkpoints.CheckpointStatsDetailsSubtasksHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.checkpoints.CheckpointStatsHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.ClusterOverviewHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.CurrentJobIdsHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.CurrentJobsOverviewHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.DashboardConfigHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarAccessDeniedHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarDeleteHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarListHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarPlanHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarRunHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.JarUploadHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.JobAccumulatorsHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.JobCancellationHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.JobConfigHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.JobDetailsHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.JobExceptionsHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.JobManagerConfigHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.JobPlanHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.JobStoppingHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.JobVertexAccumulatorsHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.JobVertexBackPressureHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.JobVertexDetailsHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.JobVertexTaskManagersHandler
 
getPaths() - Method in interface org.apache.flink.runtime.webmonitor.handlers.RequestHandler
Returns an array of REST URL's under which this handler can be registered.
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.SubtaskCurrentAttemptDetailsHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.SubtaskExecutionAttemptAccumulatorsHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.SubtaskExecutionAttemptDetailsHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.SubtasksAllAccumulatorsHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.SubtasksTimesHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.TaskManagerLogHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.handlers.TaskManagersHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.metrics.JobManagerMetricsHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.metrics.JobMetricsHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.metrics.JobVertexMetricsHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.metrics.TaskManagerMetricsHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.RuntimeMonitorHandler
 
getPaths() - Method in class org.apache.flink.runtime.webmonitor.RuntimeMonitorHandlerBase
Returns an array of REST URL's under which this handler can be registered.
getPattern() - Method in class org.apache.flink.cep.PatternStream
 
getPattern() - Method in class org.apache.flink.cep.scala.PatternStream
 
getPendingCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
getPhone() - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Attributes
 
getPhysicalOptRuleSet() - Method in class org.apache.flink.table.api.TableEnvironment
Returns the physical optimization rule set for this environment including a custom RuleSet configuration.
getPhysicalOptRuleSet() - Method in interface org.apache.flink.table.calcite.CalciteConfig
Returns a custom physical optimization rule set.
getPipelineBreakingExchange(ExecutionMode) - Static method in enum org.apache.flink.runtime.io.network.DataExchangeMode
 
getPlace() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
getPlace_type() - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Places
 
getPlan(String...) - Method in interface org.apache.flink.api.common.Program
The method which is invoked by the compiler to get the job that is then compiled into an executable schedule.
getPlan() - Method in class org.apache.flink.client.program.JobWithJars
Returns the plan
getPlan() - Method in class org.apache.flink.client.program.PreviewPlanEnvironment
 
getPlanAsJSON(Plan) - Static method in class org.apache.flink.client.LocalExecutor
Creates a JSON representation of the given dataflow plan.
getPlanner() - Method in class org.apache.flink.table.api.TableEnvironment
Returns the Calcite RelOptPlanner of this TableEnvironment.
getPlanner() - Method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
getPlanNode() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
getPlanNode() - Method in class org.apache.flink.optimizer.plan.PlanNode
 
getPlanNode() - Method in interface org.apache.flink.optimizer.plandump.DumpableNode
 
getPlanWithJars() - Method in class org.apache.flink.client.program.PackagedProgram
Returns the plan with all required jars.
getPlanWithoutJars() - Method in class org.apache.flink.client.program.PackagedProgram
Returns the plan without the required jars when the files are already provided by the cluster.
getPointDataSet(ParameterTool, ExecutionEnvironment) - Method in class org.apache.flink.examples.scala.clustering.KMeans$
 
getPointDataSet(ParameterTool, ExecutionEnvironment) - Static method in class org.apache.flink.examples.scala.clustering.KMeans
 
getPoints() - Method in class org.apache.flink.metrics.datadog.DMetric
 
getPojoFieldAt(int) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
getPojoFieldMapping() - Method in class org.apache.flink.table.functions.utils.TableSqlFunction
Get additional mapping information if the returned table type is a POJO (POJO types have no deterministic field order).
getPort() - Method in class org.apache.flink.metrics.jmx.JMXReporter
 
getPort() - Method in class org.apache.flink.runtime.blob.BlobCache
 
getPort() - Method in class org.apache.flink.runtime.blob.BlobServer
Returns the port on which the server is listening.
getPort() - Method in interface org.apache.flink.runtime.blob.BlobService
Returns the port of the blob service.
getPort() - Method in class org.apache.flink.runtime.minicluster.StandaloneMiniCluster
 
getPort() - Method in class org.apache.flink.runtime.query.KvStateServerAddress
Returns the port of the KvStateServer.
getPort() - Method in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
Gets the port of the master (JobManager), where the program will be executed.
getPort() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig
 
getPortRangeFromString(String) - Static method in class org.apache.flink.util.NetUtils
Returns an iterator over available ports defined by the range definition.
getPos() - Method in class org.apache.flink.api.common.io.InputStreamFSInputWrapper
 
getPos() - Method in class org.apache.flink.core.fs.AbstractMultiFSDataInputStream
 
getPos() - Method in class org.apache.flink.core.fs.FSDataInputStream
Gets the current position in the input stream.
getPos() - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
 
getPos() - Method in class org.apache.flink.core.fs.FSDataOutputStream
Gets the position of the stream (non-negative), defined as the number of bytes from the beginning of the file to the current writing position.
getPos() - Method in class org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
getPos() - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
 
getPos() - Method in class org.apache.flink.core.fs.local.LocalDataOutputStream
 
getPos() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
 
getPos() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataOutputStream
 
getPos() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
 
getPos() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
 
getPos() - Method in class org.apache.flink.streaming.connectors.fs.StreamWriterBase
 
getPos() - Method in interface org.apache.flink.streaming.connectors.fs.Writer
Retrieves the current position, and thus size, of the output file.
getPosition() - Method in class org.apache.flink.api.common.typeutils.CompositeType.FlatFieldDescriptor
 
getPosition() - Method in class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
 
getPosition() - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
getPosition() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileSegment
 
getPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
 
getPossibleGlobalProperties() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorSingle
 
getPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
 
getPossibleLocalProperties() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorSingle
 
getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.BinaryUnionNode
 
getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
 
getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.CoGroupNode
 
getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.CoGroupRawNode
 
getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.CrossNode
 
getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.FilterNode
 
getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.FlatMapNode
 
getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.GroupCombineNode
 
getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.GroupReduceNode
 
getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.JoinNode
 
getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.MapNode
 
getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.MapPartitionNode
 
getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.OuterJoinNode
 
getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.PartitionNode
 
getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.ReduceNode
 
getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.SingleInputNode
 
getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.SinkJoiner
 
getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.SortPartitionNode
 
getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.TwoInputNode
 
getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.UnaryOperatorNode
 
getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
 
getPossibleProperties() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode.SingleRootJoiner
 
getPossibly_sensitive() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
getPostal_code() - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Attributes
 
getPostPassClassName() - Method in class org.apache.flink.api.common.Plan
Gets the optimizer post-pass class for this job.
getPQSize(KEY) - Method in class org.apache.flink.cep.operator.AbstractKeyedCEPPatternOperator
 
getPrecedenceList() - Static method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
getPrecision() - Static method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
getPredecessor() - Method in class org.apache.flink.optimizer.plan.SingleInputPlanNode
Gets the predecessor of this node, i.e.
getPredecessorNode() - Method in class org.apache.flink.optimizer.dag.DataSinkNode
Gets the predecessor of this node.
getPredecessorNode() - Method in class org.apache.flink.optimizer.dag.SingleInputNode
Gets the predecessor of this node.
getPredecessors() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
getPredecessors() - Method in class org.apache.flink.optimizer.plan.BulkPartialSolutionPlanNode
 
getPredecessors() - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
 
getPredecessors() - Method in class org.apache.flink.optimizer.plan.NAryUnionPlanNode
 
getPredecessors() - Method in class org.apache.flink.optimizer.plan.PlanNode
 
getPredecessors() - Method in class org.apache.flink.optimizer.plan.SingleInputPlanNode
 
getPredecessors() - Method in class org.apache.flink.optimizer.plan.SolutionSetPlanNode
 
getPredecessors() - Method in class org.apache.flink.optimizer.plan.SourcePlanNode
 
getPredecessors() - Method in class org.apache.flink.optimizer.plan.WorksetPlanNode
 
getPredecessors() - Method in interface org.apache.flink.optimizer.plandump.DumpableNode
Gets an iterator over the predecessors.
getPredecessors() - Method in class org.apache.flink.table.explain.Node
 
getPredefinedOptions() - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
Gets the currently set predefined options for RocksDB.
getPreExprs() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
 
getPreferredLocations() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
Gets the overall preferred execution location for this vertex's current execution.
getPreferredLocationsBasedOnInputs() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
Gets the location preferences of the vertex's current task execution, as determined by the locations of the predecessors from which it receives input data.
getPreferredLocationsBasedOnState() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
Gets the preferred location to execute the current task execution attempt, based on the state that the execution attempt will resume.
getPreferredResources() - Method in class org.apache.flink.api.common.operators.Operator
Gets the preferred resources for this contract instance.
getPreferredResources() - Method in class org.apache.flink.api.java.operators.DataSink
Returns the preferred resources of this data sink.
getPreferredResources() - Method in class org.apache.flink.api.java.operators.DeltaIteration
Gets the preferred resources from this iteration.
getPreferredResources() - Method in class org.apache.flink.api.java.operators.Operator
Returns the preferred resource of this operator.
getPreferredResources() - Method in class org.apache.flink.optimizer.plan.PlanNode
 
getPreferredResources() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
Gets the preferred resource for the task.
getPreferredResources() - Method in class org.apache.flink.streaming.api.datastream.DataStream
Gets the preferred resources for this operator.
getPreferredResources() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getPreferredResources() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
Gets the preferred resource of this stream transformation.
getPreProcessingOperationName() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
Gets the name of the pro-processing operation for this input.
getPreviewPlan() - Method in class org.apache.flink.client.program.PackagedProgram
Returns the analyzed plan without any optimizations.
getPrevious() - Method in class org.apache.flink.cep.pattern.Pattern
 
getPrevious() - Method in class org.apache.flink.cep.scala.pattern.Pattern
 
getPreviousGlobalAggregate(String) - Method in class org.apache.flink.runtime.iterative.task.RuntimeAggregatorRegistry
 
getPreviousIterationAggregate(String) - Method in interface org.apache.flink.api.common.functions.IterationRuntimeContext
 
getPreviousIterationAggregate(String) - Method in class org.apache.flink.graph.gsa.ApplyFunction
Get the aggregated value that an aggregator computed in the previous iteration.
getPreviousIterationAggregate(String) - Method in class org.apache.flink.graph.gsa.GatherFunction
Get the aggregated value that an aggregator computed in the previous iteration.
getPreviousIterationAggregate(String) - Method in class org.apache.flink.graph.gsa.SumFunction
Get the aggregated value that an aggregator computed in the previous iteration.
getPreviousIterationAggregate(String) - Method in class org.apache.flink.graph.pregel.ComputeFunction
Get the aggregated value that an aggregator computed in the previous iteration.
getPreviousIterationAggregate(String) - Method in class org.apache.flink.graph.spargel.GatherFunction
Get the aggregated value that an aggregator computed in the previous iteration.
getPreviousIterationAggregate(String) - Method in class org.apache.flink.graph.spargel.ScatterFunction
Get the aggregated value that an aggregator computed in the previous iteration.
getPreviousState() - Method in class org.apache.flink.cep.nfa.ComputationState
 
getPreviousType() - Method in exception org.apache.flink.optimizer.postpass.ConflictingFieldTypeInfoException
 
getPrincipal() - Method in class org.apache.flink.runtime.security.SecurityUtils.SecurityConfiguration
 
getPrincipal() - Method in class org.apache.flink.test.util.TestingSecurityContext.ClientSecurityConfiguration
 
getPrintStatusDuringExecution() - Method in class org.apache.flink.client.program.ClusterClient
 
getPriorExecutionAttempt(int) - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
Returns the execution for the given attempt number.
getPriorExecutionAttempt(int) - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
 
getPriorExecutionAttempt(int) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getPrivateState() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
 
getProber(TypeComparator<PT>, TypePairComparator<PT, T>) - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
 
getProber(TypeComparator<PT>, TypePairComparator<PT, T>) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
 
getProber(TypeComparator<PT>, TypePairComparator<PT, T>) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
 
getProbeSideBlockCount() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
 
getProbeSideChannel() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
 
getProbeSideComparator() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
getProbeSideRecordCount() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
 
getProcessingTimeService() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
Returns the ProcessingTimeService responsible for getting the current processing time and registering timers.
getProcessingTimeService() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
getProcessingTimeService() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
Returns the ProcessingTimeService responsible for telling the current processing time and registering timers.
getProcessingTimeTimersPerKeyGroup() - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
 
getProctimeAttribute() - Method in interface org.apache.flink.table.sources.DefinedProctimeAttribute
Defines a name of the processing-time attribute that represents Flink's processing-time.
getProducedDataSets() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getProducedDataSets() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
getProducedPartitions() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
 
getProducedPartitions() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getProducedPartitions() - Method in class org.apache.flink.runtime.taskmanager.Task
 
getProducedType() - Method in class org.apache.flink.addons.hbase.HBaseRowInputFormat
 
getProducedType() - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormat
 
getProducedType() - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormat
 
getProducedType() - Method in class org.apache.flink.api.java.io.AvroInputFormat
 
getProducedType() - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat
 
getProducedType() - Method in class org.apache.flink.api.java.io.RowCsvInputFormat
 
getProducedType() - Method in class org.apache.flink.api.java.io.TypeSerializerInputFormat
 
getProducedType() - Method in interface org.apache.flink.api.java.typeutils.ResultTypeQueryable
Gets the data type (as a TypeInformation) produced by this function or input format.
getProducedType() - Method in class org.apache.flink.contrib.tweetinputformat.io.SimpleTweetInputFormat
 
getProducedType() - Method in class org.apache.flink.graph.library.ConnectedComponents.CCMessenger
 
getProducedType() - Method in class org.apache.flink.graph.library.LabelPropagation.SendNewLabelToNeighbors
 
getProducedType() - Method in class org.apache.flink.graph.pregel.VertexCentricIteration.MessageCombinerUdf
 
getProducedType() - Method in class org.apache.flink.graph.utils.GraphUtils.MapTo
 
getProducedType() - Method in class org.apache.flink.hadoopcompatibility.mapred.HadoopMapFunction
 
getProducedType() - Method in class org.apache.flink.hadoopcompatibility.mapred.HadoopReduceCombineFunction
 
getProducedType() - Method in class org.apache.flink.hadoopcompatibility.mapred.HadoopReduceFunction
 
getProducedType() - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
 
getProducedType() - Method in class org.apache.flink.python.api.functions.PythonCoGroup
 
getProducedType() - Method in class org.apache.flink.python.api.functions.PythonMapPartition
 
getProducedType() - Method in class org.apache.flink.streaming.api.scala.KeySelectorWithType
 
getProducedType() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
 
getProducedType() - Method in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
 
getProducedType() - Method in class org.apache.flink.streaming.util.keys.KeySelectorUtil.ArrayKeySelector
 
getProducedType() - Method in class org.apache.flink.streaming.util.keys.KeySelectorUtil.ComparableKeySelector
 
getProducedType() - Method in class org.apache.flink.streaming.util.serialization.AbstractDeserializationSchema
 
getProducedType() - Method in class org.apache.flink.streaming.util.serialization.JSONKeyValueDeserializationSchema
 
getProducedType() - Method in class org.apache.flink.streaming.util.serialization.JsonRowDeserializationSchema
 
getProducedType() - Method in class org.apache.flink.streaming.util.serialization.KeyedDeserializationSchemaWrapper
 
getProducedType() - Method in class org.apache.flink.streaming.util.serialization.SimpleStringSchema
 
getProducedType() - Method in class org.apache.flink.streaming.util.serialization.TypeInformationKeyValueSerializationSchema
 
getProducedType() - Method in class org.apache.flink.streaming.util.serialization.TypeInformationSerializationSchema
 
getProducedType() - Method in class org.apache.flink.table.runtime.aggregate.DataSetSessionWindowAggregatePreProcessor
 
getProducedType() - Method in class org.apache.flink.table.runtime.aggregate.DataSetSlideTimeWindowAggFlatMapFunction
 
getProducedType() - Method in class org.apache.flink.table.runtime.aggregate.DataSetSlideTimeWindowAggReduceGroupFunction
 
getProducedType() - Method in class org.apache.flink.table.runtime.aggregate.DataSetWindowAggMapFunction
 
getProducedType() - Method in class org.apache.flink.table.runtime.CorrelateFlatMapRunner
 
getProducedType() - Method in class org.apache.flink.table.runtime.CRowCorrelateProcessRunner
 
getProducedType() - Method in class org.apache.flink.table.runtime.CRowInputJavaTupleOutputMapRunner
 
getProducedType() - Method in class org.apache.flink.table.runtime.CRowInputMapRunner
 
getProducedType() - Method in class org.apache.flink.table.runtime.CRowInputScalaTupleOutputMapRunner
 
getProducedType() - Method in class org.apache.flink.table.runtime.CRowOutputMapRunner
 
getProducedType() - Method in class org.apache.flink.table.runtime.CRowProcessRunner
 
getProducedType() - Method in class org.apache.flink.table.runtime.FlatJoinRunner
 
getProducedType() - Method in class org.apache.flink.table.runtime.FlatMapRunner
 
getProducedType() - Method in class org.apache.flink.table.runtime.io.CRowValuesInputFormat
 
getProducedType() - Method in class org.apache.flink.table.runtime.io.ValuesInputFormat
 
getProducedType() - Method in class org.apache.flink.table.runtime.MapRunner
 
getProducedType() - Method in class org.apache.flink.table.runtime.MapSideJoinRunner
 
getProducer() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
 
getProducer() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
 
getProducer() - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
 
getProducerId() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionID
 
getProfile_background_color() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getProfile_background_image_url() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getProfile_background_image_url_https() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getProfile_banner_url() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getProfile_image_url() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getProfile_image_url_https() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getProfile_link_color() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getProfile_sidebar_border_color() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getProfile_sidebar_fill_color() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getProfile_text_color() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getProgram() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
getProgramArgs() - Method in class org.apache.flink.client.cli.ProgramOptions
 
getProgramOperator() - Method in class org.apache.flink.optimizer.plan.PlanNode
Gets the program operator that this node represents in the plan.
getProgramSpecificOptions(Options) - Static method in class org.apache.flink.client.cli.CliFrontendParser
 
getProgress() - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyReporter
 
getProgress() - Method in class org.apache.flink.yarn.YarnResourceManager
 
getProgress() - Method in class org.apache.flink.yarn.YarnResourceManagerCallbackHandler
 
getProjectedFields() - Method in class org.apache.flink.table.plan.util.RefFieldAccessorVisitor
Returns the prefix of the nested field accesses
getProperties() - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns a Properties object from this ParameterTool
getProperties() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
Returns the properties of this checkpoint.
getProperties() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
getProperties() - Method in class org.apache.flink.runtime.checkpoint.RestoredCheckpointStats
Returns the properties of the restored checkpoint.
getProperties1() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual.GlobalPropertiesPair
 
getProperties1() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual.LocalPropertiesPair
 
getProperties2() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual.GlobalPropertiesPair
 
getProperties2() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual.LocalPropertiesPair
 
getPropertiesFromBrokerList(String) - Static method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
 
getPushChainDriverClass() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
 
getQuantifier() - Method in class org.apache.flink.cep.pattern.Pattern
 
getQuantifier() - Method in class org.apache.flink.cep.scala.pattern.Pattern
 
getQuantile(double) - Method in class org.apache.flink.metrics.HistogramStatistics
Returns the value for the given quantile based on the represented histogram statistics.
getQuery() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
getQuery() - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
getQuery() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
getQuery() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
getQuery() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
getQuery() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
getQuery() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
getQuery() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
getQuery() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
getQuery() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
getQuery() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
getQuery() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
getQuery() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
getQuery() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
getQuery() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
getQuery() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getQueryableStateConfig() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
getQueryableStateName() - Method in class org.apache.flink.api.common.state.StateDescriptor
Returns the queryable state name.
getQueryableStateName() - Method in class org.apache.flink.streaming.api.datastream.QueryableStateStream
Returns the name under which the state can be queried.
getQueryService() - Method in class org.apache.flink.runtime.metrics.MetricRegistry
 
getQueryServiceMetricInfo(CharacterFilter) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
Returns the metric query service scope for this group.
getRandomFilename(String) - Static method in class org.apache.flink.util.FileUtils
Constructs a random filename with the given prefix and a random part generated from hex characters.
getRandomGenerable() - Method in class org.apache.flink.graph.generator.random.BlockInfo
 
getRandomGenerables(long, int) - Method in class org.apache.flink.graph.generator.random.AbstractGeneratorFactory
 
getRandomGenerables(long, int) - Method in interface org.apache.flink.graph.generator.random.RandomGenerableFactory
The amount of work (elementCount * cyclerPerElement) is used to generate a list of blocks of work of near-equal size.
getRandomOddEvenEdges(int, int, long) - Static method in class org.apache.flink.test.testdata.ConnectedComponentsData
Creates random edges such that even numbered vertices are connected with even numbered vertices and odd numbered vertices only with other odd numbered ones.
getRandomString(Random, int, int) - Static method in class org.apache.flink.util.StringUtils
Creates a random string with a length within the given interval.
getRandomString(Random, int, int, char, char) - Static method in class org.apache.flink.util.StringUtils
Creates a random string with a length within the given interval.
getRangeIndex(T) - Method in class org.apache.flink.api.common.distributions.CommonRangeBoundaries
 
getRangeIndex(T) - Method in interface org.apache.flink.api.common.distributions.RangeBoundaries
Get the range index of record.
getRankDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.examples.java.relational.util.WebLogData
 
getRate() - Method in class org.apache.flink.dropwizard.metrics.DropwizardMeterWrapper
 
getRate() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxMeterMBean
 
getRate() - Method in interface org.apache.flink.metrics.Meter
Returns the current rate of events per second.
getRate() - Method in class org.apache.flink.metrics.MeterView
 
getRate() - Method in class org.apache.flink.metrics.util.TestMeter
 
getRawKeyedOperatorStateOutput() - Method in interface org.apache.flink.runtime.state.StateSnapshotContext
Returns an output stream for keyed state
getRawKeyedOperatorStateOutput() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
 
getRawKeyedState() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
 
getRawKeyedState() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
 
getRawKeyedState() - Method in class org.apache.flink.runtime.state.TaskStateHandles
 
getRawKeyedState() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorStateHandles
 
getRawKeyedStateHandles(OperatorState, KeyGroupRange) - Static method in class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
Collect rawKeyedStateHandles which have intersection with given KeyGroupRange from operatorState
getRawKeyedStateInputs() - Method in interface org.apache.flink.runtime.state.StateInitializationContext
Returns an iterable to obtain input streams for previously stored keyed state partitions that are assigned to this operator.
getRawKeyedStateInputs() - Method in class org.apache.flink.runtime.state.StateInitializationContextImpl
 
getRawOperatorState() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
 
getRawOperatorState() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
 
getRawOperatorState() - Method in class org.apache.flink.runtime.state.TaskStateHandles
 
getRawOperatorState() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorStateHandles
 
getRawOperatorStateInputs() - Method in interface org.apache.flink.runtime.state.StateInitializationContext
Returns an iterable to obtain input streams for previously stored operator state partitions that are assigned to this operator.
getRawOperatorStateInputs() - Method in class org.apache.flink.runtime.state.StateInitializationContextImpl
 
getRawOperatorStateOutput() - Method in interface org.apache.flink.runtime.state.StateSnapshotContext
Returns an output stream for operator state
getRawOperatorStateOutput() - Method in class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
 
getReadEndAfterSuperstepEnded() - Method in class org.apache.flink.runtime.iterative.concurrent.BlockingBackChannel
Called by iteration head after it has sent all input for the current superstep through the data channel (blocks iteration head).
getReaderForVersion(int, ClassLoader) - Static method in class org.apache.flink.runtime.state.KeyedBackendStateMetaInfoSnapshotReaderWriters
 
getReaderForVersion(int, ClassLoader) - Static method in class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters
 
getReadFields(int) - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
 
getReadFields(int) - Method in class org.apache.flink.api.common.operators.SemanticProperties.EmptySemanticProperties
 
getReadFields(int) - Method in interface org.apache.flink.api.common.operators.SemanticProperties
Returns the position indexes of all fields of an input that are accessed by a function.
getReadFields(int) - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
 
getReadFields(int) - Method in class org.apache.flink.optimizer.dag.BinaryUnionNode.UnionSemanticProperties
 
getReadingThread(ExceptionHandler<IOException>, MutableObjectIterator<E>, UnilateralSortMerger.CircularQueues<E>, LargeRecordHandler<E>, AbstractInvokable, TypeSerializer<E>, long) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
Creates the reading thread.
getReadPosition() - Method in class org.apache.flink.runtime.io.disk.RandomAccessInputView
 
getReadVersion() - Method in class org.apache.flink.core.io.VersionedIOReadableWritable
Returns the found serialization version.
getReadWriteLock() - Method in class org.apache.flink.runtime.blob.BlobServer
Returns the lock used to guard file accesses
getReason() - Method in class org.apache.flink.runtime.messages.checkpoint.DeclineCheckpoint
Gets the reason why the checkpoint was declined.
getReason() - Method in class org.apache.flink.runtime.registration.RegistrationResponse.Decline
Gets the reason for the rejection.
getRecord() - Method in class org.apache.flink.python.api.streaming.plan.PythonPlanReceiver
 
getRecord(boolean) - Method in class org.apache.flink.python.api.streaming.plan.PythonPlanReceiver
 
getRecord() - Method in class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
 
getRecord(boolean) - Method in class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
 
getRecord(int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
getRecord(T, int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
getRecord(int) - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
Gets the record at the given logical position.
getRecord(T, int) - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
Gets the record at the given logical position.
getRecord(int) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
getRecord(T, int) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
getRecordCount() - Method in class org.apache.flink.api.common.io.BlockInfo
Returns the recordCount.
getRecordCount() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
number of records in partition including garbage
getRecordsReadFromBlock() - Method in class org.apache.flink.api.java.io.AvroInputFormat
 
getRecordType() - Method in interface org.apache.flink.table.sinks.RetractStreamTableSink
Returns the requested record type
getRecordType() - Method in interface org.apache.flink.table.sinks.UpsertStreamTableSink
Returns the requested record type
getRecoverAllJobs() - Method in class org.apache.flink.runtime.messages.JobManagerMessages$
 
getRecoverAllJobs() - Static method in class org.apache.flink.runtime.messages.JobManagerMessages
 
getRecoveryMode(Configuration) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
Gets the recovery mode as configured, based on the ConfigConstants.HA_MODE config key.
getRecursionLevel() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
Gets this partition's recursion level.
getRecycler() - Method in class org.apache.flink.runtime.io.network.buffer.Buffer
 
getRedirectAddress(String, Tuple2<ActorGateway, Integer>) - Static method in class org.apache.flink.runtime.webmonitor.handlers.HandlerRedirectUtils
 
getRedirectResponse(String, String, boolean) - Static method in class org.apache.flink.runtime.webmonitor.handlers.HandlerRedirectUtils
 
getReduceFunction() - Method in class org.apache.flink.api.common.state.ReducingStateDescriptor
Returns the reduce function to be used for the reducing state.
getReducingState(ReducingStateDescriptor<T>) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Gets a handle to the system's key/value reducing state.
getReducingState(ReducingStateDescriptor<T>) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getReducingState(ReducingStateDescriptor<T>) - Method in interface org.apache.flink.api.common.state.KeyedStateStore
Gets a handle to the system's key/value reducing state.
getReducingState(ReducingStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
 
getReducingState(ReducingStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
getReducingState(ReducingStateDescriptor<T>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
 
getReducingState(ReducingStateDescriptor<T>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.PerWindowStateStore
 
getReference() - Method in class org.apache.flink.runtime.state.SharedStateRegistry.Result
 
getReferenceCount() - Method in class org.apache.flink.runtime.state.SharedStateRegistry.Result
 
getRefreshInterval() - Method in class org.apache.flink.runtime.webmonitor.WebMonitorConfig
 
getRefusedRegistrationPause() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getRegion() - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Attributes
 
getRegisteredClass() - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
getRegisteredExecutions() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getRegisteredExternalCatalog(String) - Method in class org.apache.flink.table.api.TableEnvironment
Gets a registered ExternalCatalog by name.
getRegisteredInstance(ResourceID) - Method in class org.apache.flink.runtime.instance.InstanceManager
 
getRegisteredInstanceById(InstanceID) - Method in class org.apache.flink.runtime.instance.InstanceManager
 
getRegisteredKryoTypes() - Method in class org.apache.flink.api.common.ExecutionConfig
Returns the registered Kryo types.
getRegisteredPojoTypes() - Method in class org.apache.flink.api.common.ExecutionConfig
Returns the registered POJO types.
getRegisteredStateNames() - Method in interface org.apache.flink.api.common.state.OperatorStateStore
Returns a set with the names of all currently registered states.
getRegisteredStateNames() - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
 
getRegisteredSubclassesToSerializerConfigSnapshots() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
 
getRegisteredTypesWithKryoSerializerClasses() - Method in class org.apache.flink.api.common.ExecutionConfig
Returns the registered types with their Kryo Serializer classes.
getRegisteredTypesWithKryoSerializers() - Method in class org.apache.flink.api.common.ExecutionConfig
Returns the registered types with Kryo Serializers.
getRegistrationId() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
Gets the ID that the ResourceManager assigned the registration.
getRegistrationId() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorToResourceManagerConnection
Gets the ID under which the TaskExecutor is registered at the ResourceManager.
getRegistrationName() - Method in class org.apache.flink.runtime.query.KvStateLocation
Returns the name under which the KvState instances have been registered.
getRegistrationName() - Method in class org.apache.flink.runtime.query.KvStateMessage.LookupKvStateLocation
Returns the name under which the KvState has been registered.
getRegistrationName() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
Returns the name under which the KvState has been registered.
getRegistrationName() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateUnregistered
Returns the name under which the KvState has been registered.
getRegistrationTimeout() - Method in class org.apache.flink.runtime.messages.JobClientMessages$
 
getRegistrationTimeout() - Static method in class org.apache.flink.runtime.messages.JobClientMessages
 
getRehashThreshold() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
 
getRelativeBackChannelMemory() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getRelativeInputMaterializationMemory(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getRelativeMemoryDriver() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getRelativeMemoryInput(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getRelativeMemoryLocalStrategy() - Method in class org.apache.flink.optimizer.plan.Channel
 
getRelativeMemoryPerSubTask() - Method in class org.apache.flink.optimizer.plan.PlanNode
Gets the memory dedicated to each sub-task for this node.
getRelativePath() - Method in class org.apache.flink.examples.java.distcp.FileCopyTask
 
getRelativeSolutionSetMemory() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getRelativeTempMemory() - Method in class org.apache.flink.optimizer.plan.Channel
Gets the memory for materializing the channel's result from this Channel.
getRelBuilder() - Method in class org.apache.flink.table.api.TableEnvironment
Returns the FlinkRelBuilder of this TableEnvironment.
getRelNode() - Method in class org.apache.flink.table.api.Table
 
getRelTypeName() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
getRelTypeName() - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
getRelTypeName() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
getRelTypeName() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
getRelTypeName() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
getRelTypeName() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
getRelTypeName() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
getRelTypeName() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
getRelTypeName() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
getRelTypeName() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
getRelTypeName() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
getRelTypeName() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
getRelTypeName() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
getRelTypeName() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
getRelTypeName() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
getRelTypeName() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getReplicatedInputFormat() - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
 
getReplication() - Method in interface org.apache.flink.core.fs.FileStatus
Get the replication factor of a file.
getReplication() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
 
getReplication() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
 
getReplicationFactor() - Method in class org.apache.flink.optimizer.plan.Channel
Returns the replication factor of the connection.
getReporter(MetricConfig) - Method in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
 
getReporter(MetricConfig) - Method in class org.apache.flink.metrics.ganglia.GangliaReporter
 
getReporter(MetricConfig) - Method in class org.apache.flink.metrics.graphite.GraphiteReporter
 
getReporterConfigurations() - Method in class org.apache.flink.runtime.metrics.MetricRegistryConfiguration
 
getReporters() - Method in class org.apache.flink.runtime.metrics.MetricRegistry
 
getRequestArchive() - Method in class org.apache.flink.runtime.messages.JobManagerMessages$
 
getRequestArchive() - Static method in class org.apache.flink.runtime.messages.JobManagerMessages
 
getRequestArchivedJobs() - Method in class org.apache.flink.runtime.messages.ArchiveMessages$
 
getRequestArchivedJobs() - Static method in class org.apache.flink.runtime.messages.ArchiveMessages
 
getRequestBlobManagerPort() - Method in class org.apache.flink.runtime.messages.JobManagerMessages$
 
getRequestBlobManagerPort() - Static method in class org.apache.flink.runtime.messages.JobManagerMessages
 
getRequestBroadcastVariablesWithReferences() - Method in class org.apache.flink.runtime.messages.TaskManagerMessages$
Accessor for the case object instance, to simplify Java interoperability.
getRequestBroadcastVariablesWithReferences() - Static method in class org.apache.flink.runtime.messages.TaskManagerMessages
Accessor for the case object instance, to simplify Java interoperability.
getRequestedChannelMax() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig
Retrieve the requested maximum channel number
getRequestedFrameMax() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig
Retrieve the requested maximum frame size
getRequestedHeartbeat() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig
Retrieve the requested heartbeat interval.
getRequestFuture() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
getRequestId() - Method in class org.apache.flink.runtime.query.netty.message.KvStateRequest
Returns the request ID.
getRequestId() - Method in class org.apache.flink.runtime.query.netty.message.KvStateRequestFailure
Returns the request ID responding to.
getRequestId() - Method in class org.apache.flink.runtime.query.netty.message.KvStateRequestResult
Returns the request ID responding to.
getRequestJobCounts() - Method in class org.apache.flink.runtime.messages.ArchiveMessages$
 
getRequestJobCounts() - Static method in class org.apache.flink.runtime.messages.ArchiveMessages
 
getRequestJobManagerStatus() - Method in class org.apache.flink.runtime.messages.JobManagerMessages$
 
getRequestJobManagerStatus() - Static method in class org.apache.flink.runtime.messages.JobManagerMessages
 
getRequestJobStatus(JobID) - Method in class org.apache.flink.runtime.messages.JobManagerMessages$
 
getRequestJobStatus(JobID) - Static method in class org.apache.flink.runtime.messages.JobManagerMessages
 
getRequestLeaderSessionID() - Method in class org.apache.flink.runtime.messages.JobManagerMessages$
 
getRequestLeaderSessionID() - Static method in class org.apache.flink.runtime.messages.JobManagerMessages
 
getRequestNumActiveConnections() - Method in class org.apache.flink.runtime.messages.TaskManagerMessages$
Accessor for the case object instance, to simplify Java interoperability.
getRequestNumActiveConnections() - Static method in class org.apache.flink.runtime.messages.TaskManagerMessages
Accessor for the case object instance, to simplify Java interoperability.
getRequestNumberRegisteredTaskManager() - Method in class org.apache.flink.runtime.messages.JobManagerMessages$
 
getRequestNumberRegisteredTaskManager() - Static method in class org.apache.flink.runtime.messages.JobManagerMessages
 
getRequestRegisteredTaskManagers() - Method in class org.apache.flink.runtime.messages.JobManagerMessages$
 
getRequestRegisteredTaskManagers() - Static method in class org.apache.flink.runtime.messages.JobManagerMessages
 
getRequestRunningJobs() - Method in class org.apache.flink.runtime.messages.JobManagerMessages$
 
getRequestRunningJobs() - Static method in class org.apache.flink.runtime.messages.JobManagerMessages
 
getRequestRunningJobsStatus() - Method in class org.apache.flink.runtime.messages.JobManagerMessages$
 
getRequestRunningJobsStatus() - Static method in class org.apache.flink.runtime.messages.JobManagerMessages
 
getRequestTaskManagerLog() - Method in class org.apache.flink.runtime.messages.TaskManagerMessages$
Accessor for the case object instance, to simplify Java interoperability.
getRequestTaskManagerLog() - Static method in class org.apache.flink.runtime.messages.TaskManagerMessages
Accessor for the case object instance, to simplify Java interoperability.
getRequestTaskManagerStdout() - Method in class org.apache.flink.runtime.messages.TaskManagerMessages$
Accessor for the case object instance, to simplify Java interoperability.
getRequestTaskManagerStdout() - Static method in class org.apache.flink.runtime.messages.TaskManagerMessages
Accessor for the case object instance, to simplify Java interoperability.
getRequestTotalNumberOfSlots() - Method in class org.apache.flink.runtime.messages.JobManagerMessages$
 
getRequestTotalNumberOfSlots() - Static method in class org.apache.flink.runtime.messages.JobManagerMessages
 
getRequestWebMonitorPort() - Method in class org.apache.flink.runtime.messages.JobManagerMessages$
 
getRequestWebMonitorPort() - Static method in class org.apache.flink.runtime.messages.JobManagerMessages
 
getRequired(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the String value for the given key.
getRequiredClasspaths() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Returns a list of classpaths referring to the directories/JAR files required to run this job
getRequiredClasspaths() - Method in class org.apache.flink.runtime.jobmaster.message.ClassloadingProps
 
getRequiredClasspathURLs() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
 
getRequiredColumns() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
getRequiredGlobalProps() - Method in class org.apache.flink.optimizer.plan.Channel
 
getRequiredJarFileBlobKeys() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
 
getRequiredJarFiles() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Returns a list of BLOB keys referring to the JAR files required to run this job
getRequiredJarFiles() - Method in class org.apache.flink.runtime.jobmaster.message.ClassloadingProps
 
getRequiredLocalProps() - Method in class org.apache.flink.optimizer.plan.Channel
 
getResize() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Size
 
getResourceID() - Method in class org.apache.flink.mesos.runtime.clusterframework.RegisteredMesosWorkerNode
 
getResourceID() - Method in class org.apache.flink.runtime.clusterframework.messages.NotifyResourceStarted
 
getResourceID() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceID
A ResourceID can always retrieve a ResourceID.
getResourceID() - Method in interface org.apache.flink.runtime.clusterframework.types.ResourceIDRetrievable
Gets the ResourceID of the object.
getResourceID() - Method in class org.apache.flink.runtime.clusterframework.types.SlotID
 
getResourceID() - Method in class org.apache.flink.runtime.jobmaster.JMTMRegistrationSuccess
 
getResourceID() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
getResourceID() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
getResourceID() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
Gets the ID of the resource in which the TaskManager is started.
getResourceID() - Method in class org.apache.flink.yarn.RegisteredYarnWorkerNode
 
getResourceID() - Method in class org.apache.flink.yarn.YarnContainerInLaunch
 
getResourceIdString() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceID
Gets the Resource Id as string
getResourceManagerAkkaConfig(int) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
getResourceManagerBindAddress() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
getResourceManagerClass() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosApplicationMasterRunner
 
getResourceManagerClass() - Method in class org.apache.flink.yarn.YarnApplicationMasterRunner
 
getResourceManagerId() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
Gets the unique ID that identifies the ResourceManager.
getResourceManagerId() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorToResourceManagerConnection
Gets the unique id of ResourceManager, that is returned when registration success.
getResourceManagerLeaderElectionService() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
Gets the leader election service for the cluster's resource manager.
getResourceManagerLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
 
getResourceManagerLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
 
getResourceManagerLeaderElectionService() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
getResourceManagerLeaderElectionService() - Method in class org.apache.flink.yarn.highavailability.YarnIntraNonHaMasterServices
 
getResourceManagerLeaderElectionService() - Method in class org.apache.flink.yarn.highavailability.YarnPreConfiguredMasterNonHaServices
 
getResourceManagerLeaderId() - Method in class org.apache.flink.runtime.jobmaster.JobMasterRegistrationSuccess
 
getResourceManagerLeaderRetriever() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
Gets the leader retriever for the cluster's resource manager.
getResourceManagerLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedHaServices
 
getResourceManagerLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
 
getResourceManagerLeaderRetriever() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
getResourceManagerLeaderRetriever() - Method in class org.apache.flink.yarn.highavailability.YarnIntraNonHaMasterServices
 
getResourceManagerLeaderRetriever() - Method in class org.apache.flink.yarn.highavailability.YarnPreConfiguredMasterNonHaServices
 
getResourceManagerName(int) - Method in class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
getResourceManagerProps(Class<? extends FlinkResourceManager>, Configuration, LeaderRetrievalService) - Static method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
 
getResourceManagerProps(Class<? extends FlinkResourceManager<? extends ResourceIDRetrievable>>, Configuration, LeaderRetrievalService) - Method in class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
getResourceManagerResourceId() - Method in class org.apache.flink.runtime.jobmaster.JobMasterRegistrationSuccess
 
getResourceProfile() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
getResourceProfile() - Method in class org.apache.flink.runtime.jobmanager.slots.AllocatedSlot
Gets the resource profile of the slot.
getResourceProfile() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
getResourceProfile() - Method in class org.apache.flink.runtime.resourcemanager.SlotRequest
Get the resource profile of the desired slot
getResourceProfile() - Method in class org.apache.flink.runtime.taskexecutor.slot.SlotOffer
 
getResourceProfile() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
 
getResourceProfile() - Method in class org.apache.flink.runtime.taskexecutor.SlotStatus
Get the resource profile of this slot
getResources() - Method in class org.apache.flink.runtime.instance.Instance
 
getRestartAttempts() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FixedDelayRestartStrategyConfiguration
 
getRestartStrategy() - Method in class org.apache.flink.api.common.ExecutionConfig
Returns the restart strategy which has been set for the current job.
getRestartStrategy() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Returns the specified restart strategy configuration.
getRestartStrategy() - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Returns the specified restart strategy configuration.
getRestartStrategy() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getRestartStrategy() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Returns the specified restart strategy configuration.
getRestartStrategy() - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Returns the specified restart strategy configuration.
getRestartStrategyDescription() - Method in class org.apache.flink.api.common.ArchivedExecutionConfig
 
getRestorePath() - Method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
Returns the path to the savepoint to restore from.
getRestoreTimestamp() - Method in class org.apache.flink.runtime.checkpoint.RestoredCheckpointStats
Returns the timestamp when the checkpoint was restored.
getResult(ACC) - Method in interface org.apache.flink.api.common.functions.AggregateFunction
Gets the result of the aggregation from the accumulator.
getResult(ACC) - Method in class org.apache.flink.api.common.functions.RichAggregateFunction
 
getResult() - Method in class org.apache.flink.graph.asm.dataset.ChecksumHashCode
 
getResult() - Method in class org.apache.flink.graph.asm.dataset.Collect
 
getResult() - Method in class org.apache.flink.graph.asm.dataset.Count
 
getResult() - Method in interface org.apache.flink.graph.asm.dataset.DataSetAnalytic
This method must be called after the program has executed: 1) "run" analytics and algorithms 2) call ExecutionEnvironment.execute() 3) get analytic results
getResult() - Method in class org.apache.flink.graph.drivers.SimpleDriver
 
getResult() - Method in interface org.apache.flink.graph.GraphAnalytic
This method must be called after the program has executed: 1) "run" analytics and algorithms 2) call ExecutionEnvironment.execute() 3) get analytic results
getResult() - Method in class org.apache.flink.graph.library.clustering.directed.AverageClusteringCoefficient
 
getResult() - Method in class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient
 
getResult() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus
 
getResult() - Method in class org.apache.flink.graph.library.clustering.undirected.AverageClusteringCoefficient
 
getResult() - Method in class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient
 
getResult() - Method in class org.apache.flink.graph.library.clustering.undirected.TriadicCensus
 
getResult() - Method in class org.apache.flink.graph.library.metric.ChecksumHashCode
 
getResult() - Method in class org.apache.flink.graph.library.metric.directed.EdgeMetrics
 
getResult() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics
 
getResult() - Method in class org.apache.flink.graph.library.metric.undirected.EdgeMetrics
 
getResult() - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics
 
getResult(Row) - Method in class org.apache.flink.table.runtime.aggregate.AggregateAggFunction
 
getResultId() - Method in class org.apache.flink.runtime.deployment.PartialInputChannelDeploymentDescriptor
 
getResultId() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
 
getResultInputStream(String) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
getResultInputStream(String, String[]) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
getResultOptimizerProperties() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
getResultPartitionConsumableNotifier() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
getResultPartitionManager() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
getResultReader(String) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
getResultReader(String, String[], boolean) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
getResultsFormated(Map<String, Object>) - Static method in class org.apache.flink.api.common.accumulators.AccumulatorHelper
 
getResultType() - Method in class org.apache.flink.api.java.operators.Operator
Returns the type of the result of this operator.
getResultType() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
 
getResultType() - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
 
getResultType() - Method in class org.apache.flink.table.functions.aggfunctions.CountAggFunction
 
getResultType(Class<?>[]) - Method in class org.apache.flink.table.functions.ScalarFunction
Returns the result type of the evaluation method with a given signature.
getResultType() - Method in class org.apache.flink.table.functions.TableFunction
Returns the result type of the evaluation method with a given signature.
getResultTypeClassOfScalarFunction(ScalarFunction, Class<?>[]) - Method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils$
Returns the return type of the evaluation method matching the given signature.
getResultTypeClassOfScalarFunction(ScalarFunction, Class<?>[]) - Static method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils
Returns the return type of the evaluation method matching the given signature.
getResultTypeOfAggregateFunction(AggregateFunction<?, ?>, TypeInformation<?>) - Method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils$
Internal method of AggregateFunction#getResultType() that does some pre-checking and uses TypeExtractor as default return type inference.
getResultTypeOfAggregateFunction(AggregateFunction<?, ?>, TypeInformation<?>) - Static method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils
Internal method of AggregateFunction#getResultType() that does some pre-checking and uses TypeExtractor as default return type inference.
getResultTypeOfScalarFunction(ScalarFunction, Class<?>[]) - Method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils$
Internal method of ScalarFunction#getResultType() that does some pre-checking and uses TypeExtractor as default return type inference.
getResultTypeOfScalarFunction(ScalarFunction, Class<?>[]) - Static method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils
Internal method of ScalarFunction#getResultType() that does some pre-checking and uses TypeExtractor as default return type inference.
getReturnQueue() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockReader
Gets the queue in which the full memory segments are queued after the asynchronous read is complete.
getReturnQueue() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockWriter
Gets the queue in which the memory segments are queued after the asynchronous write is completed.
getReturnQueue() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BlockChannelReader
Gets the queue in which the full memory segments are queued after the read is complete.
getReturnQueue() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BlockChannelWriter
Gets the queue in which the memory segments are queued after the asynchronous write is completed
getReturnType(RelDataTypeFactory) - Method in class org.apache.calcite.sql.validate.SqlUserDefinedAggFunction
 
getReturnType() - Method in class org.apache.flink.addons.hbase.HBaseTableSource
 
getReturnType() - Method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils.LambdaExecutable
 
getReturnType() - Method in class org.apache.flink.streaming.connectors.kafka.KafkaTableSource
 
getReturnType(RelDataTypeFactory) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
getReturnType() - Method in class org.apache.flink.table.sources.CsvTableSource
Returns the RowTypeInfo for the return type of the CsvTableSource.
getReturnType() - Method in interface org.apache.flink.table.sources.TableSource
Returns the TypeInformation for the return type of the TableSource.
getReturnTypeInference() - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
getReturnTypeInference() - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
getReturnTypeInference() - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
getReturnTypeInference() - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
getRetweet_count() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
getRetweeted_status() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
getReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
getReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.FullOuterJoinDriver
 
getReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.LeftOuterJoinDriver
 
getReusingOuterJoinIterator(DriverStrategy, MutableObjectIterator<IT1>, MutableObjectIterator<IT2>, TypeSerializer<IT1>, TypeComparator<IT1>, TypeSerializer<IT2>, TypeComparator<IT2>, TypePairComparatorFactory<IT1, IT2>, MemoryManager, IOManager, double) - Method in class org.apache.flink.runtime.operators.RightOuterJoinDriver
 
getRevenue() - Method in class org.apache.flink.examples.java.relational.TPCHQuery3.ShippingPriorityItem
 
getRevisionInformation() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
Returns the code revision (commit and commit date) of Flink, as generated by the Maven builds.
getRexBuilder() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
 
getRexBuilder() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Returns the row-expression builder.
getRexBuilder() - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
getRight() - Method in class org.apache.flink.cep.pattern.AndFilterFunction
Deprecated.
 
getRight() - Method in class org.apache.flink.cep.pattern.conditions.AndCondition
 
getRight() - Method in class org.apache.flink.cep.pattern.conditions.OrCondition
 
getRight() - Method in class org.apache.flink.cep.pattern.OrFilterFunction
Deprecated.
 
getRight() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
getRight() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
getRightPrec() - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
getRightPrec() - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
getRightPrec() - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
getRightPrec() - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
getRightType() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
 
getRoot() - Method in class org.apache.flink.runtime.instance.Slot
Gets the root slot of the tree containing this slot.
getRootOfStepFunction() - Method in class org.apache.flink.optimizer.plan.BulkIterationPlanNode
 
getRootOfTerminationCriterion() - Method in class org.apache.flink.optimizer.plan.BulkIterationPlanNode
 
getRootSlotNumber() - Method in class org.apache.flink.runtime.instance.Slot
Gets the number of the root slot.
getRow(CRow) - Method in class org.apache.flink.table.runtime.aggregate.CRowTimeWindowPropertyCollector
 
getRow(Row) - Method in class org.apache.flink.table.runtime.aggregate.RowTimeWindowPropertyCollector
 
getRow(T) - Method in class org.apache.flink.table.runtime.aggregate.TimeWindowPropertyCollector
 
getRowCount(Calc, RelMetadataQuery) - Method in class org.apache.flink.table.plan.cost.FlinkRelMdRowCount$
 
getRowCount(DataSetSort, RelMetadataQuery) - Method in class org.apache.flink.table.plan.cost.FlinkRelMdRowCount$
 
getRowCount(Calc, RelMetadataQuery) - Static method in class org.apache.flink.table.plan.cost.FlinkRelMdRowCount
 
getRowCount(DataSetSort, RelMetadataQuery) - Static method in class org.apache.flink.table.plan.cost.FlinkRelMdRowCount
 
getRowCount() - Method in class org.apache.flink.table.plan.stats.FlinkStatistic
Returns the number of rows of the table.
getRows() - Method in class org.apache.flink.table.plan.cost.DataSetCost
 
getRows() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
getRows() - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
getRows() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
getRows() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
getRows() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
getRows() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
getRows() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
getRows() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
getRows() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
getRows() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
getRows() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
getRows() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
getRows() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
getRows() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
getRows() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
getRows() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getRowtimeAttribute() - Method in interface org.apache.flink.table.sources.DefinedRowtimeAttribute
Defines a name of the event-time attribute that represents Flink's event-time.
getRowType(String) - Method in class org.apache.flink.table.api.TableEnvironment
 
getRowType(RelDataTypeFactory, List<SqlNode>) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
getRowType() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
getRowType() - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
getRowType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
getRowType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
getRowType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
getRowType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
getRowType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
getRowType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
getRowType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
getRowType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
getRowType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
getRowType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
getRowType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
getRowType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
getRowType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
getRowType() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getRowType(RelDataTypeFactory) - Static method in class org.apache.flink.table.plan.schema.DataSetTable
 
getRowType(RelDataTypeFactory) - Method in class org.apache.flink.table.plan.schema.DataStreamTable
 
getRowType(RelDataTypeFactory) - Method in class org.apache.flink.table.plan.schema.FlinkTable
 
getRowType(RelDataTypeFactory, List<Object>) - Method in class org.apache.flink.table.plan.schema.FlinkTableFunctionImpl
 
getRowType(RelDataTypeFactory) - Method in class org.apache.flink.table.plan.schema.RelTable
 
getRowType(RelDataTypeFactory) - Method in class org.apache.flink.table.plan.schema.StreamTableSourceTable
 
getRowType(RelDataTypeFactory) - Static method in class org.apache.flink.table.plan.schema.TableSourceTable
 
getRowTypeInfo() - Method in class org.apache.flink.table.functions.utils.TableSqlFunction
Get the type information of the table returned by the table function.
getRpcService() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
Gets the endpoint's RPC service.
getRpcTimeout() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
getRpcUrl(String, int, String, HighAvailabilityServicesUtils.AddressResolution, Configuration) - Static method in class org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils
 
getRpcUrl(String, int, String, HighAvailabilityServicesUtils.AddressResolution, AkkaRpcServiceUtils.AkkaProtocol) - Static method in class org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils
 
getRunnable() - Method in class org.apache.flink.runtime.rpc.akka.messages.RunAsync
 
getRunning() - Method in class org.apache.flink.client.cli.ListOptions
 
getRunningJobs() - Method in class org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails
 
getRunningJobsRegistry() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
Gets the registry that holds information about whether jobs are currently running.
getRunningJobsRegistry() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
 
getRunningJobsRegistry() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
getRunningJobsRegistry() - Method in class org.apache.flink.yarn.highavailability.AbstractYarnNonHaServices
 
getRuntimeContext() - Method in class org.apache.flink.api.common.functions.AbstractRichFunction
 
getRuntimeContext() - Method in interface org.apache.flink.api.common.functions.RichFunction
Gets the context that contains information about the UDF's runtime, such as the parallelism of the function, the subtask index of the function, or the name of the of the task that executes the function.
getRuntimeContext() - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
 
getRuntimeContext() - Method in class org.apache.flink.api.common.io.RichInputFormat
 
getRuntimeContext() - Method in class org.apache.flink.api.common.io.RichOutputFormat
 
getRuntimeContext() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
Returns a context that allows the operator to query information about the execution and also to interact with systems such as broadcast variables and managed state.
getRuntimeContext() - Method in class org.apache.flink.streaming.api.scala.function.util.ScalaAllWindowFunctionWrapper
 
getRuntimeContext() - Method in class org.apache.flink.streaming.api.scala.function.util.ScalaWindowFunctionWrapper
 
getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
 
getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
 
getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
 
getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
 
getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
 
getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
 
getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
 
getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
 
getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
 
getRuntimeContext() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
 
getSafetyNetCloseableRegistryForThread() - Static method in class org.apache.flink.core.fs.FileSystemSafetyNet
Deprecated.
This method should be removed after FLINK-6684 is implemented.
getSalarySource(StreamExecutionEnvironment, long) - Method in class org.apache.flink.streaming.scala.examples.join.WindowJoinSampleData$
Continuously generates (name, salary).
getSalarySource(StreamExecutionEnvironment, long) - Static method in class org.apache.flink.streaming.scala.examples.join.WindowJoinSampleData
Continuously generates (name, salary).
getSampleId() - Method in class org.apache.flink.runtime.messages.StackTraceSampleResponse
 
getSampleId() - Method in class org.apache.flink.runtime.webmonitor.OperatorBackPressureStats
Returns the ID of the sample.
getSampleId() - Method in class org.apache.flink.runtime.webmonitor.StackTraceSample
Returns the ID of the sample.
getSamples() - Method in class org.apache.flink.runtime.messages.StackTraceSampleResponse
 
getSavepointPath() - Method in class org.apache.flink.client.cli.SavepointOptions
 
getSavepointRestoreSettings() - Method in class org.apache.flink.client.cli.ProgramOptions
 
getSavepointRestoreSettings() - Method in class org.apache.flink.client.program.ContextEnvironment
 
getSavepointRestoreSettings() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Returns the configured savepoint restore setting.
getSavepointSettings() - Method in class org.apache.flink.client.program.PackagedProgram
 
getSavepointTargetDirectory() - Method in class org.apache.flink.client.cli.CancelOptions
 
getScalaFuture() - Method in class org.apache.flink.runtime.concurrent.impl.FlinkFuture
 
getScalarFunction() - Method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
getScale() - Static method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
getScanner() - Method in class org.apache.flink.addons.hbase.AbstractTableInputFormat
Returns an instance of Scan that retrieves the required subset of records from the HBase table.
getScanner() - Method in class org.apache.flink.addons.hbase.HBaseRowInputFormat
 
getScanner() - Method in class org.apache.flink.addons.hbase.TableInputFormat
Returns an instance of Scan that retrieves the required subset of records from the HBase table.
getScatterBcastVars() - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
Get the broadcast variables of the ScatterFunction.
getScheduled() - Method in class org.apache.flink.client.cli.ListOptions
 
getScheduledExecutor() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
getScheduledExecutor() - Method in interface org.apache.flink.runtime.rpc.RpcService
Gets a scheduled executor from the RPC service.
getScheduleMode() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getScheduleMode() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
 
getSchema(Schema, Schema) - Static method in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter.AvroKeyValue
Creates a KeyValuePair generic record schema.
getSchema() - Method in class org.apache.flink.table.api.Table
Returns the schema of this table.
getScopeComponents() - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
 
getScopeComponents() - Method in interface org.apache.flink.metrics.MetricGroup
Gets the scope as an array of the scope components, for example ["host-7", "taskmanager-2", "window_word_count", "my-mapper"]
getScopeComponents() - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
Gets the scope as an array of the scope components, for example ["host-7", "taskmanager-2", "window_word_count", "my-mapper"]
getScopeComponents() - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
getScopeFormats() - Method in class org.apache.flink.runtime.metrics.MetricRegistry
 
getScopeFormats() - Method in class org.apache.flink.runtime.metrics.MetricRegistryConfiguration
 
getScreen_name() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.UserMention
 
getScreen_name() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getScreenName() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Contributors
 
getSecondDegree() - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.EdgeWithDegrees
 
getSecondDegree() - Method in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
 
getSecondIncomingConnection() - Method in class org.apache.flink.optimizer.dag.TwoInputNode
Gets the DagConnection through which this node receives its second input.
getSecondInput() - Method in class org.apache.flink.api.common.operators.DualInputOperator
Returns the second input, or null, if none is set.
getSecondInput() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
Returns the second DataStream.
getSecondInputType() - Method in class org.apache.flink.api.common.operators.BinaryOperatorInformation
 
getSecondPredecessorNode() - Method in class org.apache.flink.optimizer.dag.TwoInputNode
 
getSecondVertex() - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Edge
 
getSecondVertex() - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.EdgeWithDegrees
 
getSecondVertex() - Method in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
 
getSecondVertex() - Method in class org.apache.flink.graph.library.TriangleEnumerator.Triad
 
getSecurityModules() - Method in class org.apache.flink.runtime.security.SecurityUtils.SecurityConfiguration
 
getSeekedStreamForOffset(long) - Method in class org.apache.flink.core.fs.AbstractMultiFSDataInputStream
Delivers a the right stream for the given global stream offset.
getSegmentsForReaders(List<List<MemorySegment>>, List<MemorySegment>, int) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Divides the given collection of memory buffers among numChannels sublists.
getSegmentSize() - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
Gets the size of the segments used by this view.
getSelectedNames() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
 
getSelectedNames() - Method in class org.apache.flink.streaming.api.transformations.SelectTransformation
Returns the names of the split streams that this SelectTransformation selects.
getSelectorForArray(int[], TypeInformation<X>) - Static method in class org.apache.flink.streaming.util.keys.KeySelectorUtil
 
getSelectorForKeys(Keys<X>, TypeInformation<X>, ExecutionConfig) - Static method in class org.apache.flink.streaming.util.keys.KeySelectorUtil
 
getSelectorForOneKey(Keys<X>, Partitioner<K>, TypeInformation<X>, ExecutionConfig) - Static method in class org.apache.flink.streaming.util.keys.KeySelectorUtil
 
getSelf() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
Get self-gateway which should be used to run asynchronous RPC calls on this endpoint.
getSelfGatewayType() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
Returns the class of the self gateway type.
getSemanticProperties() - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
getSemanticProperties() - Method in class org.apache.flink.api.common.operators.base.SortPartitionOperatorBase
 
getSemanticProperties() - Method in class org.apache.flink.api.common.operators.DualInputOperator
 
getSemanticProperties() - Method in class org.apache.flink.api.common.operators.SingleInputOperator
 
getSemanticProperties() - Method in class org.apache.flink.api.java.operators.CoGroupOperator
 
getSemanticProperties() - Method in class org.apache.flink.api.java.operators.GroupCombineOperator
 
getSemanticProperties() - Method in class org.apache.flink.api.java.operators.GroupReduceOperator
 
getSemanticProperties() - Method in class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
 
getSemanticProperties() - Method in class org.apache.flink.api.java.operators.ReduceOperator
 
getSemanticProperties() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
 
getSemanticProperties() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
 
getSemanticProperties() - Method in interface org.apache.flink.api.java.operators.UdfOperator
Gets the semantic properties that have been set for the user-defined functions (UDF).
getSemanticProperties() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
getSemanticProperties() - Method in class org.apache.flink.optimizer.dag.AbstractPartialSolutionNode
 
getSemanticProperties() - Method in class org.apache.flink.optimizer.dag.BinaryUnionNode
 
getSemanticProperties() - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
 
getSemanticProperties() - Method in class org.apache.flink.optimizer.dag.DataSinkNode
 
getSemanticProperties() - Method in class org.apache.flink.optimizer.dag.DataSourceNode
 
getSemanticProperties() - Method in class org.apache.flink.optimizer.dag.FilterNode
 
getSemanticProperties() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
getSemanticProperties() - Method in class org.apache.flink.optimizer.dag.PartitionNode
 
getSemanticProperties() - Method in class org.apache.flink.optimizer.dag.SingleInputNode
 
getSemanticProperties() - Method in class org.apache.flink.optimizer.dag.SortPartitionNode
 
getSemanticProperties() - Method in class org.apache.flink.optimizer.dag.TwoInputNode
 
getSemanticProperties() - Method in class org.apache.flink.optimizer.dag.UnaryOperatorNode
 
getSemanticProperties() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
 
getSemanticPropertiesForGlobalPropertyFiltering() - Method in class org.apache.flink.optimizer.dag.SingleInputNode
 
getSemanticPropertiesForGlobalPropertyFiltering() - Method in class org.apache.flink.optimizer.dag.TwoInputNode
 
getSemanticPropertiesForLocalPropertyFiltering() - Method in class org.apache.flink.optimizer.dag.CoGroupNode
 
getSemanticPropertiesForLocalPropertyFiltering() - Method in class org.apache.flink.optimizer.dag.GroupCombineNode
 
getSemanticPropertiesForLocalPropertyFiltering() - Method in class org.apache.flink.optimizer.dag.GroupReduceNode
 
getSemanticPropertiesForLocalPropertyFiltering() - Method in class org.apache.flink.optimizer.dag.MapPartitionNode
 
getSemanticPropertiesForLocalPropertyFiltering() - Method in class org.apache.flink.optimizer.dag.SingleInputNode
 
getSemanticPropertiesForLocalPropertyFiltering() - Method in class org.apache.flink.optimizer.dag.TwoInputNode
 
getSemanticPropsDual(Set<Annotation>, TypeInformation<?>, TypeInformation<?>, TypeInformation<?>) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
 
getSemanticPropsDualFromString(DualInputSemanticProperties, String[], String[], String[], String[], String[], String[], TypeInformation<?>, TypeInformation<?>, TypeInformation<?>) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
 
getSemanticPropsDualFromString(DualInputSemanticProperties, String[], String[], String[], String[], String[], String[], TypeInformation<?>, TypeInformation<?>, TypeInformation<?>, boolean) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
 
getSemanticPropsSingle(Set<Annotation>, TypeInformation<?>, TypeInformation<?>) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
 
getSemanticPropsSingleFromString(SingleInputSemanticProperties, String[], String[], String[], TypeInformation<?>, TypeInformation<?>) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
 
getSemanticPropsSingleFromString(SingleInputSemanticProperties, String[], String[], String[], TypeInformation<?>, TypeInformation<?>, boolean) - Static method in class org.apache.flink.api.java.functions.SemanticPropUtil
 
getSendAndReceiveBufferSize() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
getSentence() - Method in class org.apache.flink.storm.wordcount.operators.WordCountDataPojos.Sentence
 
getSerializableListState(String) - Method in interface org.apache.flink.api.common.state.OperatorStateStore
Deprecated.
since 1.3.0. Using Java serialization for persisting state is not encouraged. Please use OperatorStateStore.getListState(ListStateDescriptor) instead.
getSerializableListState(String) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
Deprecated.
Using Java serialization for persisting state is not encouraged. Please use DefaultOperatorStateBackend.getListState(ListStateDescriptor) instead.
getSerializableSerializerInstance() - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
getSerializationFormatIdentifier() - Method in class org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
 
getSerializedAccumulatorResults() - Method in class org.apache.flink.runtime.client.SerializedJobExecutionResult
 
getSerializedData() - Method in class org.apache.flink.migration.runtime.state.memory.SerializedStateHandle
 
getSerializedData() - Method in class org.apache.flink.runtime.state.SerializedCheckpointData
Gets the binary data for the serialized elements.
getSerializedExecutionConfig() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
 
getSerializedExecutionConfig() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Returns the ExecutionConfig
getSerializedJobInformation() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
Return the sub task's serialized job information.
getSerializedJobInformation() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getSerializedKeyAndNamespace() - Method in class org.apache.flink.runtime.query.netty.message.KvStateRequest
Returns the serialized key and namespace to request from the KvState instance.
getSerializedResult() - Method in class org.apache.flink.runtime.query.netty.message.KvStateRequestResult
Returns the serialized result or null if none available.
getSerializedStateBackend() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getSerializedTaskInformation() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
Return the sub task's serialized task information.
getSerializedTaskInformation() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getSerializedValue(byte[]) - Method in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
 
getSerializedValue(byte[]) - Method in class org.apache.flink.contrib.streaming.state.RocksDBMapState
 
getSerializedValue(byte[]) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
 
getSerializedValue(K, N) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
 
getSerializedValue(K, N) - Method in class org.apache.flink.runtime.state.heap.HeapListState
 
getSerializedValue(K, N) - Method in class org.apache.flink.runtime.state.heap.HeapMapState
 
getSerializedValue(byte[]) - Method in interface org.apache.flink.runtime.state.internal.InternalKvState
Returns the serialized value for the given key and namespace.
getSerializer() - Method in class org.apache.flink.api.common.ExecutionConfig.SerializableSerializer
 
getSerializer() - Method in class org.apache.flink.api.common.state.StateDescriptor
Returns the TypeSerializer that can be used to serialize the value in the state.
getSerializer() - Method in interface org.apache.flink.api.common.typeutils.TypeSerializerFactory
 
getSerializer(Kryo) - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
getSerializer() - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
 
getSerializer() - Method in class org.apache.flink.optimizer.plan.Channel
Gets the serializer from this Channel.
getSerializer() - Method in class org.apache.flink.optimizer.plan.SourcePlanNode
Gets the serializer from this PlanNode.
getSerializer(IN) - Method in class org.apache.flink.python.api.streaming.data.PythonSender
 
getSerializer(IN) - Static method in class org.apache.flink.python.api.streaming.util.SerializationUtils
 
getSerializer(T) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointSerializers
Returns the SavepointSerializer for the given savepoint.
getSerializer(int) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointSerializers
Returns the SavepointSerializer for the given savepoint version.
getSerializerClass() - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
getSerializerDefinitionType() - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
getSerializerForIterationChannel() - Method in class org.apache.flink.optimizer.plan.BulkIterationPlanNode
 
getSerializerForIterationChannel() - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
 
getSerializerTree(TypeInformation<T>) - Static method in class org.apache.flink.api.java.Utils
Debugging utility to understand the hierarchy of serializers created by the Java API.
getSeries() - Method in class org.apache.flink.metrics.datadog.DSeries
 
getServerChannelHandlers() - Method in interface org.apache.flink.runtime.io.network.netty.NettyProtocol
 
getServerConnectBacklog() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
getServerNumThreads() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
getServerPort() - Method in class org.apache.flink.mesos.util.MesosArtifactServer
Get the server port on which the artifact server is listening.
getServerPort() - Method in class org.apache.flink.runtime.webmonitor.utils.WebFrontendBootstrap
 
getServerPort() - Method in interface org.apache.flink.runtime.webmonitor.WebMonitor
Gets the port that the web server actually binds to.
getServerPort() - Method in class org.apache.flink.runtime.webmonitor.WebRuntimeMonitor
 
getSessionTimeout() - Method in class org.apache.flink.api.common.Plan
 
getSessionTimeout() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Gets the session timeout for this environment.
getSessionTimeout() - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Gets the session timeout for this environment.
getSessionTimeout() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Gets the timeout after which the corresponding ExecutionGraph is removed at the job manager after it has been executed.
getSharedNeighborCount() - Method in class org.apache.flink.graph.library.similarity.JaccardIndex.Result
Get the shared neighbor count.
getSharedSlot() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
Gets the shared slot into which this constraint's tasks are places.
getSharedState() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
 
getShift() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
 
getShipComparator(Channel, ExecutionConfig) - Static method in class org.apache.flink.optimizer.util.Utils
 
getShipdate() - Method in class org.apache.flink.examples.java.relational.TPCHQuery3.Lineitem
 
getShippriority() - Method in class org.apache.flink.examples.java.relational.TPCHQuery3.Order
 
getShippriority() - Method in class org.apache.flink.examples.java.relational.TPCHQuery3.ShippingPriorityItem
 
getShipStrategy() - Method in class org.apache.flink.optimizer.dag.DagConnection
Gets the shipping strategy for this connection.
getShipStrategy() - Method in class org.apache.flink.optimizer.plan.Channel
 
getShipStrategy() - Method in interface org.apache.flink.optimizer.plandump.DumpableConnection
 
getShipStrategyComparator() - Method in class org.apache.flink.optimizer.plan.Channel
Gets the ship strategy comparator from this Channel.
getShipStrategyKeys() - Method in class org.apache.flink.optimizer.plan.Channel
 
getShipStrategyName() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
Gets the name of the ship strategy for the represented input, like "forward", "partition hash", "rebalance", "broadcast", ...
getShipStrategySortOrder() - Method in class org.apache.flink.optimizer.plan.Channel
 
getShipStrategyString(ShipStrategyType) - Static method in class org.apache.flink.optimizer.plantranslate.JsonMapper
 
getShort(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the Short value for the given key.
getShort(String, short) - Method in class org.apache.flink.api.java.utils.ParameterTool
Returns the Short value for the given key.
getShort(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads two memory at the given position, composing them into a short value according to the current byte order.
getShort(int) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getShortBigEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads an short integer value (16 bit, 2 bytes) from the given position, in big-endian byte order.
getShortByField(String) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getShortDescription() - Method in class org.apache.flink.graph.drivers.AdamicAdar
 
getShortDescription() - Method in class org.apache.flink.graph.drivers.ClusteringCoefficient
 
getShortDescription() - Method in class org.apache.flink.graph.drivers.ConnectedComponents
 
getShortDescription() - Method in interface org.apache.flink.graph.drivers.Driver
A one-line description, presented in the algorithm listing.
getShortDescription() - Method in class org.apache.flink.graph.drivers.EdgeList
 
getShortDescription() - Method in class org.apache.flink.graph.drivers.GraphMetrics
 
getShortDescription() - Method in class org.apache.flink.graph.drivers.HITS
 
getShortDescription() - Method in class org.apache.flink.graph.drivers.JaccardIndex
 
getShortDescription() - Method in class org.apache.flink.graph.drivers.PageRank
 
getShortDescription() - Method in class org.apache.flink.graph.drivers.TriangleListing
 
getShortLittleEndian(int) - Method in class org.apache.flink.core.memory.MemorySegment
Reads an short integer value (16 bit, 2 bytes) from the given position, in little-endian byte order.
getShortName() - Method in enum org.apache.flink.api.common.operators.Order
 
getShortString() - Method in class org.apache.flink.graph.drivers.parameter.Simplify
 
getSideOutput(OutputTag<X>) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Gets the DataStream that contains the elements that are emitted from an operation into the side output with the given OutputTag.
getSideOutput(OutputTag<X>, TypeInformation<X>) - Method in class org.apache.flink.streaming.api.scala.DataStream
 
getSignatureTemplate(int) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
getSignatureTemplate(int) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
getSignatureTemplate(int) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
getSignatureTemplate(int) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
getSimpleEdgeDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.CommunityDetectionData
 
getSimpleName() - Method in class org.apache.flink.table.plan.nodes.datastream.AccModeTraitDef
 
getSimpleName() - Method in class org.apache.flink.table.plan.nodes.datastream.UpdateAsRetractionTraitDef
 
getSimplifyShortString() - Method in class org.apache.flink.graph.drivers.input.GeneratedMultiGraph
Get the short string representation of the simplify transformation.
getSingleAbstractMethod(Class<?>) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils
Extracts a Single Abstract Method (SAM) as defined in Java Specification (4.3.2.
getSingleInputNode() - Method in class org.apache.flink.optimizer.plan.SingleInputPlanNode
 
getSingleInputNodeSchema(SingleInputPlanNode, T) - Method in class org.apache.flink.optimizer.postpass.GenericFlatTypePostPass
 
getSingleNestedSerializerAndConfig() - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
 
getSingleRootOfStepFunction() - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
 
getSingleRootOfStepFunction() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
 
getSinkIDs() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getSinkNode() - Method in class org.apache.flink.optimizer.plan.SinkPlanNode
 
getSinks() - Method in class org.apache.flink.optimizer.traversals.GraphCreatingVisitor
 
getSinkSchema(SinkPlanNode, T) - Method in class org.apache.flink.optimizer.postpass.GenericFlatTypePostPass
 
getSize() - Method in class org.apache.flink.api.common.time.Time
Gets the length of this policy's time interval.
getSize() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
 
getSize() - Method in interface org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
Gets the size (in bytes) of the file underlying the channel.
getSize() - Method in class org.apache.flink.runtime.io.network.buffer.Buffer
 
getSize() - Method in class org.apache.flink.runtime.rpc.akka.messages.RemoteRpcInvocation
Size (#bytes of the serialized data) of the rpc invocation message.
getSize() - Method in class org.apache.flink.streaming.api.windowing.assigners.BaseAlignedWindowAssigner
 
getSize() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
 
getSize() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
 
getSize() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
 
getSize() - Method in class org.apache.flink.streaming.api.windowing.time.Time
Gets the length of this policy's time interval.
getSizeLimit() - Method in class org.apache.flink.runtime.util.EvictingBoundedList
 
getSizeOfFreeHeapMemory() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
Gets an estimate of the size of the free heap memory.
getSizeOfFreeHeapMemoryWithDefrag() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
Gets an estimate of the size of the free heap memory.
getSizeOfJvmHeap() - Method in class org.apache.flink.runtime.instance.HardwareDescription
Returns the size of the JVM heap memory
getSizeOfManagedMemory() - Method in class org.apache.flink.runtime.instance.HardwareDescription
Returns the size of the memory managed by the system for caching, hashing, sorting, ...
getSizeOfPhysicalMemory() - Method in class org.apache.flink.runtime.instance.HardwareDescription
Returns the size of physical memory in bytes available on the compute node.
getSizeOfPhysicalMemory() - Static method in class org.apache.flink.runtime.util.Hardware
Returns the size of the physical memory in bytes.
getSizeOfSerializedState() - Method in class org.apache.flink.migration.runtime.state.memory.SerializedStateHandle
Gets the size of the serialized state.
getSizes() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Media
 
getSlide() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingAlignedProcessingTimeWindows
 
getSlide() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
 
getSlide() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
 
getSlotAllocationId() - Method in class org.apache.flink.runtime.jobmanager.slots.AllocatedSlot
Gets the ID under which the slot is allocated, which uniquely identifies the slot.
getSlotForTask(ExecutionVertex) - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
Gets a slot suitable for the given task vertex.
getSlotForTask(ExecutionVertex, CoLocationConstraint) - Method in class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
Gets a slot for a task that has a co-location constraint.
getSlotId() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
getSlotID() - Method in class org.apache.flink.runtime.taskexecutor.SlotStatus
Get the unique identification of this slot
getSlotIndex() - Method in class org.apache.flink.runtime.taskexecutor.slot.SlotOffer
 
getSlotManager() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServices
 
getSlotManagerConfiguration() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServicesConfiguration
 
getSlotNumber() - Method in class org.apache.flink.runtime.clusterframework.types.SlotID
 
getSlotNumber() - Method in class org.apache.flink.runtime.instance.Slot
Gets the number of the slot.
getSlotNumber() - Method in class org.apache.flink.runtime.jobmanager.slots.AllocatedSlot
Gets the number of the slot.
getSlotOwner() - Method in class org.apache.flink.runtime.instance.SlotPool
Gets the slot owner implementation for this pool.
getSlotProvider() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getSlotProvider() - Method in class org.apache.flink.runtime.instance.SlotPool
Gets the slot provider implementation for this pool.
getSlotRequestTimeout() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
 
getSlots() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
getSlotSharingGroup() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getSlotSharingGroup() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
Gets the slot sharing group that this vertex is associated with.
getSlotSharingGroup() - Method in class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
 
getSlotSharingGroup(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
Determines the slot sharing group of an operation across virtual nodes.
getSlotSharingGroup() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getSlotSharingGroup() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
Returns the slot sharing group of this transformation.
getSnapshot() - Method in class org.apache.flink.dropwizard.metrics.FlinkHistogramWrapper
 
getSnapshot() - Method in class org.apache.flink.runtime.accumulators.AccumulatorRegistry
Creates a snapshot of this accumulator registry.
getSnapshottingSettings() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsTracker
Returns the job's snapshotting settings which are derived from the CheckpointConfig.
getSolutionSet() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
Gets the contract that represents the solution set for the step function.
getSolutionSet() - Method in class org.apache.flink.api.java.operators.DeltaIteration
Gets the solution set of the delta iteration.
getSolutionSetComparator() - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
 
getSolutionSetComparator(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getSolutionSetDelta() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
Gets the contract that has been set as the solution set delta.
getSolutionSetDelta() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
 
getSolutionSetDeltaPlanNode() - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
 
getSolutionSetKeyFields() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
 
getSolutionSetKeyFields() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
 
getSolutionSetKeyFields() - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
 
getSolutionSetNode() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
 
getSolutionSetNode() - Method in class org.apache.flink.optimizer.plan.SolutionSetPlanNode
 
getSolutionSetPlanNode() - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
 
getSolutionSetSerializer() - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
 
getSolutionSetSerializer(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getSortedGrouping(int) - Method in class org.apache.flink.python.api.util.SetCache
Returns the cached SortedGrouping for the given ID.
getSortingThread(ExceptionHandler<IOException>, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
 
getSortOrders() - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
 
getSortOrders(int) - Method in class org.apache.flink.optimizer.plan.SingleInputPlanNode
Gets the sort order for the specified driver comparator.
getSortSelectionFunctionKey() - Method in class org.apache.flink.api.java.operators.SortedGrouping
 
getSource() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
getSource() - Method in class org.apache.flink.graph.Edge
 
getSource() - Method in class org.apache.flink.optimizer.dag.DagConnection
Gets the source of the connection.
getSource() - Method in class org.apache.flink.optimizer.plan.Channel
Gets the source of this Channel.
getSource() - Method in interface org.apache.flink.optimizer.plandump.DumpableConnection
 
getSource() - Method in class org.apache.flink.runtime.executiongraph.ExecutionEdge
 
getSource() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
Returns the data set at the source of the edge.
getSource(StreamExecutionEnvironment, long) - Static method in class org.apache.flink.streaming.examples.join.WindowJoinSampleData.GradeSource
 
getSource(StreamExecutionEnvironment, long) - Static method in class org.apache.flink.streaming.examples.join.WindowJoinSampleData.SalarySource
 
getSourceComponent() - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getSourceContext(TimeCharacteristic, ProcessingTimeService, Object, StreamStatusMaintainer, Output<StreamRecord<OUT>>, long, long) - Static method in class org.apache.flink.streaming.api.operators.StreamSourceContexts
Depending on the TimeCharacteristic, this method will return the adequate SourceFunction.SourceContext.
getSourceEdgeValue() - Method in class org.apache.flink.graph.bipartite.Projection
 
getSourceGlobalStreamid() - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getSourceGlobalStreamId() - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getSourceId() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
Gets the ID of the consumed data set.
getSourceId() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
 
getSourceIDs() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getSourceState() - Method in class org.apache.flink.cep.nfa.StateTransition
 
getSourceStreamId() - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getSourceTask() - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getSourceVertex() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
 
getSpillingDirectories() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
Gets the directories that the I/O manager spills to.
getSpillingDirectoriesPaths() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
Gets the directories that the I/O manager spills to, as path strings.
getSpillingThread(ExceptionHandler<IOException>, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable, MemoryManager, IOManager, TypeSerializerFactory<E>, TypeComparator<E>, List<MemorySegment>, List<MemorySegment>, int) - Method in class org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger
 
getSpillingThread(ExceptionHandler<IOException>, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable, MemoryManager, IOManager, TypeSerializerFactory<E>, TypeComparator<E>, List<MemorySegment>, List<MemorySegment>, int) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
 
getSpillingThresholdDriver() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getSpillingThresholdInput(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getSplit(int, int) - Method in class org.apache.flink.util.SplittableIterator
Splits this iterator into n partitions and returns the i-th partition out of those.
getSplitAssigner() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getSplitDataProperties() - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
Returns the data properties of this data source's splits.
getSplitDataProperties() - Method in class org.apache.flink.api.java.operators.DataSource
Returns the SplitDataProperties for the InputSplits of this DataSource for configurations.
getSplitGroupKeys() - Method in interface org.apache.flink.api.common.operators.GenericDataSourceBase.SplitDataProperties
 
getSplitGroupKeys() - Method in class org.apache.flink.api.java.io.SplitDataProperties
 
getSplitLength() - Method in class org.apache.flink.api.common.io.FileInputFormat
Gets the length or remaining length of the current split.
getSplitNumber() - Method in class org.apache.flink.core.io.GenericInputSplit
 
getSplitNumber() - Method in interface org.apache.flink.core.io.InputSplit
Returns the number of this input split.
getSplitNumber() - Method in class org.apache.flink.core.io.LocatableInputSplit
 
getSplitNumber() - Method in class org.apache.flink.examples.java.distcp.FileCopyTaskInputSplit
 
getSplitOrder() - Method in interface org.apache.flink.api.common.operators.GenericDataSourceBase.SplitDataProperties
 
getSplitOrder() - Method in class org.apache.flink.api.java.io.SplitDataProperties
 
getSplitPartitioner() - Method in interface org.apache.flink.api.common.operators.GenericDataSourceBase.SplitDataProperties
 
getSplitPartitioner() - Method in class org.apache.flink.api.java.io.SplitDataProperties
 
getSplitPartitionKeys() - Method in interface org.apache.flink.api.common.operators.GenericDataSourceBase.SplitDataProperties
 
getSplitPartitionKeys() - Method in class org.apache.flink.api.java.io.SplitDataProperties
 
getSplitStart() - Method in class org.apache.flink.api.common.io.FileInputFormat
Gets the start of the current split.
getSplitState() - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
 
getSqlAggFunction(RelBuilder) - Method in class org.apache.flink.table.expressions.AggFunctionCall
 
getSqlAggFunction(RelBuilder) - Method in class org.apache.flink.table.expressions.Aggregation
Returns the SqlAggFunction for this Aggregation.
getSqlAggFunction(RelBuilder) - Method in class org.apache.flink.table.expressions.Avg
 
getSqlAggFunction(RelBuilder) - Method in class org.apache.flink.table.expressions.Count
 
getSqlAggFunction(RelBuilder) - Method in class org.apache.flink.table.expressions.Max
 
getSqlAggFunction(RelBuilder) - Method in class org.apache.flink.table.expressions.Min
 
getSqlAggFunction(RelBuilder) - Method in class org.apache.flink.table.expressions.StddevPop
 
getSqlAggFunction(RelBuilder) - Method in class org.apache.flink.table.expressions.StddevSamp
 
getSqlAggFunction(RelBuilder) - Method in class org.apache.flink.table.expressions.Sum
 
getSqlAggFunction(RelBuilder) - Method in class org.apache.flink.table.expressions.Sum0
 
getSqlAggFunction(RelBuilder) - Method in class org.apache.flink.table.expressions.VarPop
 
getSqlAggFunction(RelBuilder) - Method in class org.apache.flink.table.expressions.VarSamp
 
getSqlExecutionPlan(String, Boolean) - Static method in class org.apache.flink.table.explain.PlanJsonParser
 
getSqlIdentifier() - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
getSqlIdentifier() - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
getSqlIdentifier() - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
getSqlIdentifier() - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
getSqlIdentifier() - Static method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
getSqlOperatorTable() - Method in class org.apache.flink.table.api.TableEnvironment
Returns the operator table for this environment including a custom Calcite configuration.
getSqlOperatorTable() - Method in interface org.apache.flink.table.calcite.CalciteConfig
Returns a custom SQL operator table.
getSqlOperatorTable() - Method in class org.apache.flink.table.validate.FunctionCatalog
 
getSqlParserConfig() - Method in class org.apache.flink.table.api.TableEnvironment
Returns the SQL parser config for this environment including a custom Calcite configuration.
getSqlParserConfig() - Method in interface org.apache.flink.table.calcite.CalciteConfig
Returns a custom SQL parser configuration.
getSqlTypeName() - Static method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
getSrcVertex() - Method in class org.apache.flink.graph.Triplet
 
getSSLEnabled() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
getSSLEnabled(Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
Retrieves the global ssl flag from configuration
getsSourceVertexValue() - Method in class org.apache.flink.graph.bipartite.Projection
 
getStackTrace() - Method in class org.apache.flink.runtime.messages.StackTrace
 
getStackTrace() - Static method in exception org.apache.flink.table.api.AmbiguousTableSourceConverterException
 
getStackTrace() - Static method in exception org.apache.flink.table.api.CatalogAlreadyExistException
 
getStackTrace() - Static method in exception org.apache.flink.table.api.CatalogNotExistException
 
getStackTrace() - Static method in exception org.apache.flink.table.api.ExpressionParserException
 
getStackTrace() - Static method in exception org.apache.flink.table.api.ExternalCatalogAlreadyExistException
 
getStackTrace() - Static method in exception org.apache.flink.table.api.ExternalCatalogNotExistException
 
getStackTrace() - Static method in exception org.apache.flink.table.api.NoMatchedTableSourceConverterException
 
getStackTrace() - Static method in exception org.apache.flink.table.api.SqlParserException
 
getStackTrace() - Static method in exception org.apache.flink.table.api.TableAlreadyExistException
 
getStackTrace() - Static method in exception org.apache.flink.table.api.TableException
 
getStackTrace() - Static method in exception org.apache.flink.table.api.TableNotExistException
 
getStackTrace() - Static method in exception org.apache.flink.table.api.UnresolvedException
 
getStackTrace() - Static method in exception org.apache.flink.table.api.ValidationException
 
getStackTraceDepth() - Static method in exception org.apache.flink.table.api.AmbiguousTableSourceConverterException
 
getStackTraceDepth() - Static method in exception org.apache.flink.table.api.CatalogAlreadyExistException
 
getStackTraceDepth() - Static method in exception org.apache.flink.table.api.CatalogNotExistException
 
getStackTraceDepth() - Static method in exception org.apache.flink.table.api.ExpressionParserException
 
getStackTraceDepth() - Static method in exception org.apache.flink.table.api.ExternalCatalogAlreadyExistException
 
getStackTraceDepth() - Static method in exception org.apache.flink.table.api.ExternalCatalogNotExistException
 
getStackTraceDepth() - Static method in exception org.apache.flink.table.api.NoMatchedTableSourceConverterException
 
getStackTraceDepth() - Static method in exception org.apache.flink.table.api.SqlParserException
 
getStackTraceDepth() - Static method in exception org.apache.flink.table.api.TableAlreadyExistException
 
getStackTraceDepth() - Static method in exception org.apache.flink.table.api.TableException
 
getStackTraceDepth() - Static method in exception org.apache.flink.table.api.TableNotExistException
 
getStackTraceDepth() - Static method in exception org.apache.flink.table.api.UnresolvedException
 
getStackTraceDepth() - Static method in exception org.apache.flink.table.api.ValidationException
 
getStackTraceElement(int) - Static method in exception org.apache.flink.table.api.AmbiguousTableSourceConverterException
 
getStackTraceElement(int) - Static method in exception org.apache.flink.table.api.CatalogAlreadyExistException
 
getStackTraceElement(int) - Static method in exception org.apache.flink.table.api.CatalogNotExistException
 
getStackTraceElement(int) - Static method in exception org.apache.flink.table.api.ExpressionParserException
 
getStackTraceElement(int) - Static method in exception org.apache.flink.table.api.ExternalCatalogAlreadyExistException
 
getStackTraceElement(int) - Static method in exception org.apache.flink.table.api.ExternalCatalogNotExistException
 
getStackTraceElement(int) - Static method in exception org.apache.flink.table.api.NoMatchedTableSourceConverterException
 
getStackTraceElement(int) - Static method in exception org.apache.flink.table.api.SqlParserException
 
getStackTraceElement(int) - Static method in exception org.apache.flink.table.api.TableAlreadyExistException
 
getStackTraceElement(int) - Static method in exception org.apache.flink.table.api.TableException
 
getStackTraceElement(int) - Static method in exception org.apache.flink.table.api.TableNotExistException
 
getStackTraceElement(int) - Static method in exception org.apache.flink.table.api.UnresolvedException
 
getStackTraceElement(int) - Static method in exception org.apache.flink.table.api.ValidationException
 
getStackTraces() - Method in class org.apache.flink.runtime.webmonitor.StackTraceSample
Returns the a map of stack traces by execution ID.
getStandardDeviation() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
Standard Deviation is a measure of variation in a set of numbers.
getStart() - Method in class org.apache.flink.core.fs.FileInputSplit
Returns the position of the first byte in the file to process.
getStart() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
Gets the starting timestamp of the window.
getStartCommand(String, Map<String, String>) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
Replaces placeholders in the template start command with values from startCommandValues.
getStartedTaskManagers() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Gets the currently registered resources.
getStartKeyGroup() - Method in class org.apache.flink.runtime.state.KeyGroupRange
 
getStartRow() - Method in class org.apache.flink.addons.hbase.TableInputSplit
Returns the start row.
getStartTime() - Method in class org.apache.flink.runtime.client.JobStatusMessage
 
getStartTime() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
 
getStartTime() - Method in class org.apache.flink.runtime.webmonitor.StackTraceSample
Returns the time stamp, when the sample was triggered.
getStartTimestamp() - Method in class org.apache.flink.cep.nfa.ComputationState
 
getState(ValueStateDescriptor<T>) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Gets a handle to the system's key/value state.
getState(ValueStateDescriptor<T>) - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getState(ValueStateDescriptor<T>) - Method in interface org.apache.flink.api.common.state.KeyedStateStore
Gets a handle to the system's key/value state.
getState() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
getState() - Method in class org.apache.flink.cep.nfa.ComputationState
 
getState() - Method in class org.apache.flink.graph.utils.proxy.OptionalBoolean
Get the actual state.
getState() - Method in class org.apache.flink.migration.runtime.checkpoint.SubtaskState
Deprecated.
 
getState(int) - Method in class org.apache.flink.migration.runtime.checkpoint.TaskState
Deprecated.
 
getState(ClassLoader) - Method in class org.apache.flink.migration.runtime.state.AbstractStateBackend.DataInputViewHandle
Deprecated.
 
getState(ClassLoader) - Method in class org.apache.flink.migration.runtime.state.filesystem.FileSerializableStateHandle
Deprecated.
 
getState(ClassLoader) - Method in class org.apache.flink.migration.runtime.state.filesystem.FileStreamStateHandle
Deprecated.
 
getState(ClassLoader) - Method in class org.apache.flink.migration.runtime.state.memory.ByteStreamStateHandle
Deprecated.
 
getState(ClassLoader) - Method in class org.apache.flink.migration.runtime.state.memory.SerializedStateHandle
 
getState(ClassLoader) - Method in interface org.apache.flink.migration.runtime.state.StateHandle
Deprecated.
This retrieves and return the state represented by the handle.
getState(ClassLoader) - Method in class org.apache.flink.migration.streaming.runtime.tasks.StreamTaskStateList
Deprecated.
 
getState(int) - Method in class org.apache.flink.runtime.checkpoint.OperatorState
 
getState(int) - Method in class org.apache.flink.runtime.checkpoint.TaskState
Deprecated.
 
getState() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
Returns the current ExecutionState for this execution.
getState() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns the current JobStatus for this execution graph.
getState() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
 
getState() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getState() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
getState() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getState() - Method in class org.apache.flink.runtime.executiongraph.failover.FailoverRegion
 
getState(ValueStateDescriptor<T>) - Method in class org.apache.flink.runtime.state.DefaultKeyedStateStore
 
getState() - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
Returns the internal data structure.
getState() - Method in interface org.apache.flink.runtime.state.heap.StateEntry
Returns the state of this entry.
getState() - Method in class org.apache.flink.storm.api.FlinkLocalCluster
 
getState(ValueStateDescriptor<T>) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
getState() - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
 
getState(ValueStateDescriptor<T>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
 
getState(ValueStateDescriptor<T>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.PerWindowStateStore
 
getStateBackend() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Returns the state backend that defines how to store and checkpoint state.
getStateBackend(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getStateBackend() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getStateBackend() - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Returns the state backend that defines how to store and checkpoint state.
getStateDesc() - Method in class org.apache.flink.migration.runtime.state.filesystem.AbstractFsStateSnapshot
Deprecated.
 
getStateDescriptor() - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
 
getStateDescriptor() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
getStateKeySelector() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
Returns the KeySelector that must be used for partitioning keyed state in this Operation.
getStateKeySelector() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
Returns the KeySelector that must be used for partitioning keyed state in this Sink.
getStateKeySelector1() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
Returns the KeySelector that must be used for partitioning keyed state in this Operation for the first input.
getStateKeySelector2() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
Returns the KeySelector that must be used for partitioning keyed state in this Operation for the second input.
getStateKeySerializer(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getStateKeySerializer() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getStateKeyType() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
 
getStateKeyType() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
 
getStateKeyType() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
 
getStateMetaInfoSnapshots() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
 
getStateMetaInfoSnapshots() - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
 
getStateNameToPartitionOffsets() - Method in class org.apache.flink.runtime.state.OperatorStateHandle
 
getStatePartitioner(int, ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getStatePartitioner1() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getStatePartitioner2() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getStates() - Method in class org.apache.flink.cep.nfa.NFA
 
getStates() - Method in class org.apache.flink.migration.runtime.checkpoint.TaskState
Deprecated.
 
getStates() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
 
getStates() - Method in class org.apache.flink.runtime.checkpoint.TaskState
Deprecated.
 
getStateSentinel() - Method in enum org.apache.flink.streaming.connectors.kafka.config.StartupMode
 
getStateSerializer() - Method in class org.apache.flink.migration.runtime.state.filesystem.AbstractFsStateSnapshot
Deprecated.
 
getStateSerializer() - Method in class org.apache.flink.migration.runtime.state.memory.AbstractMemStateSnapshot
Deprecated.
 
getStateSerializer() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
getStateSerializer() - Method in class org.apache.flink.runtime.state.heap.StateTable
 
getStateSerializer() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo
 
getStateSerializer() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo.Snapshot
 
getStateSerializerConfigSnapshot() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo.Snapshot
 
getStateSize() - Method in class org.apache.flink.api.common.operators.ResourceSpec
 
getStateSize() - Method in class org.apache.flink.migration.contrib.streaming.state.RocksDBStateBackend.FinalFullyAsyncSnapshot
Deprecated.
 
getStateSize() - Method in class org.apache.flink.migration.runtime.checkpoint.KeyGroupState
Deprecated.
 
getStateSize() - Method in class org.apache.flink.migration.runtime.checkpoint.SubtaskState
Deprecated.
 
getStateSize() - Method in class org.apache.flink.migration.runtime.checkpoint.TaskState
Deprecated.
 
getStateSize() - Method in class org.apache.flink.migration.runtime.state.AbstractStateBackend.DataInputViewHandle
Deprecated.
 
getStateSize() - Method in class org.apache.flink.migration.runtime.state.filesystem.AbstractFsStateSnapshot
Deprecated.
 
getStateSize() - Method in class org.apache.flink.migration.runtime.state.filesystem.FileSerializableStateHandle
Deprecated.
Returns the file size in bytes.
getStateSize() - Method in class org.apache.flink.migration.runtime.state.filesystem.FileStreamStateHandle
Deprecated.
Returns the file size in bytes.
getStateSize() - Method in class org.apache.flink.migration.runtime.state.memory.AbstractMemStateSnapshot
Deprecated.
 
getStateSize() - Method in class org.apache.flink.migration.runtime.state.memory.ByteStreamStateHandle
Deprecated.
 
getStateSize() - Method in class org.apache.flink.migration.runtime.state.memory.SerializedStateHandle
 
getStateSize() - Method in interface org.apache.flink.migration.runtime.state.StateObject
Deprecated.
Returns the size of the state in bytes.
getStateSize() - Method in class org.apache.flink.migration.state.MigrationStreamStateHandle
Deprecated.
 
getStateSize() - Method in class org.apache.flink.migration.streaming.runtime.tasks.StreamTaskStateList
Deprecated.
 
getStateSize() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
Returns the total checkpoint state size over all subtasks.
getStateSize() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
getStateSize() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
 
getStateSize() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
 
getStateSize() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
 
getStateSize() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
 
getStateSize() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpointStats
 
getStateSize() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
 
getStateSize() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
Returns the size of the checkpointed state at this subtask.
getStateSize() - Method in class org.apache.flink.runtime.checkpoint.TaskState
Deprecated.
 
getStateSize() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
Returns the total checkpoint state size over all subtasks.
getStateSize() - Method in class org.apache.flink.runtime.state.ChainedStateHandle
 
getStateSize() - Method in class org.apache.flink.runtime.state.filesystem.FileStateHandle
Returns the file size in bytes.
getStateSize() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
 
getStateSize() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
 
getStateSize() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
 
getStateSize() - Method in class org.apache.flink.runtime.state.MultiStreamStateHandle
 
getStateSize() - Method in class org.apache.flink.runtime.state.OperatorStateHandle
 
getStateSize() - Method in class org.apache.flink.runtime.state.PlaceholderStreamStateHandle
 
getStateSize() - Method in class org.apache.flink.runtime.state.RetrievableStreamStateHandle
 
getStateSize() - Method in interface org.apache.flink.runtime.state.StateObject
Returns the size of the state in bytes.
getStateSize(StateObject) - Static method in class org.apache.flink.runtime.state.StateUtil
Returns the size of a state object
getStateSizeStats() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStatsSummary
Returns the summary stats for the state size of completed checkpoints.
getStateSizeStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
Returns the summary stats for the state size.
getStateTable() - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
This should only be used for testing.
getStateTimestamp(ExecutionState) - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
Returns the timestamp for the given ExecutionState.
getStateTimestamp(ExecutionState) - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
Returns the timestamp for the given ExecutionState.
getStateTimestamp(ExecutionState) - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
 
getStateTimestamp(ExecutionState) - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
 
getStateTimestamp(ExecutionState) - Method in class org.apache.flink.runtime.executiongraph.Execution
 
getStateTimestamp(ExecutionState) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getStateTimestamps() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
Returns the timestamps for every ExecutionState.
getStateTimestamps() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
 
getStateTimestamps() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
getStateTransitions() - Method in class org.apache.flink.cep.nfa.State
 
getStateType() - Method in class org.apache.flink.cep.nfa.State
 
getStateType() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo
 
getStateType() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo.Snapshot
 
getStateWindow(W) - Method in class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
Returns the state window for the given in-flight Window.
getStatistic() - Static method in class org.apache.flink.table.plan.schema.DataSetTable
 
getStatistic() - Static method in class org.apache.flink.table.plan.schema.DataStreamTable
 
getStatistic() - Method in class org.apache.flink.table.plan.schema.FlinkTable
Returns statistics of current table
getStatistic() - Static method in class org.apache.flink.table.plan.schema.StreamTableSourceTable
 
getStatistic() - Static method in class org.apache.flink.table.plan.schema.TableSourceTable
 
getStatistics(BaseStatistics) - Method in class org.apache.flink.addons.hbase.AbstractTableInputFormat
 
getStatistics(BaseStatistics) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
 
getStatistics(BaseStatistics) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
getStatistics(BaseStatistics) - Method in class org.apache.flink.api.common.io.FileInputFormat
Obtains basic file statistics containing only file size.
getStatistics(BaseStatistics) - Method in class org.apache.flink.api.common.io.GenericInputFormat
 
getStatistics(BaseStatistics) - Method in interface org.apache.flink.api.common.io.InputFormat
Gets the basic statistics from the input described by this format.
getStatistics(BaseStatistics) - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
 
getStatistics(BaseStatistics) - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
getStatistics(BaseStatistics) - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
getStatistics(BaseStatistics) - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat
 
getStatistics(BaseStatistics) - Method in class org.apache.flink.batch.connectors.cassandra.CassandraInputFormat
 
getStatistics() - Method in class org.apache.flink.dropwizard.metrics.DropwizardHistogramWrapper
 
getStatistics(BaseStatistics) - Method in class org.apache.flink.examples.java.distcp.FileCopyTaskInputFormat
 
getStatistics(BaseStatistics) - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
 
getStatistics() - Method in interface org.apache.flink.metrics.Histogram
Create statistics for the currently recorded elements.
getStatisticsKey() - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
Gets the key under which statistics about this data source may be obtained from the statistics cache.
getStatus() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
Returns the status of this checkpoint.
getStatus() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
 
getStatus() - Method in class org.apache.flink.runtime.checkpoint.FailedCheckpointStats
 
getStatus() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpointStats
 
getStatus() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
 
getStatus() - Method in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
getStatuses_count() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getStatusMessages() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RunningJobsStatus
 
getStatusTimestamp(JobStatus) - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns the timestamp for the given JobStatus
getStatusTimestamp(JobStatus) - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getStatusTimestamp(JobStatus) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getStdDev() - Method in class org.apache.flink.metrics.HistogramStatistics
Returns the standard deviation of the distribution reflected by the histogram statistics.
getStdDev() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxHistogramMBean
 
getStdoutLogging() - Method in class org.apache.flink.client.cli.ProgramOptions
 
getStopException() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncIOCallable
Returns Exception that might happen on stop.
getStopException() - Method in interface org.apache.flink.runtime.io.async.AsyncStoppable
Delivers Exception that might happen during AsyncStoppable.stop()
getStorageDir() - Method in class org.apache.flink.runtime.blob.BlobCache
 
getStormTopology() - Method in class org.apache.flink.storm.api.FlinkTopology
 
getStrategy() - Method in class org.apache.flink.optimizer.dag.PartitionNode.PartitionDescriptor
 
getStrategy() - Method in class org.apache.flink.optimizer.dag.SortPartitionNode.SortPartitionDescriptor
 
getStrategy() - Method in interface org.apache.flink.optimizer.operators.AbstractOperatorDescriptor
Gets the runtime strategy to be executed by this operator.
getStrategy() - Method in class org.apache.flink.optimizer.operators.AllGroupCombineProperties
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.AllGroupReduceProperties
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.AllGroupWithPartialPreGroupProperties
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.AllReduceProperties
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.BinaryUnionOpDescriptor
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.CoGroupDescriptor
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.CoGroupRawDescriptor
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.CrossBlockOuterFirstDescriptor
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.CrossBlockOuterSecondDescriptor
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.CrossStreamOuterFirstDescriptor
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.CrossStreamOuterSecondDescriptor
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.FilterDescriptor
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.FlatMapDescriptor
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.GroupCombineProperties
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.GroupReduceProperties
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.GroupReduceWithCombineProperties
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.HashFullOuterJoinBuildFirstDescriptor
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.HashFullOuterJoinBuildSecondDescriptor
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.HashJoinBuildFirstProperties
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.HashJoinBuildSecondProperties
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.HashLeftOuterJoinBuildFirstDescriptor
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.HashLeftOuterJoinBuildSecondDescriptor
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.HashRightOuterJoinBuildFirstDescriptor
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.HashRightOuterJoinBuildSecondDescriptor
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.MapDescriptor
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.MapPartitionDescriptor
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.NoOpDescriptor
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.PartialGroupProperties
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.ReduceProperties
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.SolutionSetDeltaOperator
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.SortMergeFullOuterJoinDescriptor
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.SortMergeInnerJoinDescriptor
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.SortMergeLeftOuterJoinDescriptor
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.SortMergeRightOuterJoinDescriptor
 
getStrategy() - Method in class org.apache.flink.optimizer.operators.UtilSinkJoinOpDescriptor
 
getStrategyName() - Method in class org.apache.flink.runtime.executiongraph.failover.FailoverStrategy
Gets the name of the failover strategy, for logging purposes.
getStrategyName() - Method in class org.apache.flink.runtime.executiongraph.failover.RestartAllStrategy
 
getStrategyName() - Method in class org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy
 
getStrategyName() - Method in class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy
 
getStream() - Method in class org.apache.flink.runtime.state.StatePartitionStreamProvider
Returns a stream with the data of one state partition.
getStream() - Method in class org.apache.flink.streaming.connectors.fs.StreamWriterBase
Returns the current output stream, if the stream is open.
getStreamEdges(int, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getStreamElement() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
 
getStreamGraph() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Getter of the StreamGraph of the streaming job.
getStreamGraph() - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Getter of the StreamGraph of the streaming job.
getStreamingPlanAsJSON() - Method in class org.apache.flink.optimizer.plan.StreamingPlan
 
getStreamingPlanAsJSON() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getStreamNode(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getStreamNodes() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getStreamOperator(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getStreamOutputs() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
 
getStreamRecord() - Method in class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
Creates a StreamRecord from this TimestampedValue.
getStreamStateHandle() - Method in class org.apache.flink.migration.runtime.state.AbstractStateBackend.DataInputViewHandle
Deprecated.
 
getStreamStatus() - Method in interface org.apache.flink.streaming.runtime.streamstatus.StreamStatusProvider
Returns the current stream status.
getStreamStatus() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
 
getStreamStatusMaintainer() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
getStreamTimeCharacteristic() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Gets the time characteristic.
getStreamTimeCharacteristic() - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Gets the time characteristic/
getStreet_address() - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Attributes
 
getString(String, String) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given key as a string.
getString(ConfigOption<String>) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as a string.
getString(ConfigOption<String>, String) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as a string.
getString(String, String) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getString(ConfigOption<String>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getString(ConfigOption<String>, String) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getString(String, String) - Method in class org.apache.flink.metrics.MetricConfig
 
getString(int) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getStringByField(String) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getStringWithDeprecatedKeys(Configuration, String, String, String...) - Static method in class org.apache.flink.util.ConfigurationUtil
Returns the value associated with the given key as a String in the given Configuration.
getStructKind() - Static method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
getStub() - Method in class org.apache.flink.runtime.operators.BatchTask
 
getStub() - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
 
getStub() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
getStub() - Method in class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
 
getStub() - Method in class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
 
getStub() - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
 
getStub() - Method in class org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
 
getStub() - Method in class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
 
getStub() - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
 
getStub() - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
 
getStub() - Method in interface org.apache.flink.runtime.operators.TaskContext
 
getStubParameter(String, String) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getStubParameters() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getStubType() - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
getStubType() - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
 
getStubType() - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
 
getStubType() - Method in class org.apache.flink.runtime.operators.AllReduceDriver
 
getStubType() - Method in class org.apache.flink.runtime.operators.CoGroupDriver
 
getStubType() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
 
getStubType() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
 
getStubType() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
 
getStubType() - Method in class org.apache.flink.runtime.operators.CrossDriver
 
getStubType() - Method in interface org.apache.flink.runtime.operators.Driver
Gets the class of the stub type that is run by this task.
getStubType() - Method in class org.apache.flink.runtime.operators.FlatMapDriver
 
getStubType() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
 
getStubType() - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
 
getStubType() - Method in class org.apache.flink.runtime.operators.JoinDriver
 
getStubType() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
 
getStubType() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
 
getStubType() - Method in class org.apache.flink.runtime.operators.MapDriver
 
getStubType() - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
 
getStubType() - Method in class org.apache.flink.runtime.operators.NoOpDriver
 
getStubType() - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
 
getStubType() - Method in class org.apache.flink.runtime.operators.ReduceDriver
 
getStubType() - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
 
getStubWrapper(ClassLoader) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getSubCatalog(String) - Method in interface org.apache.flink.table.catalog.ExternalCatalog
Gets a sub catalog from this catalog.
getSubCatalog(String) - Method in class org.apache.flink.table.catalog.InMemoryExternalCatalog
 
getSubmissionTimeout() - Method in class org.apache.flink.runtime.messages.JobClientMessages$
 
getSubmissionTimeout() - Static method in class org.apache.flink.runtime.messages.JobClientMessages
 
getSubmittedJobGraphStore() - Method in interface org.apache.flink.runtime.highavailability.HighAvailabilityServices
Gets the submitted job graph store for the job manager
getSubmittedJobGraphStore() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
 
getSubmittedJobGraphStore() - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
getSubmittedJobGraphStore() - Method in class org.apache.flink.yarn.highavailability.AbstractYarnNonHaServices
 
getSubQueryExpr(SqlCall) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
 
getSubSchema(String) - Method in class org.apache.flink.table.catalog.ExternalCatalogSchema
Looks up a sub-schema by the given sub-schema name in the external catalog.
getSubSchemaNames() - Method in class org.apache.flink.table.catalog.ExternalCatalogSchema
Lists the sub-schemas of the external catalog.
getSubtaskIndex() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
Returns the subtask index.
getSubtaskIndex() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
Returns the task's index in the subtask group.
getSubtaskIndex() - Method in class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
 
getSubtaskMetricStore(String, String, int) - Method in class org.apache.flink.runtime.webmonitor.metrics.MetricStore
Returns the MetricStore.SubtaskMetricStore for the given job/task ID and subtask index.
getSubtaskMetricStore(int) - Method in class org.apache.flink.runtime.webmonitor.metrics.MetricStore.TaskMetricStore
 
getSubtaskState() - Method in class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
 
getSubtaskStates() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
 
getSubtaskStates() - Method in class org.apache.flink.runtime.checkpoint.TaskState
Deprecated.
 
getSubtaskStatesById() - Method in class org.apache.flink.migration.runtime.checkpoint.TaskState
Deprecated.
 
getSubtaskStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
Returns the stats for all subtasks.
getSuccessfulCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
getSum() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
 
getSum() - Method in class org.apache.flink.runtime.checkpoint.MinMaxAvgStats
Returns the sum of all seen values.
getSumBcastVars() - Method in class org.apache.flink.graph.gsa.GSAConfiguration
Get the broadcast variables of the SumFunction.
getSummary() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
 
getSummaryStats() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsSnapshot
Returns the snapshotted completed checkpoint summary stats.
getSummaryStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats
Returns the summary of the subtask stats.
getSuperstep() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableKey
 
getSuperstepNumber() - Method in interface org.apache.flink.api.common.functions.IterationRuntimeContext
Gets the number of the current superstep.
getSuperstepNumber() - Method in class org.apache.flink.graph.gsa.ApplyFunction
Gets the number of the superstep, starting at 1.
getSuperstepNumber() - Method in class org.apache.flink.graph.gsa.GatherFunction
Gets the number of the superstep, starting at 1.
getSuperstepNumber() - Method in class org.apache.flink.graph.gsa.SumFunction
Gets the number of the superstep, starting at 1.
getSuperstepNumber() - Method in class org.apache.flink.graph.pregel.ComputeFunction
Gets the number of the superstep, starting at 1.
getSuperstepNumber() - Method in class org.apache.flink.graph.spargel.GatherFunction
Gets the number of the superstep, starting at 1.
getSuperstepNumber() - Method in class org.apache.flink.graph.spargel.ScatterFunction
Gets the number of the superstep, starting at 1.
getSuperTemplateTypes(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
 
getSuperTemplateTypes(Class<?>, Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
 
getSuppressed() - Static method in exception org.apache.flink.table.api.AmbiguousTableSourceConverterException
 
getSuppressed() - Static method in exception org.apache.flink.table.api.CatalogAlreadyExistException
 
getSuppressed() - Static method in exception org.apache.flink.table.api.CatalogNotExistException
 
getSuppressed() - Static method in exception org.apache.flink.table.api.ExpressionParserException
 
getSuppressed() - Static method in exception org.apache.flink.table.api.ExternalCatalogAlreadyExistException
 
getSuppressed() - Static method in exception org.apache.flink.table.api.ExternalCatalogNotExistException
 
getSuppressed() - Static method in exception org.apache.flink.table.api.NoMatchedTableSourceConverterException
 
getSuppressed() - Static method in exception org.apache.flink.table.api.SqlParserException
 
getSuppressed() - Static method in exception org.apache.flink.table.api.TableAlreadyExistException
 
getSuppressed() - Static method in exception org.apache.flink.table.api.TableException
 
getSuppressed() - Static method in exception org.apache.flink.table.api.TableNotExistException
 
getSuppressed() - Static method in exception org.apache.flink.table.api.UnresolvedException
 
getSuppressed() - Static method in exception org.apache.flink.table.api.ValidationException
 
getSymbols() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Entities
 
getSyncCheckpointDuration() - Method in class org.apache.flink.runtime.checkpoint.SubtaskStateStats
Returns the duration of the synchronous part of the checkpoint.
getSyncCheckpointDurationStats() - Method in class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
Returns the summary stats for the sync checkpoint duration.
getSyncDurationMillis() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
getSynchronizationLock() - Method in class org.apache.flink.util.AbstractCloseableRegistry
 
getSyntax() - Method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction$
 
getSyntax() - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
getSyntax() - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
getSyntax() - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
getSyntax() - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
getSystemFieldList() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
getSystemFields() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Returns a list of fields to be prefixed to each relational expression.
getSystemProperties() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification
Get the system properties.
getTable(String) - Method in interface org.apache.flink.table.catalog.ExternalCatalog
Get a table from this catalog.
getTable(String) - Method in class org.apache.flink.table.catalog.ExternalCatalogSchema
Looks up and returns a table from this schema.
getTable(String) - Method in class org.apache.flink.table.catalog.InMemoryExternalCatalog
 
getTable() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
getTable() - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
getTable() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
getTable() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
getTable() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
getTable() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
getTable() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
getTable() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
getTable() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
getTable() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
getTable() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
getTable() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
getTable() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
getTable() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
getTable() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
getTable() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getTableEnvironment(ExecutionEnvironment) - Method in class org.apache.flink.table.api.TableEnvironment$
Returns a JavaBatchTableEnv for a Java JavaBatchExecEnv.
getTableEnvironment(ExecutionEnvironment, TableConfig) - Method in class org.apache.flink.table.api.TableEnvironment$
Returns a JavaBatchTableEnv for a Java JavaBatchExecEnv and a given TableConfig.
getTableEnvironment(ExecutionEnvironment) - Method in class org.apache.flink.table.api.TableEnvironment$
Returns a ScalaBatchTableEnv for a Scala ScalaBatchExecEnv.
getTableEnvironment(ExecutionEnvironment, TableConfig) - Method in class org.apache.flink.table.api.TableEnvironment$
Returns a ScalaBatchTableEnv for a Scala ScalaBatchExecEnv and a given TableConfig.
getTableEnvironment(StreamExecutionEnvironment) - Method in class org.apache.flink.table.api.TableEnvironment$
Returns a JavaStreamTableEnv for a Java JavaStreamExecEnv.
getTableEnvironment(StreamExecutionEnvironment, TableConfig) - Method in class org.apache.flink.table.api.TableEnvironment$
Returns a JavaStreamTableEnv for a Java JavaStreamExecEnv and a given TableConfig.
getTableEnvironment(StreamExecutionEnvironment) - Method in class org.apache.flink.table.api.TableEnvironment$
Returns a ScalaStreamTableEnv for a Scala stream ScalaStreamExecEnv.
getTableEnvironment(StreamExecutionEnvironment, TableConfig) - Method in class org.apache.flink.table.api.TableEnvironment$
Returns a ScalaStreamTableEnv for a Scala stream ScalaStreamExecEnv.
getTableEnvironment(ExecutionEnvironment) - Static method in class org.apache.flink.table.api.TableEnvironment
Returns a JavaBatchTableEnv for a Java JavaBatchExecEnv.
getTableEnvironment(ExecutionEnvironment, TableConfig) - Static method in class org.apache.flink.table.api.TableEnvironment
Returns a JavaBatchTableEnv for a Java JavaBatchExecEnv and a given TableConfig.
getTableEnvironment(ExecutionEnvironment) - Static method in class org.apache.flink.table.api.TableEnvironment
Returns a ScalaBatchTableEnv for a Scala ScalaBatchExecEnv.
getTableEnvironment(ExecutionEnvironment, TableConfig) - Static method in class org.apache.flink.table.api.TableEnvironment
Returns a ScalaBatchTableEnv for a Scala ScalaBatchExecEnv and a given TableConfig.
getTableEnvironment(StreamExecutionEnvironment) - Static method in class org.apache.flink.table.api.TableEnvironment
Returns a JavaStreamTableEnv for a Java JavaStreamExecEnv.
getTableEnvironment(StreamExecutionEnvironment, TableConfig) - Static method in class org.apache.flink.table.api.TableEnvironment
Returns a JavaStreamTableEnv for a Java JavaStreamExecEnv and a given TableConfig.
getTableEnvironment(StreamExecutionEnvironment) - Static method in class org.apache.flink.table.api.TableEnvironment
Returns a ScalaStreamTableEnv for a Scala stream ScalaStreamExecEnv.
getTableEnvironment(StreamExecutionEnvironment, TableConfig) - Static method in class org.apache.flink.table.api.TableEnvironment
Returns a ScalaStreamTableEnv for a Scala stream ScalaStreamExecEnv.
getTableFunction() - Method in class org.apache.flink.table.functions.utils.TableSqlFunction
Get the user-defined table function.
getTableName() - Method in class org.apache.flink.addons.hbase.AbstractTableInputFormat
What table is to be read.
getTableName() - Method in class org.apache.flink.addons.hbase.HBaseRowInputFormat
 
getTableName() - Method in class org.apache.flink.addons.hbase.TableInputFormat
What table is to be read.
getTableName() - Method in class org.apache.flink.addons.hbase.TableInputSplit
Returns the table name.
getTableNames() - Method in class org.apache.flink.table.catalog.ExternalCatalogSchema
 
getTableStats() - Method in class org.apache.flink.table.plan.stats.FlinkStatistic
Returns the table statistics.
getTag() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
getTags() - Method in class org.apache.flink.metrics.datadog.DMetric
 
getTarget() - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferEdge
 
getTarget() - Method in class org.apache.flink.graph.Edge
 
getTarget() - Method in class org.apache.flink.optimizer.dag.DagConnection
Gets the target of the connection.
getTarget() - Method in class org.apache.flink.optimizer.plan.Channel
Gets the target of this Channel.
getTarget() - Method in class org.apache.flink.runtime.executiongraph.ExecutionEdge
 
getTarget() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
Returns the vertex connected to this edge.
getTargetAddress() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
 
getTargetAddress() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
getTargetAddress() - Method in class org.apache.flink.runtime.resourcemanager.SlotRequest
 
getTargetEdgeValue() - Method in class org.apache.flink.graph.bipartite.Projection
 
getTargetGateway() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
Gets the RegisteredGateway.
getTargetId() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
 
getTargetLeaderId() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
 
getTargetLocation() - Method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
Returns a custom target location or null if none was specified.
getTargetSlotNumber() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
Gets the number of the slot into which the task is to be deployed.
getTargetState() - Method in class org.apache.flink.cep.nfa.StateTransition
 
getTargetTable(SqlNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
 
getTargetTopic(T) - Method in interface org.apache.flink.streaming.util.serialization.KeyedSerializationSchema
Optional method to determine the target topic for the element
getTargetTopic(T) - Method in class org.apache.flink.streaming.util.serialization.KeyedSerializationSchemaWrapper
 
getTargetTopic(Tuple2<K, V>) - Method in class org.apache.flink.streaming.util.serialization.TypeInformationKeyValueSerializationSchema
 
getTargetVertex() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
 
getTargetVertexValue() - Method in class org.apache.flink.graph.bipartite.Projection
 
getTask() - Method in class org.apache.flink.examples.java.distcp.FileCopyTaskInputSplit
 
getTask(ExecutionAttemptID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Get the task for the given execution attempt id.
getTaskAssignment() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
 
getTaskCancellationInterval() - Method in class org.apache.flink.api.common.ExecutionConfig
Gets the interval (in milliseconds) between consecutive attempts to cancel a running task.
getTaskCancellationTimeout() - Method in class org.apache.flink.api.common.ExecutionConfig
Returns the timeout (in milliseconds) after which an ongoing task cancellation leads to a fatal TaskManager error.
getTaskConfig() - Method in class org.apache.flink.runtime.operators.BatchTask
 
getTaskConfig() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
getTaskConfig() - Method in interface org.apache.flink.runtime.operators.TaskContext
 
getTaskConfiguration() - Method in interface org.apache.flink.runtime.execution.Environment
Returns the task-wide configuration object, originally attached to the job vertex.
getTaskConfiguration() - Method in class org.apache.flink.runtime.executiongraph.TaskInformation
 
getTaskConfiguration() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
Returns the task configuration object which was attached to the original JobVertex.
getTaskConfiguration() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getTaskConfiguration() - Method in class org.apache.flink.runtime.taskmanager.Task
 
getTaskEventDispatcher() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
getTaskExecutionId() - Method in class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
 
getTaskExecutorGateway() - Method in class org.apache.flink.runtime.resourcemanager.registration.TaskExecutorConnection
 
getTaskFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
 
getTaskInfo() - Method in interface org.apache.flink.runtime.execution.Environment
Returns the TaskInfo object associated with this subtask
getTaskInfo() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getTaskInfo() - Method in class org.apache.flink.runtime.taskmanager.Task
 
getTaskKvStateRegistry() - Method in interface org.apache.flink.runtime.execution.Environment
Returns the registry for InternalKvState instances.
getTaskKvStateRegistry() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getTaskManagerActions() - Method in class org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
getTaskManagerAddress() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
getTaskManagerAkkaConfig(int) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
getTaskManagerBindAddress() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
getTaskManagerClass() - Method in class org.apache.flink.yarn.YarnApplicationMasterRunner
 
getTaskManagerConnection() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
getTaskManagerConnection() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
getTaskManagerCount() - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
 
getTaskManagerFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
 
getTaskManagerGateway() - Method in class org.apache.flink.runtime.instance.Instance
Returns the InstanceGateway of this Instance.
getTaskManagerGateway() - Method in class org.apache.flink.runtime.instance.Slot
Gets the actor gateway that can be used to send messages to the TaskManager.
getTaskManagerGateway() - Method in class org.apache.flink.runtime.jobmanager.slots.AllocatedSlot
Gets the actor gateway that can be used to send messages to the TaskManager.
getTaskManagerHostname() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
Get the taskManager hostname.
getTaskManagerID() - Method in class org.apache.flink.runtime.instance.Instance
 
getTaskManagerID() - Method in class org.apache.flink.runtime.instance.Slot
Gets the ID of the TaskManager that offers this slot.
getTaskManagerId() - Method in class org.apache.flink.runtime.jobmanager.slots.AllocatedSlot
Gets the ID of the TaskManager on which this slot was allocated.
getTaskManagerInfo() - Method in interface org.apache.flink.runtime.execution.Environment
Gets the task manager info, with configuration and hostname.
getTaskManagerInfo() - Method in class org.apache.flink.runtime.operators.BatchTask
 
getTaskManagerInfo() - Method in interface org.apache.flink.runtime.operators.TaskContext
 
getTaskManagerInfo() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getTaskManagerJobFormat() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormats
 
getTaskManagerLocation() - Method in class org.apache.flink.runtime.instance.Instance
 
getTaskManagerLocation() - Method in class org.apache.flink.runtime.instance.Slot
Gets the location info of the TaskManager that offers this slot.
getTaskManagerLocation() - Method in class org.apache.flink.runtime.jobmanager.slots.AllocatedSlot
Gets the location info of the TaskManager that offers this slot.
getTaskManagerLocation() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
 
getTaskManagerMetricGroup() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
 
getTaskManagerMetricStore(String) - Method in class org.apache.flink.runtime.webmonitor.metrics.MetricStore
Returns the MetricStore.TaskManagerMetricStore for the given taskmanager ID.
getTaskManagerNumSlots() - Method in class org.apache.flink.client.LocalExecutor
 
getTaskManagerNumSlots() - Method in class org.apache.flink.test.util.AbstractTestBase
 
getTaskManagerProps(Class<? extends TaskManager>, TaskManagerConfiguration, ResourceID, TaskManagerLocation, MemoryManager, IOManager, NetworkEnvironment, MetricRegistry) - Method in class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
getTaskManagerProps(Class<? extends TaskManager>, TaskManagerConfiguration, ResourceID, TaskManagerLocation, MemoryManager, IOManager, NetworkEnvironment, HighAvailabilityServices, MetricRegistry) - Method in class org.apache.flink.runtime.taskmanager.TaskManager$
 
getTaskManagerProps(Class<? extends TaskManager>, TaskManagerConfiguration, ResourceID, TaskManagerLocation, MemoryManager, IOManager, NetworkEnvironment, HighAvailabilityServices, MetricRegistry) - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
 
getTaskManagerRemoteReference(String, ActorSystem, FiniteDuration) - Method in class org.apache.flink.runtime.taskmanager.TaskManager$
Resolves the TaskManager actor reference in a blocking fashion.
getTaskManagerRemoteReference(String, ActorSystem, FiniteDuration) - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
Resolves the TaskManager actor reference in a blocking fashion.
getTaskManagerRequestTimeout() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
 
getTaskManagers() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
getTaskManagersAsJava() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
getTaskManagerShellCommand(Configuration, ContaineredTaskManagerParameters, String, String, boolean, boolean, boolean, Class<?>) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
Generates the shell command to start a task manager.
getTaskManagerSlots() - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
 
getTaskManagerTimeout() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
 
getTaskMetricStore(String, String) - Method in class org.apache.flink.runtime.webmonitor.metrics.MetricStore
Returns the MetricStore.TaskMetricStore for the given job/task ID.
getTaskMetricStore(String) - Method in class org.apache.flink.runtime.webmonitor.metrics.MetricStore.JobMetricStore
 
getTaskName() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Returns the name of the task in which the UDF runs, as assigned during plan construction.
getTaskName() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getTaskName() - Method in class org.apache.flink.api.common.TaskInfo
Returns the name of the task
getTaskName() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getTaskName() - Method in class org.apache.flink.runtime.executiongraph.TaskInformation
 
getTaskName() - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
 
getTaskName() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
getTaskName() - Method in class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
 
getTaskName() - Method in class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
 
getTaskName() - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
 
getTaskName() - Method in class org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
 
getTaskName() - Method in exception org.apache.flink.runtime.operators.chaining.ExceptionInChainedStubException
 
getTaskName() - Method in class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
 
getTaskName() - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
 
getTaskName() - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
 
getTaskName() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getTaskNameWithSubtaskIndex() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionVertex
Returns the name of this execution vertex in the format "myTask (2/7)".
getTaskNameWithSubtaskIndex() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionVertex
 
getTaskNameWithSubtaskIndex() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
Creates a simple name representation in the style 'taskname (x/y)', where 'taskname' is the name as returned by ExecutionVertex.getTaskName(), 'x' is the parallel subtask index as returned by ExecutionVertex.getParallelSubtaskIndex()+ 1, and 'y' is the total number of tasks, as returned by ExecutionVertex.getTotalNumberOfParallelSubtasks().
getTaskNameWithSubtasks() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Returns the name of the task, appended with the subtask indicator, such as "MyTask (3/6)", where 3 would be (RuntimeContext.getIndexOfThisSubtask() + 1), and 6 would be RuntimeContext.getNumberOfParallelSubtasks().
getTaskNameWithSubtasks() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getTaskNameWithSubtasks() - Method in class org.apache.flink.api.common.TaskInfo
Returns the name of the task, appended with the subtask indicator, such as "MyTask (3/6)", where 3 would be (TaskInfo.getIndexOfThisSubtask() + 1), and 6 would be TaskInfo.getNumberOfParallelSubtasks().
getTasks() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
Get all tasks running in this task slot.
getTasks(JobID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Return an iterator over all tasks for a given job.
getTaskSlotTable() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServices
 
getTaskStateHandles() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
 
getTaskStateHandles() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
getTaskStates() - Method in class org.apache.flink.migration.runtime.checkpoint.savepoint.SavepointV0
 
getTaskStates() - Method in interface org.apache.flink.runtime.checkpoint.savepoint.Savepoint
Deprecated.
Only kept for backwards-compatibility with versionS < 1.3. Will be removed in the future.
getTaskStates() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
 
getTaskStates() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
 
getTaskStateStats(JobVertexID) - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
Returns the task state stats for the given job vertex ID or null if no task with such an ID is available.
getTaskToExecute() - Method in class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
 
getTaskVertices() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionJobVertex
Returns all execution vertices for this job vertex.
getTaskVertices() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionJobVertex
 
getTaskVertices() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
getTebiBytes() - Method in class org.apache.flink.configuration.MemorySize
Gets the memory size in Tebibytes (= 1024 Gibibytes).
getTempDir() - Static method in class org.apache.flink.core.testutils.CommonTestUtils
Reads the path to the directory for temporary files from the configuration and returns it.
getTempDirPath(String) - Method in class org.apache.flink.test.util.AbstractTestBase
 
getTempFilePath(String) - Method in class org.apache.flink.test.util.AbstractTestBase
 
getTemplateType(Class<?>, int) - Static method in class org.apache.flink.util.ReflectionUtil
 
getTemplateType(Class<?>, Class<?>, int) - Static method in class org.apache.flink.util.ReflectionUtil
 
getTemplateType1(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
 
getTemplateType1(Type) - Static method in class org.apache.flink.util.ReflectionUtil
 
getTemplateType2(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
 
getTemplateType3(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
 
getTemplateType4(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
 
getTemplateType5(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
 
getTemplateType6(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
 
getTemplateType7(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
 
getTemplateType8(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
 
getTemplateTypeInfos() - Method in class org.apache.flink.util.ReflectionUtil.FullTypeInfo
 
getTemplateTypes(ParameterizedType) - Static method in class org.apache.flink.util.ReflectionUtil
 
getTemplateTypes(Class<?>) - Static method in class org.apache.flink.util.ReflectionUtil
 
getTempMode() - Method in class org.apache.flink.optimizer.plan.Channel
 
getTemporaryFileDirectory() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
Gets the directory for temporary files, as returned by the JVM system property "java.io.tmpdir".
getter() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.FieldDescriptor
 
getTerminationCriterion() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
 
getTerminationCriterion() - Method in class org.apache.flink.api.java.operators.BulkIterationResultSet
 
getTerminationFuture() - Method in class org.apache.flink.runtime.executiongraph.Execution
Gets a future that completes once the task execution reaches a terminal state.
getTerminationFuture() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getTerminationFuture() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
getTerminationFuture() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
Return a future which is completed when the rpc endpoint has been terminated.
getTerminationFuture() - Method in interface org.apache.flink.runtime.rpc.RpcService
Returns a future indicating when the RPC service has been shut down.
getTerminationFuture() - Method in interface org.apache.flink.runtime.rpc.SelfGateway
Return a future which is completed when the rpc endpoint has been terminated.
getTerminationFuture() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
 
getters() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.CaseClassDescriptor
 
getters() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.PojoDescriptor
 
getTestKeytab() - Static method in class org.apache.flink.test.util.SecureTestEnvironment
 
getText() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.HashTags
 
getText() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Symbol
 
getText() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
getTheta0() - Method in class org.apache.flink.examples.java.ml.LinearRegression.Params
 
getTheta1() - Method in class org.apache.flink.examples.java.ml.LinearRegression.Params
 
getThirdVertex() - Method in class org.apache.flink.graph.library.TriangleEnumerator.Triad
 
getTieEdgeDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.CommunityDetectionData
 
getTieEdgeDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.LabelPropagationData
 
getTieVertexSet(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.LabelPropagationData
 
getTime_zone() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getTimeCharacteristic() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getTimeNanos() - Method in class org.apache.flink.runtime.rpc.akka.messages.RunAsync
 
getTimeout(Configuration) - Method in class org.apache.flink.runtime.akka.AkkaUtils$
 
getTimeout(Configuration) - Static method in class org.apache.flink.runtime.akka.AkkaUtils
 
getTimeout() - Method in class org.apache.flink.runtime.client.JobListeningContext
 
getTimeout() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerConfiguration
 
getTimeout() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getTimerServiceShutdownTimeout() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
getTimes() - Method in class org.apache.flink.cep.pattern.Pattern
 
getTimestamp() - Method in class org.apache.flink.cep.nfa.ComputationState
 
getTimestamp() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetaData
 
getTimestamp() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
getTimestamp() - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
 
getTimestamp() - Method in class org.apache.flink.runtime.messages.checkpoint.NotifyCheckpointComplete
 
getTimestamp() - Method in class org.apache.flink.runtime.messages.checkpoint.TriggerCheckpoint
 
getTimestamp() - Method in interface org.apache.flink.streaming.api.operators.async.queue.AsyncCollectionResult
 
getTimestamp() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamRecordQueueEntry
 
getTimestamp() - Method in class org.apache.flink.streaming.api.operators.InternalTimer
 
getTimestamp() - Method in class org.apache.flink.streaming.api.watermark.Watermark
Returns the timestamp associated with this Watermark in milliseconds.
getTimestamp() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
Returns the timestamp when this event arrived at the source.
getTimestamp() - Method in class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
 
getTimestamp() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
Returns the timestamp associated with this stream value in milliseconds.
getTimestampForRecord(T, long) - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionStateWithPeriodicWatermarks
 
getTimestampForRecord(T, long) - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionStateWithPunctuatedWatermarks
 
getTimeZone() - Method in class org.apache.flink.table.api.TableConfig
Returns the timezone for date/time/timestamp conversions.
getTitle() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
 
getTmpDirectories() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
getTmpDirectories() - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo
Gets the list of temporary file directories.
getTmpDirPaths() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
getTo() - Method in class org.apache.flink.util.LongValueSequenceIterator
 
getTo() - Method in class org.apache.flink.util.NumberSequenceIterator
 
getTopic() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartition
 
getTopic() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionState
 
getTopicPartition() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionLeader
 
getTopId() - Method in class org.apache.flink.graph.bipartite.BipartiteEdge
 
getTopology(String) - Method in class org.apache.flink.storm.api.FlinkLocalCluster
 
getTopologyConf(String) - Method in class org.apache.flink.storm.api.FlinkLocalCluster
 
getTopologyInfo(String) - Method in class org.apache.flink.storm.api.FlinkLocalCluster
 
GetTopSongPerUser() - Constructor for class org.apache.flink.graph.examples.MusicProfiles.GetTopSongPerUser
 
getTopVertices() - Method in class org.apache.flink.graph.bipartite.BipartiteGraph
Get dataset with top vertices.
getTotalCount() - Method in class org.apache.flink.api.java.summarize.ColumnSummary
The number of all rows in this column including both nulls and non-nulls
getTotalFields() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
Gets the number of logical fields in this type.
getTotalFields() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.java.typeutils.ListTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
getTotalFields() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.scala.typeutils.EitherTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.scala.typeutils.EnumValueTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.scala.typeutils.OptionTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.scala.typeutils.ScalaNothingTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.scala.typeutils.TraversableTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.scala.typeutils.TryTypeInfo
 
getTotalFields() - Method in class org.apache.flink.api.scala.typeutils.UnitTypeInfo
 
getTotalFields() - Method in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
 
getTotalFields() - Method in class org.apache.flink.table.runtime.types.CRowTypeInfo
 
getTotalFields() - Method in class org.apache.flink.table.typeutils.InternalTypeInfo
 
getTotalFields() - Static method in class org.apache.flink.table.typeutils.RowIntervalTypeInfo
 
getTotalFields() - Static method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
 
getTotalFields() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
 
getTotalInputSize() - Method in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
Gets the file size.
getTotalInputSize() - Method in interface org.apache.flink.api.common.io.statistics.BaseStatistics
Gets the total size of the input.
getTotalNumberOfBuffers() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
Returns the total number of processed network buffers since initialization.
getTotalNumberOfBuffers() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
getTotalNumberOfBytes() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
Returns the total size of processed network buffers since initialization.
getTotalNumberOfBytes() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
getTotalNumberOfCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.CheckpointStatsCounts
Returns the total number of checkpoints (in progress, completed, failed).
getTotalNumberOfMemorySegments() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
getTotalNumberOfParallelSubtasks() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
getTotalNumberOfSlots() - Method in class org.apache.flink.runtime.instance.Instance
 
getTotalNumberOfSlots() - Method in class org.apache.flink.runtime.instance.InstanceManager
 
getTotalNumberOfSlots() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
getTotalNumberOfSplits() - Method in class org.apache.flink.core.io.GenericInputSplit
 
getTotalNumberOfVertices() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getTotalNumPages() - Method in class org.apache.flink.runtime.memory.MemoryManager
Gets the total number of memory pages managed by this memory manager.
getTraitClass() - Method in class org.apache.flink.table.plan.nodes.datastream.AccModeTraitDef
 
getTraitClass() - Method in class org.apache.flink.table.plan.nodes.datastream.UpdateAsRetractionTraitDef
 
getTraitDef() - Method in class org.apache.flink.table.plan.nodes.datastream.AccModeTrait
 
getTraitDef() - Method in class org.apache.flink.table.plan.nodes.datastream.UpdateAsRetractionTrait
 
getTraitDef() - Static method in class org.apache.flink.table.plan.rules.dataSet.BatchTableSourceScanRule
 
getTraitDef() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateRule
 
getTraitDef() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateWithNullValuesRule
 
getTraitDef() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetCalcRule
 
getTraitDef() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetCorrelateRule
 
getTraitDef() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetDistinctRule
 
getTraitDef() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetIntersectRule
 
getTraitDef() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetJoinRule
 
getTraitDef() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetMinusRule
 
getTraitDef() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetScanRule
 
getTraitDef() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetSingleRowJoinRule
 
getTraitDef() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetSortRule
 
getTraitDef() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetUnionRule
 
getTraitDef() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetValuesRule
 
getTraitDef() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetWindowAggregateRule
 
getTraitDef() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamCalcRule
 
getTraitDef() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamCorrelateRule
 
getTraitDef() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupAggregateRule
 
getTraitDef() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupWindowAggregateRule
 
getTraitDef() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamOverAggregateRule
 
getTraitDef() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamScanRule
 
getTraitDef() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamUnionRule
 
getTraitDef() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamValuesRule
 
getTraitDef() - Static method in class org.apache.flink.table.plan.rules.datastream.StreamTableSourceScanRule
 
getTraitSet() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
getTraitSet() - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
getTraitSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
getTraitSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
getTraitSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
getTraitSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
getTraitSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
getTraitSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
getTraitSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
getTraitSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
getTraitSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
getTraitSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
getTraitSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
getTraitSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
getTraitSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
getTraitSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getTransformation() - Method in class org.apache.flink.streaming.api.datastream.DataStream
Returns the StreamTransformation that represents the operation that logically creates this DataStream.
getTransformation() - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
Returns the transformation that contains the actual sink operator of this sink.
getTransformation() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010.FlinkKafkaProducer010Configuration
 
getTransformationUID() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getTransitiveChainedTaskConfigs(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
 
getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
 
getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
 
getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.PartitionTransformation
 
getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.SelectTransformation
 
getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.SideOutputTransformation
 
getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
 
getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
 
getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.SplitTransformation
 
getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
Returns all transitive predecessor StreamTransformations of this StreamTransformation.
getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
 
getTransitivePredecessors() - Method in class org.apache.flink.streaming.api.transformations.UnionTransformation
 
getTransportType() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
getTrgVertex() - Method in class org.apache.flink.graph.Triplet
 
getTriangleCount() - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient.Result
Get the number of triangles containing this vertex; equivalently, this is the number of edges between neighbors of this vertex.
getTriangleCount() - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient.Result
Get the number of triangles containing this vertex; equivalently, this is the number of edges between neighbors of this vertex.
getTrigger() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
getTriggerHandler() - Method in class org.apache.flink.runtime.webmonitor.handlers.JobCancellationWithSavepointHandlers
 
getTriggerTimestamp() - Method in class org.apache.flink.runtime.checkpoint.AbstractCheckpointStats
Returns the timestamp when the checkpoint was triggered.
getTriplets() - Method in class org.apache.flink.graph.Graph
This method allows access to the graph's edge values along with its source and target vertex values.
getTriplets() - Method in class org.apache.flink.graph.scala.Graph
 
getTrueArray(int) - Static method in class org.apache.flink.optimizer.plan.SingleInputPlanNode
 
getTrueCount() - Method in class org.apache.flink.api.java.summarize.BooleanColumnSummary
 
getTupleClass(int) - Static method in class org.apache.flink.api.java.tuple.Tuple
Gets the class corresponding to the tuple of the given arity (dimensions).
getTupleClass() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
getTupleClass() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerConfigSnapshot
 
getTuples(RelInput) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
getTuples() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
getTweetLevel() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
getTwitter() - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Attributes
 
getTwo() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
 
getTwoInputNode() - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
 
getType(int) - Method in class org.apache.flink.api.common.operators.Ordering
 
getType() - Method in class org.apache.flink.api.common.state.AggregatingStateDescriptor
 
getType() - Method in class org.apache.flink.api.common.state.FoldingStateDescriptor
Deprecated.
 
getType() - Method in class org.apache.flink.api.common.state.ListStateDescriptor
 
getType() - Method in class org.apache.flink.api.common.state.MapStateDescriptor
 
getType() - Method in class org.apache.flink.api.common.state.ReducingStateDescriptor
 
getType() - Method in class org.apache.flink.api.common.state.StateDescriptor
 
getType() - Method in class org.apache.flink.api.common.state.ValueStateDescriptor
 
getType() - Method in class org.apache.flink.api.common.typeutils.CompositeType.FlatFieldDescriptor
 
getType() - Method in class org.apache.flink.api.java.DataSet
Returns the TypeInformation for the type of this DataSet.
getType() - Method in class org.apache.flink.api.java.operators.DataSink
 
getType() - Method in class org.apache.flink.api.java.utils.Option
 
getType() - Static method in class org.apache.flink.api.scala.CrossDataSet
 
getType() - Method in class org.apache.flink.api.scala.DataSet
Returns the TypeInformation for the elements of this DataSet.
getType() - Method in class org.apache.flink.contrib.tweetinputformat.model.places.BoundingBox
 
getType() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Coordinates
 
getType() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Media
 
getType() - Method in class org.apache.flink.metrics.datadog.DMetric
 
getType() - Method in class org.apache.flink.migration.api.common.state.ListStateDescriptor
Deprecated.
 
getType(int) - Method in class org.apache.flink.optimizer.postpass.AbstractSchema
 
getType() - Method in class org.apache.flink.python.api.types.CustomTypeWrapper
 
getType() - Method in class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
 
getType() - Method in exception org.apache.flink.runtime.broadcast.InitializationTypeConflictException
 
getType() - Method in class org.apache.flink.streaming.api.datastream.DataStream
Gets the type of the stream.
getType() - Method in class org.apache.flink.streaming.api.scala.DataStream
Deprecated.
Use dataType instead.
getType(int) - Method in class org.apache.flink.table.api.TableSchema
Returns the specified type information for the given column index.
getType(String) - Method in class org.apache.flink.table.api.TableSchema
Returns the specified type information for the given column name.
getType() - Method in class org.apache.flink.table.explain.Node
 
getType1() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
Gets the type of the first input.
getType2() - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
Gets the type of the second input.
getTypeAt(String) - Method in class org.apache.flink.api.common.typeutils.CompositeType
Returns the type of the (nested) field at the given field expression position.
getTypeAt(int) - Method in class org.apache.flink.api.common.typeutils.CompositeType
Returns the type of the (unnested) field at the given field position.
getTypeAt(String) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
getTypeAt(int) - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
getTypeAt(String) - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
 
getTypeAt(String) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
getTypeAt(int) - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
getTypeAt(String) - Method in class org.apache.flink.api.scala.typeutils.CaseClassTypeInfo
 
getTypeAt(String) - Method in class org.apache.flink.table.runtime.types.CRowTypeInfo
 
getTypeAt(int) - Method in class org.apache.flink.table.runtime.types.CRowTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
Gets the class of the type represented by this type information.
getTypeClass() - Method in class org.apache.flink.api.common.typeutils.CompositeType
Returns the type class of the composite type
getTypeClass() - Method in class org.apache.flink.api.common.typeutils.GenericTypeSerializerConfigSnapshot
 
getTypeClass() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.java.typeutils.ListTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.scala.typeutils.EitherTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.scala.typeutils.EnumValueTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.scala.typeutils.OptionTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.scala.typeutils.ScalaNothingTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.scala.typeutils.TraversableTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.scala.typeutils.TryTypeInfo
 
getTypeClass() - Method in class org.apache.flink.api.scala.typeutils.UnitTypeInfo
 
getTypeClass() - Method in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
 
getTypeClass() - Static method in class org.apache.flink.table.runtime.types.CRowTypeInfo
 
getTypeClass() - Method in class org.apache.flink.table.typeutils.InternalTypeInfo
 
getTypeClass() - Static method in class org.apache.flink.table.typeutils.RowIntervalTypeInfo
 
getTypeClass() - Static method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
 
getTypeClass() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
 
getTypeException() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
getTypeFactory() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
 
getTypeFactory() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
 
getTypeFactory() - Method in class org.apache.flink.table.api.TableEnvironment
Returns the FlinkTypeFactory of this TableEnvironment.
getTypeFactory() - Method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
getTypeInfo() - Method in class org.apache.flink.api.common.typeinfo.TypeHint
Gets the type information described by this TypeHint.
getTypeInfo() - Static method in class org.apache.flink.streaming.api.scala.OutputTag
 
getTypeInfo() - Method in class org.apache.flink.util.OutputTag
 
getTypeInfoFactory(Type) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
Returns the type information factory for a type using the factory registry or annotations.
getTypeInformation() - Method in class org.apache.flink.api.java.typeutils.PojoField
 
getTypeInfoSize() - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.Serializer
 
getTypeInfoSize() - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.TupleSerializer
 
getTypeName() - Method in class org.apache.flink.graph.drivers.input.GeneratedGraph
Get the name of the type.
getTypeNumber() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
 
getTypes() - Method in class org.apache.flink.api.common.operators.Ordering
 
getTypes() - Method in class org.apache.flink.table.api.TableSchema
Returns all type information as an array.
getTypeSerializer() - Method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil.TypeSerializerSerializationProxy
 
getTypeSerializer() - Method in class org.apache.flink.cep.NonDuplicatingTypeSerializer
 
getTypeSerializerIn1(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getTypeSerializerIn1() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getTypeSerializerIn2(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getTypeSerializerIn2() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getTypeSerializerOut(ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getTypeSerializerOut() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getTypeSerializerSideOut(OutputTag<?>, ClassLoader) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getTypeSystem() - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
getTypeToInstantiate() - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer.AvroSerializerConfigSnapshot
 
getUdfRuntimeContext() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
getUDTDescriptor(scala.reflect.macros.Context.universe) - Method in interface org.apache.flink.api.scala.codegen.TypeAnalyzer
 
getUid() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
Returns the user-specified ID of this transformation.
getUnaryOperatorReturnType(Function, Class<?>, int, int, int[], int[], TypeInformation<IN>, String, boolean) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractor
Returns the unary operator's return type.
getUnavailableResponse() - Static method in class org.apache.flink.runtime.webmonitor.handlers.HandlerRedirectUtils
 
getUndirected() - Method in class org.apache.flink.graph.Graph
This operation adds all inverse-direction edges to the graph.
getUndirected() - Method in class org.apache.flink.graph.scala.Graph
This operation adds all inverse-direction edges to the graph.
getUnguardedFileSystem(URI) - Static method in class org.apache.flink.core.fs.FileSystem
 
getUnionListState(ListStateDescriptor<S>) - Method in interface org.apache.flink.api.common.state.OperatorStateStore
Creates (or restores) a list state.
getUnionListState(ListStateDescriptor<S>) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
 
getUniqueFieldCombination() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
 
getUniqueFields() - Method in class org.apache.flink.api.common.operators.CompilerHints
Gets the FieldSets that are unique
getUniqueFields() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
Gets the FieldSets which are unique in the output of the node.
getUniqueFields() - Method in class org.apache.flink.optimizer.dataproperties.LocalProperties
Gets the fields whose combination is unique within the data set.
getUniqueInternalName(String) - Method in class org.apache.flink.cep.nfa.compiler.NFAStateNameHandler
Used to give a unique name to NFA states created during the translation process.
getUniqueKeyFields(RelNode) - Method in class org.apache.flink.table.api.StreamTableEnvironment
Extracts the unique keys of the table produced by the plan.
getUnit() - Method in class org.apache.flink.api.common.time.Time
Gets the time unit for this policy's time interval.
getUnit() - Method in class org.apache.flink.streaming.api.windowing.time.Time
Gets the time unit for this policy's time interval.
getUnixEpochTimestamp() - Static method in class org.apache.flink.metrics.datadog.DMetric
 
getUnsortedGrouping(int) - Method in class org.apache.flink.python.api.util.SetCache
Returns the cached UnsortedGrouping for the given ID.
getUnwrappedKvStates(Set<Integer>) - Method in class org.apache.flink.migration.runtime.checkpoint.TaskState
Deprecated.
Retrieve the set of key-value state key groups specified by the given key group partition set.
getUpperPart() - Method in class org.apache.flink.util.AbstractID
Gets the upper 64 bits of the ID.
getUri() - Method in class org.apache.flink.core.fs.FileSystem
Returns a URI whose scheme and authority identify this file system.
getUri() - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
getUri() - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
getUri() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
 
getUri() - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
 
getUri() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig
Retrieve the URI.
getUrl() - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Attributes
 
getUrl() - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Places
 
getUrl() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Media
 
getUrl() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.URL
 
getUrl() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getURL(BlobKey) - Method in class org.apache.flink.runtime.blob.BlobCache
Returns the URL for the BLOB with the given key.
getURL(BlobKey) - Method in class org.apache.flink.runtime.blob.BlobServer
Method which retrieves the URL of a file associated with a blob key.
getURL(BlobKey) - Method in interface org.apache.flink.runtime.blob.BlobService
This method returns the URL of the file associated with the provided blob key.
getUrls() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Entities
 
getUsage() - Method in class org.apache.flink.graph.drivers.input.CirculantGraph
 
getUsage() - Method in class org.apache.flink.graph.drivers.input.GridGraph
 
getUsage() - Method in class org.apache.flink.graph.drivers.parameter.BooleanParameter
 
getUsage() - Method in class org.apache.flink.graph.drivers.parameter.ChoiceParameter
 
getUsage() - Method in class org.apache.flink.graph.drivers.parameter.IterationConvergence
 
getUsage() - Method in interface org.apache.flink.graph.drivers.parameter.Parameter
An informal usage string.
getUsage() - Method in interface org.apache.flink.graph.drivers.parameter.Parameterized
Human-readable format for the command-line usage string.
getUsage() - Method in class org.apache.flink.graph.drivers.parameter.ParameterizedBase
 
getUsage() - Method in class org.apache.flink.graph.drivers.parameter.SimpleParameter
 
getUsage() - Method in class org.apache.flink.graph.drivers.parameter.Simplify
 
getUseLargeRecordHandler() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getUser() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
getUser() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
 
getUser_mentions() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Entities
 
getUserAccumulators() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getUserAccumulators() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
getUserAccumulatorsStringified() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecution
Returns the user-defined accumulators as strings.
getUserAccumulatorsStringified() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecution
 
getUserAccumulatorsStringified() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
getUserClassLoader() - Method in interface org.apache.flink.runtime.execution.Environment
Returns the user code class loader
getUserClassLoader() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getUserClassLoader() - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getUserCodeAnnotation(Class<A>) - Method in class org.apache.flink.api.common.operators.util.UserCodeClassWrapper
 
getUserCodeAnnotation(Class<A>) - Method in class org.apache.flink.api.common.operators.util.UserCodeObjectWrapper
 
getUserCodeAnnotation(Class<A>) - Method in interface org.apache.flink.api.common.operators.util.UserCodeWrapper
Gets an annotation that pertains to the user code class.
getUserCodeClass() - Method in class org.apache.flink.api.common.operators.util.UserCodeClassWrapper
 
getUserCodeClass() - Method in class org.apache.flink.api.common.operators.util.UserCodeObjectWrapper
 
getUserCodeClass() - Method in interface org.apache.flink.api.common.operators.util.UserCodeWrapper
Gets the class of the user code.
getUserCodeClassLoader() - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Gets the ClassLoader to load classes that were are not in system's classpath, but are part of the jar file of a user job.
getUserCodeClassLoader() - Method in class org.apache.flink.api.common.functions.util.AbstractRuntimeUDFContext
 
getUserCodeClassLoader() - Method in class org.apache.flink.api.common.typeutils.TypeSerializerConfigSnapshot
Returns the user code class loader.
getUserCodeClassLoader() - Method in class org.apache.flink.client.program.ContextEnvironment
 
getUserCodeClassLoader() - Method in class org.apache.flink.client.program.JobWithJars
Gets the ClassLoader that must be used to load user code classes.
getUserCodeClassLoader() - Method in class org.apache.flink.client.program.PackagedProgram
Gets the ClassLoader that must be used to load user code classes.
getUserCodeClassLoader() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
Returns the user code class loader of this invokable.
getUserCodeClassLoader() - Method in interface org.apache.flink.runtime.operators.TaskContext
 
getUserCodeClassloader() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
getUserCodeClassLoaderInfo(ClassLoader) - Static method in class org.apache.flink.runtime.util.ClassLoaderUtil
Gets information about URL class loaders.
getUserCodeObject(Class<? super T>, ClassLoader) - Method in class org.apache.flink.api.common.operators.util.UserCodeClassWrapper
 
getUserCodeObject() - Method in class org.apache.flink.api.common.operators.util.UserCodeClassWrapper
 
getUserCodeObject(Class<? super T>, ClassLoader) - Method in class org.apache.flink.api.common.operators.util.UserCodeObjectWrapper
 
getUserCodeObject() - Method in class org.apache.flink.api.common.operators.util.UserCodeObjectWrapper
 
getUserCodeObject(Class<? super T>, ClassLoader) - Method in interface org.apache.flink.api.common.operators.util.UserCodeWrapper
Gets the user code object, which may be either a function or an input or output format.
getUserCodeObject() - Method in interface org.apache.flink.api.common.operators.util.UserCodeWrapper
Gets the user code object.
getUserCodeWrapper() - Method in class org.apache.flink.api.common.operators.AbstractUdfOperator
Gets the function that is held by this operator.
getUserCodeWrapper() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.PartialSolutionPlaceHolder
 
getUserCodeWrapper() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase.SolutionSetPlaceHolder
 
getUserCodeWrapper() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase.WorksetPlaceHolder
 
getUserCodeWrapper() - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
Gets the class describing the output format.
getUserCodeWrapper() - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
Gets the class describing the input format.
getUserCodeWrapper() - Method in class org.apache.flink.api.common.operators.Operator
Gets the user code wrapper.
getUserDefinedMethod(UserDefinedFunction, String, Class<?>[]) - Method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils$
Returns user defined method matching the given name and signature.
getUserDefinedMethod(UserDefinedFunction, String, Class<?>[]) - Static method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils
Returns user defined method matching the given name and signature.
getUserDefinedOperatorIDs() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
Returns a list containing the alternative IDs of all operators contained in this execution job vertex.
getUserDefinedOperatorIDs() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
getUserFunction() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
Gets the user function executed in this operator.
getUserFunctionParameters() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
Since the streaming API does not implement any parametrization of functions via a configuration, the config returned here is actually empty.
getUserHash() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
getUserJarBlobKeys() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Returns a set of BLOB keys referring to the JAR files required to run this job.
getUserJars() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Gets the list of assigned user jar paths.
getUserMap() - Method in class org.apache.flink.runtime.accumulators.AccumulatorRegistry
Gets the map for user-defined accumulators.
getUsername() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig
Retrieve the user name.
getUserProvidedNodeHash() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
Gets the user provided hash.
getUserRunning() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
Gets the name of the user that is running the JVM.
getUserSongTriplets(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.MusicProfilesData
 
getUseSingleRpcSystem() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
getUtc_offset() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
getValidator() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
 
getValue(BooleanValue) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.BooleanValueSummaryAggregator
 
getValue(DoubleValue) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.DoubleValueSummaryAggregator
 
getValue(FloatValue) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.FloatValueSummaryAggregator
 
getValue(VT) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator
Get the value out of a value type.
getValue(IntValue) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.IntegerValueSummaryAggregator
 
getValue(LongValue) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.LongValueSummaryAggregator
 
getValue(ShortValue) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.ShortValueSummaryAggregator
 
getValue(StringValue) - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.StringValueSummaryAggregator
 
getValue() - Method in class org.apache.flink.api.scala.metrics.ScalaGauge
 
getValue(ConfigOption<?>) - Method in class org.apache.flink.configuration.Configuration
Returns the value associated with the given config option as a string.
getValue(ConfigOption<?>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
getValue() - Method in class org.apache.flink.dropwizard.metrics.FlinkGaugeWrapper
 
getValue() - Method in class org.apache.flink.graph.bipartite.BipartiteEdge
 
getValue() - Method in class org.apache.flink.graph.drivers.parameter.IterationConvergence
 
getValue() - Method in interface org.apache.flink.graph.drivers.parameter.Parameter
Get the parameter value.
getValue() - Method in class org.apache.flink.graph.drivers.parameter.SimpleParameter
 
getValue() - Method in class org.apache.flink.graph.drivers.parameter.Simplify
 
getValue() - Method in class org.apache.flink.graph.Edge
 
getValue() - Method in class org.apache.flink.graph.Vertex
 
getValue() - Method in interface org.apache.flink.metrics.Gauge
Calculates and returns the measured value.
getValue() - Method in interface org.apache.flink.metrics.jmx.JMXReporter.JmxGaugeMBean
 
getValue() - Method in class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
 
getValue() - Method in class org.apache.flink.runtime.executiongraph.metrics.DownTimeGauge
 
getValue() - Method in class org.apache.flink.runtime.executiongraph.metrics.NumberOfFullRestartsGauge
 
getValue() - Method in class org.apache.flink.runtime.executiongraph.metrics.RestartTimeGauge
 
getValue() - Method in class org.apache.flink.runtime.executiongraph.metrics.UpTimeGauge
 
getValue() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedValue
 
getValue() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperVersionedValue
 
getValue(int) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getValue() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator.LatencyGauge
 
getValue() - Method in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter.AvroKeyValue
 
getValue() - Method in class org.apache.flink.streaming.connectors.kafka.internals.metrics.KafkaMetricWrapper
 
getValue() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap.Entry
 
getValue() - Method in class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
 
getValue() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
Returns the value wrapped in this stream value.
getValue(BigIntegralAvgAccumulator) - Method in class org.apache.flink.table.functions.aggfunctions.BigIntegralAvgAggFunction
 
getValue(CountAccumulator) - Method in class org.apache.flink.table.functions.aggfunctions.CountAggFunction
 
getValue(DecimalAvgAccumulator) - Method in class org.apache.flink.table.functions.aggfunctions.DecimalAvgAggFunction
 
getValue(DecimalSumAccumulator) - Method in class org.apache.flink.table.functions.aggfunctions.DecimalSum0AggFunction
 
getValue(DecimalSumWithRetractAccumulator) - Method in class org.apache.flink.table.functions.aggfunctions.DecimalSum0WithRetractAggFunction
 
getValue(DecimalSumAccumulator) - Method in class org.apache.flink.table.functions.aggfunctions.DecimalSumAggFunction
 
getValue(DecimalSumWithRetractAccumulator) - Method in class org.apache.flink.table.functions.aggfunctions.DecimalSumWithRetractAggFunction
 
getValue(FloatingAvgAccumulator) - Method in class org.apache.flink.table.functions.aggfunctions.FloatingAvgAggFunction
 
getValue(IntegralAvgAccumulator) - Method in class org.apache.flink.table.functions.aggfunctions.IntegralAvgAggFunction
 
getValue(MaxAccumulator<T>) - Method in class org.apache.flink.table.functions.aggfunctions.MaxAggFunction
 
getValue(MaxWithRetractAccumulator<T>) - Method in class org.apache.flink.table.functions.aggfunctions.MaxWithRetractAggFunction
 
getValue(MinAccumulator<T>) - Method in class org.apache.flink.table.functions.aggfunctions.MinAggFunction
 
getValue(MinWithRetractAccumulator<T>) - Method in class org.apache.flink.table.functions.aggfunctions.MinWithRetractAggFunction
 
getValue(SumAccumulator<T>) - Method in class org.apache.flink.table.functions.aggfunctions.Sum0AggFunction
 
getValue(SumWithRetractAccumulator<T>) - Method in class org.apache.flink.table.functions.aggfunctions.Sum0WithRetractAggFunction
 
getValue(SumAccumulator<T>) - Method in class org.apache.flink.table.functions.aggfunctions.SumAggFunction
 
getValue(SumWithRetractAccumulator<T>) - Method in class org.apache.flink.table.functions.aggfunctions.SumWithRetractAggFunction
 
getValue(ACC) - Method in class org.apache.flink.table.functions.AggregateFunction
Called every time when an aggregation result should be materialized.
getValue() - Method in class org.apache.flink.types.BooleanValue
 
getValue() - Method in class org.apache.flink.types.ByteValue
Returns the value of the encapsulated byte.
getValue() - Method in class org.apache.flink.types.CharValue
Returns the value of the encapsulated char.
getValue() - Method in class org.apache.flink.types.DoubleValue
Returns the value of the encapsulated primitive double.
getValue() - Method in class org.apache.flink.types.FloatValue
Returns the value of the encapsulated primitive float.
getValue() - Method in class org.apache.flink.types.IntValue
Returns the value of the encapsulated int.
getValue() - Method in class org.apache.flink.types.LongValue
Returns the value of the encapsulated long.
getValue() - Method in class org.apache.flink.types.ShortValue
Returns the value of the encapsulated short.
getValue() - Method in class org.apache.flink.types.StringValue
Gets this StringValue as a String.
getValueByField(String) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getValueByName(String) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getValues() - Method in class org.apache.flink.api.common.operators.util.ListKeyGroupedIterator
Returns an iterator over all values that belong to the current key.
getValues() - Method in class org.apache.flink.metrics.HistogramStatistics
Returns the elements of the statistics' sample
getValues() - Method in interface org.apache.flink.runtime.util.KeyGroupedIterator
 
getValues() - Method in class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator
Returns an iterator over all values that belong to the current key.
getValues() - Method in class org.apache.flink.runtime.util.ReusingKeyGroupedIterator
Returns an iterator over all values that belong to the current key.
getValues() - Method in class org.apache.flink.storm.wrappers.StormTuple
 
getValues1() - Method in class org.apache.flink.runtime.operators.sort.NonReusingSortMergeCoGroupIterator
 
getValues1() - Method in class org.apache.flink.runtime.operators.sort.ReusingSortMergeCoGroupIterator
 
getValues1() - Method in interface org.apache.flink.runtime.operators.util.CoGroupTaskIterator
Returns an iterable over the left input values for the current key.
getValues2() - Method in class org.apache.flink.runtime.operators.sort.NonReusingSortMergeCoGroupIterator
 
getValues2() - Method in class org.apache.flink.runtime.operators.sort.ReusingSortMergeCoGroupIterator
 
getValues2() - Method in interface org.apache.flink.runtime.operators.util.CoGroupTaskIterator
Returns an iterable over the left input values for the current key.
getValueSerializer() - Method in class org.apache.flink.api.common.state.MapStateDescriptor
Gets the serializer for the values in the state.
getValueSerializer() - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
getValueSerializer() - Method in class org.apache.flink.cep.nfa.SharedBuffer
 
getValueSerializer() - Method in class org.apache.flink.runtime.state.HashMapSerializer
 
getValueSerializer() - Method in class org.apache.flink.streaming.api.datastream.QueryableStateStream
Returns the value serializer for the queryable state instance.
getValueType() - Static method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
getValueTypeInfo() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
Gets the type information for the values in the map
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.BooleanMaxAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.BooleanMaxWithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.BooleanMinAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.BooleanMinWithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.ByteMaxAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.ByteMaxWithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.ByteMinAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.ByteMinWithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.ByteSum0AggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.ByteSum0WithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.ByteSumAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.ByteSumWithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.DecimalMaxAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.DecimalMaxWithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.DecimalMinAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.DecimalMinWithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.DoubleMaxAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.DoubleMaxWithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.DoubleMinAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.DoubleMinWithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.DoubleSum0AggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.DoubleSum0WithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.DoubleSumAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.DoubleSumWithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.FloatMaxAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.FloatMaxWithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.FloatMinAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.FloatMinWithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.FloatSum0AggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.FloatSum0WithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.FloatSumAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.FloatSumWithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.IntMaxAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.IntMaxWithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.IntMinAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.IntMinWithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.IntSum0AggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.IntSum0WithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.IntSumAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.IntSumWithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.LongMaxAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.LongMaxWithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.LongMinAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.LongMinWithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.LongSum0AggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.LongSum0WithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.LongSumAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.LongSumWithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.MaxAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.MaxWithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.MinAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.MinWithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.ShortMaxAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.ShortMaxWithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.ShortMinAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.ShortMinWithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.ShortSum0AggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.ShortSum0WithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.ShortSumAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.ShortSumWithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.StringMaxAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.StringMaxWithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.StringMinAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.StringMinWithRetractAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.SumAggFunction
 
getValueTypeInfo() - Method in class org.apache.flink.table.functions.aggfunctions.SumWithRetractAggFunction
 
getVariable() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization
 
getVariable(BroadcastVariableInitializer<T, C>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization
 
getVariablesSet() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
getVariablesSet() - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
getVariablesSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
getVariablesSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
getVariablesSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
getVariablesSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
getVariablesSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
getVariablesSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
getVariablesSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
getVariablesSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
getVariablesSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
getVariablesSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
getVariablesSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
getVariablesSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
getVariablesSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
getVariablesSet() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getVariablesStopped() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
getVariablesStopped() - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
getVariablesStopped() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
getVariablesStopped() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
getVariablesStopped() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
getVariablesStopped() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
getVariablesStopped() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
getVariablesStopped() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
getVariablesStopped() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
getVariablesStopped() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
getVariablesStopped() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
getVariablesStopped() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
getVariablesStopped() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
getVariablesStopped() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
getVariablesStopped() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
getVariablesStopped() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getVariance() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
Variance is a measure of how far a set of numbers are spread out.
getVersion() - Method in class org.apache.flink.api.common.typeutils.base.CollectionSerializerConfigSnapshot
 
getVersion() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot
 
getVersion() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializerConfigSnapshot
 
getVersion() - Method in class org.apache.flink.api.common.typeutils.base.MapSerializerConfigSnapshot
 
getVersion() - Method in class org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
 
getVersion() - Method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil.TypeSerializerSerializationProxy
 
getVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer.AvroSerializerConfigSnapshot
 
getVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer.CopyableValueSerializerConfigSnapshot
 
getVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializerConfigSnapshot
 
getVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer.KryoSerializerConfigSnapshot
 
getVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
 
getVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerConfigSnapshot
 
getVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerConfigSnapshot
 
getVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer.ValueSerializerConfigSnapshot
 
getVersion() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer.WritableSerializerConfigSnapshot
 
getVersion() - Method in class org.apache.flink.api.scala.typeutils.EnumValueSerializer.ScalaEnumSerializerConfigSnapshot
 
getVersion() - Method in class org.apache.flink.api.scala.typeutils.OptionSerializer.OptionSerializerConfigSnapshot
 
getVersion() - Method in class org.apache.flink.api.scala.typeutils.ScalaOptionSerializerConfigSnapshot
 
getVersion() - Method in class org.apache.flink.api.scala.typeutils.ScalaTrySerializerConfigSnapshot
 
getVersion() - Method in class org.apache.flink.api.scala.typeutils.TraversableSerializerConfigSnapshot
 
getVersion() - Method in class org.apache.flink.api.scala.typeutils.TrySerializer.TrySerializerConfigSnapshot
 
getVersion() - Method in class org.apache.flink.cep.nfa.ComputationState
 
getVersion() - Method in class org.apache.flink.cep.nfa.NFA.NFASerializerConfigSnapshot
 
getVersion() - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferEdge
 
getVersion() - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializerConfigSnapshot
 
getVersion() - Method in interface org.apache.flink.core.io.SimpleVersionedSerializer
Gets the version with which this serializer serializes.
getVersion() - Method in interface org.apache.flink.core.io.Versioned
Returns the version number of the object.
getVersion() - Method in class org.apache.flink.migration.runtime.checkpoint.savepoint.SavepointV0
 
getVersion() - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer.MultiplexingStreamRecordSerializerConfigSnapshot
 
getVersion() - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.StreamRecordSerializer.StreamRecordSerializerConfigSnapshot
 
getVersion() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
 
getVersion() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
 
getVersion() - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
 
getVersion() - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
 
getVersion() - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
Returns the version of the code as String.
getVersion() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializerConfigSnapshot
 
getVersion() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerConfigSnapshot
 
getVersion() - Method in class org.apache.flink.table.runtime.types.CRowSerializer.CRowSerializerConfigSnapshot
 
getVersionedValue() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedCount
 
getVertex() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
getVertexGroupCount() - Method in class org.apache.flink.graph.library.Summarization.VertexGroupItem
 
getVertexGroupCount() - Method in class org.apache.flink.graph.library.Summarization.VertexValue
 
getVertexGroupValue() - Method in class org.apache.flink.graph.library.Summarization.VertexGroupItem
 
getVertexGroupValue() - Method in class org.apache.flink.graph.library.Summarization.VertexValue
 
getVertexId() - Method in class org.apache.flink.graph.library.Summarization.VertexGroupItem
 
getVertexId() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableKey
 
getVertexID() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
getVertexID() - Method in class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
 
getVertexId0() - Method in interface org.apache.flink.graph.asm.result.BinaryResult
Get the first vertex ID.
getVertexId0() - Method in interface org.apache.flink.graph.asm.result.TertiaryResult
Get the first vertex ID.
getVertexId0() - Method in interface org.apache.flink.graph.asm.result.UnaryResult
Get the first vertex ID.
getVertexId0() - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient.Result
 
getVertexId0() - Method in class org.apache.flink.graph.library.clustering.directed.TriangleListing.Result
 
getVertexId0() - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient.Result
 
getVertexId0() - Method in class org.apache.flink.graph.library.clustering.undirected.TriangleListing.Result
 
getVertexId0() - Method in class org.apache.flink.graph.library.link_analysis.HITS.Result
 
getVertexId0() - Method in class org.apache.flink.graph.library.link_analysis.PageRank.Result
 
getVertexId0() - Method in class org.apache.flink.graph.library.similarity.AdamicAdar.Result
 
getVertexId0() - Method in class org.apache.flink.graph.library.similarity.JaccardIndex.Result
 
getVertexId1() - Method in interface org.apache.flink.graph.asm.result.BinaryResult
Get the second vertex ID.
getVertexId1() - Method in interface org.apache.flink.graph.asm.result.TertiaryResult
Get the second vertex ID.
getVertexId1() - Method in class org.apache.flink.graph.library.clustering.directed.TriangleListing.Result
 
getVertexId1() - Method in class org.apache.flink.graph.library.clustering.undirected.TriangleListing.Result
 
getVertexId1() - Method in class org.apache.flink.graph.library.similarity.AdamicAdar.Result
 
getVertexId1() - Method in class org.apache.flink.graph.library.similarity.JaccardIndex.Result
 
getVertexId2() - Method in interface org.apache.flink.graph.asm.result.TertiaryResult
Get the third vertex ID.
getVertexId2() - Method in class org.apache.flink.graph.library.clustering.directed.TriangleListing.Result
 
getVertexId2() - Method in class org.apache.flink.graph.library.clustering.undirected.TriangleListing.Result
 
getVertexIds() - Method in class org.apache.flink.graph.Graph
 
getVertexIds() - Method in class org.apache.flink.graph.scala.Graph
 
getVertexIDs() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
getVertexWithAttempt() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
getVertices(ExecutionEnvironment) - Static method in class org.apache.flink.graph.examples.data.SummarizationData
Creates a set of vertices with attached String values.
getVertices() - Method in class org.apache.flink.graph.Graph
 
getVertices() - Method in class org.apache.flink.graph.scala.Graph
 
getVertices() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Returns an Iterable to iterate all vertices registered with the job graph.
getVerticesAsArray() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Returns an array of all job vertices that are registered with the job graph.
getVerticesAsTuple2() - Method in class org.apache.flink.graph.Graph
 
getVerticesAsTuple2() - Method in class org.apache.flink.graph.scala.Graph
 
getVerticesSortedTopologicallyFromSources() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
 
getVerticesToAcknowledge() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
getVerticesToConfirm() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
getVerticesTopologically() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns an iterable containing all job vertices for this execution graph in the order they were created.
getVerticesTopologically() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
getVerticesTopologically() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
getVerticesToTrigger() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
getVirtualHost() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig
Retrieve the virtual host.
getVisitDataSet(ExecutionEnvironment) - Static method in class org.apache.flink.examples.java.relational.util.WebLogData
 
getWaitForSolutionSetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
getWaitTime() - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
Returns the wait time.
getWaitTime() - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
Returns the wait time.
getWatermark() - Method in interface org.apache.flink.streaming.api.operators.async.queue.AsyncWatermarkResult
Get the resulting watermark.
getWatermark() - Method in class org.apache.flink.streaming.api.operators.async.queue.WatermarkQueueEntry
 
getWebFrontendAddress() - Method in class org.apache.flink.runtime.webmonitor.WebMonitorConfig
 
getWebFrontendPort() - Method in class org.apache.flink.runtime.webmonitor.WebMonitorConfig
 
getWebInterfaceURL() - Method in class org.apache.flink.client.program.ClusterClient
Returns an URL (as a string) to the JobManager web interface
getWebInterfaceURL() - Method in class org.apache.flink.client.program.StandaloneClusterClient
 
getWebInterfaceURL() - Method in class org.apache.flink.yarn.YarnClusterClient
 
getWebInterfaceURL() - Method in class org.apache.flink.yarn.YarnClusterClientV2
 
getWebUIPort() - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
 
getWeight() - Method in class org.apache.flink.api.java.sampling.IntermediateSampleData
 
getWidth() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Size
 
getWildcardIPAddress() - Static method in class org.apache.flink.util.NetUtils
Returns the wildcard address to listen on all interfaces.
getWindow() - Method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
getWindow() - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
getWindowAssigner() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
getWindowExpressions(LogicalAggregate) - Method in class org.apache.flink.table.plan.rules.common.LogicalWindowAggregateRule
 
getWindowExpressions(LogicalAggregate) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetLogicalWindowAggregateRule
 
getWindowExpressions(LogicalAggregate) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamLogicalWindowAggregateRule
 
getWindowProperties() - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.BaseAlignedWindowAssigner
 
getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
 
getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
 
getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
 
getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
 
getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
 
getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
 
getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
 
getWindowSerializer(ExecutionConfig) - Method in class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
Returns a TypeSerializer for serializing windows that are assigned by this WindowAssigner.
getWindowSize() - Method in class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
 
getWindowSize() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
Deprecated.
 
getWindowSlide() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
Deprecated.
 
getWindowStartWithOffset(long, long, long) - Static method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
Method to get the window start for a timestamp.
getWindowTime() - Method in class org.apache.flink.cep.pattern.Pattern
 
getWindowTime() - Method in class org.apache.flink.cep.scala.pattern.Pattern
 
getWord() - Method in class org.apache.flink.examples.java.wordcount.WordCountPojo.Word
 
getWord() - Method in class org.apache.flink.streaming.examples.wordcount.PojoExample.Word
 
getWorker() - Method in class org.apache.flink.runtime.resourcemanager.registration.WorkerRegistration
 
getWorkerIndex() - Method in class org.apache.flink.runtime.iterative.event.WorkerDoneEvent
 
getWorkingDirectory() - Method in class org.apache.flink.core.fs.FileSystem
Returns the path of the file system's current working directory.
getWorkingDirectory() - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
getWorkingDirectory() - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
getWorkingDirectory() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
 
getWorkingDirectory() - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
 
getWorkset() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
Gets the contract that represents the workset for the step function.
getWorkset() - Method in class org.apache.flink.api.java.operators.DeltaIteration
Gets the working set of the delta iteration.
getWorksetNode() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
 
getWorksetNode() - Method in class org.apache.flink.optimizer.plan.WorksetPlanNode
 
getWorksetPlanNode() - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
 
getWorksetSerializer() - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
 
getWorksetType() - Method in class org.apache.flink.api.java.operators.DeltaIterationResultSet
 
getWrappedDelegate() - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
 
getWrappedDelegate() - Method in class org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
getWrappedDelegate() - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
getWrappedDelegate() - Method in interface org.apache.flink.util.WrappingProxy
 
getWrappedException() - Method in exception org.apache.flink.runtime.operators.chaining.ExceptionInChainedStubException
 
getWrappedFunction() - Method in class org.apache.flink.api.java.operators.translation.WrappingFunction
 
getWrappedGraph() - Method in class org.apache.flink.graph.scala.Graph
 
getWrappedStreamExecutionEnvironment() - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Getter of the wrapped StreamExecutionEnvironment
getWriteEnd() - Method in class org.apache.flink.runtime.iterative.concurrent.BlockingBackChannel
Called by iteration tail to save the output of the current superstep.
getWriteMode() - Method in class org.apache.flink.api.common.io.FileOutputFormat
 
getWriteOffset() - Method in class org.apache.flink.runtime.io.disk.FileChannelOutputView
 
getWriter(int) - Method in interface org.apache.flink.runtime.execution.Environment
 
getWriter(int) - Method in class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
getWriterForVersion(int, RegisteredKeyedBackendStateMetaInfo.Snapshot<N, S>) - Static method in class org.apache.flink.runtime.state.KeyedBackendStateMetaInfoSnapshotReaderWriters
 
getWriterForVersion(int, RegisteredOperatorBackendStateMetaInfo.Snapshot<S>) - Static method in class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters
 
getWriters() - Method in class org.apache.flink.runtime.operators.shipping.OutputCollector
List of writers that are associated with this output collector
getYarnClient() - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
Gets a Hadoop Yarn client
getYarnPropertiesLocation(Configuration) - Static method in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
 
getZooKeeperEnsemble(Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
Returns the configured ZooKeeper quorum (and removes whitespace, because ZooKeeper does not tolerate it).
getZooKeeperLoginContextName() - Method in class org.apache.flink.runtime.security.SecurityUtils.SecurityConfiguration
 
getZookeeperNamespace() - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
 
getZooKeeperServiceName() - Method in class org.apache.flink.runtime.security.SecurityUtils.SecurityConfiguration
 
global() - Method in class org.apache.flink.streaming.api.datastream.DataStream
Sets the partitioning of the DataStream so that the output values all go to the first instance of the next processing operator.
global() - Method in class org.apache.flink.streaming.api.scala.DataStream
Sets the partitioning of the DataStream so that the output values all go to the first instance of the next processing operator.
globalClasspaths - Variable in class org.apache.flink.api.java.RemoteEnvironment
The classpaths that need to be attached to each job
GlobalClusteringCoefficient<K extends Comparable<K> & CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.clustering.directed
The global clustering coefficient measures the connectedness of a graph.
GlobalClusteringCoefficient() - Constructor for class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient
 
GlobalClusteringCoefficient<K extends Comparable<K> & CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.clustering.undirected
The global clustering coefficient measures the connectedness of a graph.
GlobalClusteringCoefficient() - Constructor for class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient
 
GlobalClusteringCoefficient.Result - Class in org.apache.flink.graph.library.clustering.directed
Wraps global clustering coefficient metrics.
GlobalClusteringCoefficient.Result - Class in org.apache.flink.graph.library.clustering.undirected
Wraps global clustering coefficient metrics.
GlobalConfiguration - Class in org.apache.flink.configuration
Global configuration object for Flink.
GlobalJobParameters() - Constructor for class org.apache.flink.api.common.ExecutionConfig.GlobalJobParameters
 
GlobalModVersionMismatch - Exception in org.apache.flink.runtime.executiongraph
An exception that indicates a mismatch between the expected global modification version of the execution graph, and the actual modification version.
GlobalModVersionMismatch(long, long) - Constructor for exception org.apache.flink.runtime.executiongraph.GlobalModVersionMismatch
 
GlobalPartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
Partitioner that sends all elements to the downstream operator with subtask ID=0.
GlobalPartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
 
GlobalProperties - Class in org.apache.flink.optimizer.dataproperties
This class represents global properties of the data at a certain point in the plan.
GlobalProperties() - Constructor for class org.apache.flink.optimizer.dataproperties.GlobalProperties
Initializes the global properties with no partitioning.
GlobalPropertiesPair(RequestedGlobalProperties, RequestedGlobalProperties) - Constructor for class org.apache.flink.optimizer.operators.OperatorDescriptorDual.GlobalPropertiesPair
 
globalProps - Variable in class org.apache.flink.optimizer.plan.PlanNode
 
globalState() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyAllWindowContext
 
globalState() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
 
globalState() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction.Context
State accessor for per-key global state.
globalState() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
State accessor for per-key global state.
globalState() - Method in class org.apache.flink.streaming.api.scala.function.ProcessAllWindowFunction.Context
State accessor for per-key global state.
globalState() - Method in class org.apache.flink.streaming.api.scala.function.ProcessWindowFunction.Context
State accessor for per-key global state.
globalState() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessAllWindowContext
 
globalState() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
 
globalState() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction.InternalWindowContext
 
globalState() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
 
GlobalWindow - Class in org.apache.flink.streaming.api.windowing.windows
The default window into which all data is placed (via GlobalWindows).
GlobalWindow.Serializer - Class in org.apache.flink.streaming.api.windowing.windows
GlobalWindows - Class in org.apache.flink.streaming.api.windowing.assigners
A WindowAssigner that assigns all elements to the same GlobalWindow.
GlobalWindows.NeverTrigger - Class in org.apache.flink.streaming.api.windowing.assigners
A trigger that never fires, as default Trigger for GlobalWindows.
GlobFilePathFilter - Class in org.apache.flink.api.common.io
Class for determining if a particular file should be included or excluded based on a set of include and exclude glob filters.
GlobFilePathFilter() - Constructor for class org.apache.flink.api.common.io.GlobFilePathFilter
Constructor for GlobFilePathFilter that will match all files
GlobFilePathFilter(List<String>, List<String>) - Constructor for class org.apache.flink.api.common.io.GlobFilePathFilter
Constructor for GlobFilePathFilter
GMT() - Method in class org.apache.flink.table.expressions.Literal$
 
GMT() - Static method in class org.apache.flink.table.expressions.Literal
 
go() - Method in class org.apache.flink.core.testutils.CheckedThread
This method needs to be overwritten to contain the main work logic.
go() - Method in class org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger.CombiningSpillingThread
Entry point of the thread.
go() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ReadingThread
The entry point for the thread.
go() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SortingThread
Entry point of the thread.
go() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Entry point of the thread.
go() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
Equivalent to the run() method.
goal() - Method in class org.apache.flink.mesos.scheduler.TaskMonitor.StateData
 
gossip(Object, ActorRef) - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
gossip(Object, ActorRef) - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
gossip(Object, ActorRef) - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
gossip(Object, ActorRef) - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
gossip$default$2(Object) - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
gossip$default$2(Object) - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
gossip$default$2(Object) - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
gossip$default$2(Object) - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
gracefulShutdown(long, TimeUnit, ExecutorService...) - Static method in class org.apache.flink.runtime.concurrent.Executors
Gracefully shutdown the given ExecutorService.
Grade(String, int) - Constructor for class org.apache.flink.streaming.scala.examples.join.WindowJoin.Grade
 
grade() - Method in class org.apache.flink.streaming.scala.examples.join.WindowJoin.Grade
 
grade() - Method in class org.apache.flink.streaming.scala.examples.join.WindowJoin.Person
 
Grade$() - Constructor for class org.apache.flink.streaming.scala.examples.join.WindowJoin.Grade$
 
GRADE_COUNT() - Method in class org.apache.flink.streaming.scala.examples.join.WindowJoinSampleData$
 
GRADE_COUNT() - Static method in class org.apache.flink.streaming.scala.examples.join.WindowJoinSampleData
 
GradeSource() - Constructor for class org.apache.flink.streaming.examples.join.WindowJoinSampleData.GradeSource
 
GradeSource() - Constructor for class org.apache.flink.streaming.scala.examples.join.WindowJoinSampleData.GradeSource
 
gradient(LabeledVector, WeightVector) - Static method in class org.apache.flink.ml.optimization.GenericLossFunction
 
gradient(Vector, WeightVector) - Method in class org.apache.flink.ml.optimization.LinearPrediction$
 
gradient(Vector, WeightVector) - Static method in class org.apache.flink.ml.optimization.LinearPrediction
 
gradient(LabeledVector, WeightVector) - Method in interface org.apache.flink.ml.optimization.LossFunction
Calculates the gradient of the loss function given a data point and weight vector
gradient(Vector, WeightVector) - Method in class org.apache.flink.ml.optimization.PredictionFunction
 
GradientDescent - Class in org.apache.flink.ml.optimization
Base class which performs Stochastic Gradient Descent optimization using mini batches.
GradientDescent() - Constructor for class org.apache.flink.ml.optimization.GradientDescent
 
GradientDescent$ - Class in org.apache.flink.ml.optimization
Implementation of a Gradient Descent solver.
GradientDescent$() - Constructor for class org.apache.flink.ml.optimization.GradientDescent$
 
grantLeadership(UUID) - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
grantLeadership(UUID) - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
 
grantLeadership(UUID) - Method in interface org.apache.flink.runtime.leaderelection.LeaderContender
Callback method which is called by the LeaderElectionService upon selecting this instance as the new leader.
GrantLeadership(Option<UUID>) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.GrantLeadership
 
grantLeadership(UUID) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
Callback method when current resourceManager is granted leadership
GrantLeadership$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.GrantLeadership$
 
Graph<K,VV,EV> - Class in org.apache.flink.graph
Represents a Graph consisting of edges and vertices.
Graph(DataSet<Vertex<K, VV>>, DataSet<Edge<K, EV>>, ExecutionEnvironment) - Constructor for class org.apache.flink.graph.Graph
Creates a graph from two DataSets: vertices and edges
Graph<K,VV,EV> - Class in org.apache.flink.graph.scala
Represents a graph consisting of Edge edges and Vertex vertices.
Graph(Graph<K, VV, EV>, TypeInformation<K>, ClassTag<K>, TypeInformation<VV>, ClassTag<VV>, TypeInformation<EV>, ClassTag<EV>) - Constructor for class org.apache.flink.graph.scala.Graph
 
graph() - Method in class org.apache.flink.runtime.messages.ArchiveMessages.ArchiveExecutionGraph
 
Graph$ - Class in org.apache.flink.graph.scala
 
Graph$() - Constructor for class org.apache.flink.graph.scala.Graph$
 
GraphAlgorithm<K,VV,EV,T> - Interface in org.apache.flink.graph
 
GraphAlgorithmWrappingDataSet<K,VV,EV,T> - Class in org.apache.flink.graph.utils.proxy
A GraphAlgorithm transforms an input Graph into an output of type T.
GraphAlgorithmWrappingDataSet() - Constructor for class org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingDataSet
 
GraphAlgorithmWrappingGraph<IN_K,IN_VV,IN_EV,OUT_K,OUT_VV,OUT_EV> - Class in org.apache.flink.graph.utils.proxy
A GraphAlgorithm transforms an input Graph into an output of type T.
GraphAlgorithmWrappingGraph() - Constructor for class org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingGraph
 
GraphAnalytic<K,VV,EV,T> - Interface in org.apache.flink.graph
A GraphAnalytic is similar to a GraphAlgorithm but is terminal and results are retrieved via accumulators.
GraphCreatingVisitor - Class in org.apache.flink.optimizer.traversals
This traversal creates the optimizer DAG from a program.
GraphCreatingVisitor(int, ExecutionMode) - Constructor for class org.apache.flink.optimizer.traversals.GraphCreatingVisitor
 
GraphCsvReader - Class in org.apache.flink.graph
A class to build a Graph using path(s) provided to CSV file(s) with optional vertex and edge data.
GraphCsvReader(Path, Path, ExecutionEnvironment) - Constructor for class org.apache.flink.graph.GraphCsvReader
 
GraphCsvReader(Path, ExecutionEnvironment) - Constructor for class org.apache.flink.graph.GraphCsvReader
 
GraphCsvReader(Path, MapFunction<K, VV>, ExecutionEnvironment) - Constructor for class org.apache.flink.graph.GraphCsvReader
 
GraphCsvReader(String, ExecutionEnvironment) - Constructor for class org.apache.flink.graph.GraphCsvReader
 
GraphCsvReader(String, String, ExecutionEnvironment) - Constructor for class org.apache.flink.graph.GraphCsvReader
 
GraphCsvReader(String, MapFunction<K, VV>, ExecutionEnvironment) - Constructor for class org.apache.flink.graph.GraphCsvReader
 
GraphGenerator<K,VV,EV> - Interface in org.apache.flink.graph.generator
Graph generators shall be - parallelizable, in order to create large datasets - scale-free, generating the same graph regardless of parallelism - thrifty, using as few operators as possible Graph generators should prefer to emit edges sorted by the source label.
GraphGeneratorUtils - Class in org.apache.flink.graph.generator
 
GraphGeneratorUtils() - Constructor for class org.apache.flink.graph.generator.GraphGeneratorUtils
 
GraphiteReporter - Class in org.apache.flink.metrics.graphite
 
GraphiteReporter() - Constructor for class org.apache.flink.metrics.graphite.GraphiteReporter
 
GraphMetrics<K extends Comparable<K>,VV,EV> - Class in org.apache.flink.graph.drivers
Driver for directed and undirected graph metrics analytics.
GraphMetrics() - Constructor for class org.apache.flink.graph.drivers.GraphMetrics
 
graphs() - Method in class org.apache.flink.runtime.jobmanager.MemoryArchivist
 
GraphUtils - Class in org.apache.flink.graph.utils
 
GraphUtils() - Constructor for class org.apache.flink.graph.utils.GraphUtils
 
GraphUtils.AddLongValue - Class in org.apache.flink.graph.utils
Add LongValue elements.
GraphUtils.IdentityMapper<T> - Class in org.apache.flink.graph.utils
The identity mapper returns the input as output.
GraphUtils.MapTo<I,O> - Class in org.apache.flink.graph.utils
Map each element to a value.
GraphUtils.NonForwardingIdentityMapper<T> - Class in org.apache.flink.graph.utils
The identity mapper returns the input as output.
GraphValidator<K,VV,EV> - Class in org.apache.flink.graph.validation
A utility for defining validation criteria for different types of Graphs.
GraphValidator() - Constructor for class org.apache.flink.graph.validation.GraphValidator
 
GREATER_THAN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Logical greater-than operator, '>'.
GREATER_THAN_OR_EQUAL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Logical greater-than-or-equal operator, '>='.
greaterThan() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
greaterThan() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
GreaterThan - Class in org.apache.flink.table.expressions
 
GreaterThan(Expression, Expression) - Constructor for class org.apache.flink.table.expressions.GreaterThan
 
GreaterThan$ - Class in org.apache.flink.table.expressions
 
GreaterThan$() - Constructor for class org.apache.flink.table.expressions.GreaterThan$
 
greaterThanOrEqual() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
greaterThanOrEqual() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
GreaterThanOrEqual - Class in org.apache.flink.table.expressions
 
GreaterThanOrEqual(Expression, Expression) - Constructor for class org.apache.flink.table.expressions.GreaterThanOrEqual
 
GreaterThanOrEqual$ - Class in org.apache.flink.table.expressions
 
GreaterThanOrEqual$() - Constructor for class org.apache.flink.table.expressions.GreaterThanOrEqual$
 
GridGraph - Class in org.apache.flink.graph.drivers.input
Generate a GridGraph.
GridGraph() - Constructor for class org.apache.flink.graph.drivers.input.GridGraph
 
GridGraph - Class in org.apache.flink.graph.generator
 
GridGraph(ExecutionEnvironment) - Constructor for class org.apache.flink.graph.generator.GridGraph
An undirected Graph connecting vertices in a regular tiling in one or more dimensions and where the endpoints are optionally connected.
GROUP_ID - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
GROUP_ID function.
GROUP_OFFSET - Static variable in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionStateSentinel
Magic number that defines the partition should start from its committed group offset in Kafka.
GroupAggProcessFunction - Class in org.apache.flink.table.runtime.aggregate
Aggregate Function used for the groupby (without window) aggregate
GroupAggProcessFunction(GeneratedAggregationsFunction, RowTypeInfo, boolean, StreamQueryConfig) - Constructor for class org.apache.flink.table.runtime.aggregate.GroupAggProcessFunction
 
groupBy(KeySelector<T, K>) - Method in class org.apache.flink.api.java.DataSet
Groups a DataSet using a KeySelector function.
groupBy(int...) - Method in class org.apache.flink.api.java.DataSet
Groups a Tuple DataSet using field position keys.
Note: Field position keys only be specified for Tuple DataSets.
The field position keys specify the fields of Tuples on which the DataSet is grouped.
groupBy(String...) - Method in class org.apache.flink.api.java.DataSet
Groups a DataSet using field expressions.
groupBy(Function1<T, K>, TypeInformation<K>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
groupBy(Seq<Object>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
groupBy(String, Seq<String>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
groupBy(Function1<T, K>, TypeInformation<K>) - Method in class org.apache.flink.api.scala.DataSet
Creates a GroupedDataSet which provides operations on groups of elements.
groupBy(Seq<Object>) - Method in class org.apache.flink.api.scala.DataSet
Creates a GroupedDataSet which provides operations on groups of elements.
groupBy(String, Seq<String>) - Method in class org.apache.flink.api.scala.DataSet
Creates a GroupedDataSet which provides operations on groups of elements.
groupBy(Seq<Expression>) - Method in class org.apache.flink.table.api.Table
Groups the elements on some grouping keys.
groupBy(String) - Method in class org.apache.flink.table.api.Table
Groups the elements on some grouping keys.
groupBy(Seq<Expression>) - Method in class org.apache.flink.table.api.WindowedTable
Groups the elements by a mandatory window and one or more optional grouping attributes.
groupBy(String) - Method in class org.apache.flink.table.api.WindowedTable
Groups the elements by a mandatory window and one or more optional grouping attributes.
GroupCombineChainedDriver<IN,OUT> - Class in org.apache.flink.runtime.operators.chaining
Chained variant of the GroupReduceCombineDriver Acts like a combiner with a custom output type OUT.
GroupCombineChainedDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
 
GroupCombineFunction<IN,OUT> - Interface in org.apache.flink.api.common.functions
Generic interface used for combine functions ("combiners").
GroupCombineNode - Class in org.apache.flink.optimizer.dag
The optimizer representation of a GroupCombineNode operation.
GroupCombineNode(GroupCombineOperatorBase<?, ?, ?>) - Constructor for class org.apache.flink.optimizer.dag.GroupCombineNode
Creates a new optimizer node for the given operator.
GroupCombineOperator<IN,OUT> - Class in org.apache.flink.api.java.operators
This operator behaves like the GroupReduceOperator with Combine but only runs the Combine part which reduces all data locally in their partitions.
GroupCombineOperator(DataSet<IN>, TypeInformation<OUT>, GroupCombineFunction<IN, OUT>, String) - Constructor for class org.apache.flink.api.java.operators.GroupCombineOperator
Constructor for a non-grouped reduce (all reduce).
GroupCombineOperator(Grouping<IN>, TypeInformation<OUT>, GroupCombineFunction<IN, OUT>, String) - Constructor for class org.apache.flink.api.java.operators.GroupCombineOperator
Constructor for a grouped reduce.
GroupCombineOperatorBase<IN,OUT,FT extends GroupCombineFunction<IN,OUT>> - Class in org.apache.flink.api.common.operators.base
Base operator for the combineGroup transformation.
GroupCombineOperatorBase(FT, UnaryOperatorInformation<IN, OUT>, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.GroupCombineOperatorBase
 
GroupCombineProperties - Class in org.apache.flink.optimizer.operators
The properties file belonging to the GroupCombineNode.
GroupCombineProperties(FieldSet, Ordering) - Constructor for class org.apache.flink.optimizer.operators.GroupCombineProperties
 
GroupedDataSet<T> - Class in org.apache.flink.api.scala
A DataSet to which a grouping key was added.
GroupedDataSet(DataSet<T>, Keys<T>, ClassTag<T>) - Constructor for class org.apache.flink.api.scala.GroupedDataSet
 
GroupedProcessingTimeWindowExample - Class in org.apache.flink.streaming.examples.windowing
 
GroupedProcessingTimeWindowExample() - Constructor for class org.apache.flink.streaming.examples.windowing.GroupedProcessingTimeWindowExample
 
GroupedProcessingTimeWindowExample.FirstFieldKeyExtractor<Type extends Tuple,Key> - Class in org.apache.flink.streaming.examples.windowing
 
GroupedProcessingTimeWindowExample.SummingReducer - Class in org.apache.flink.streaming.examples.windowing
 
GroupedProcessingTimeWindowExample.SummingWindowFunction - Class in org.apache.flink.streaming.examples.windowing
 
GroupedTable - Class in org.apache.flink.table.api
A table that has been grouped on a set of grouping keys.
GroupedTable(Table, Seq<Expression>) - Constructor for class org.apache.flink.table.api.GroupedTable
 
GROUPING - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
GROUPING function.
Grouping<T> - Class in org.apache.flink.api.java.operators
Grouping(DataSet<T>, Keys<T>) - Constructor for class org.apache.flink.api.java.operators.Grouping
 
GROUPING_ID - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
GROUP_ID function is a synonym for GROUPING.
GROUPING_SETS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
GROUPING SETS operator, occurs within GROUP BY clause or nested within a GROUPING SETS.
groupingBy(Function1<T, K>, TypeInformation<K>) - Method in class org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions.OnDataSet
Groups the items according to a grouping function fun
groupingExpressions() - Method in class org.apache.flink.table.plan.logical.Aggregate
 
groupingExpressions() - Method in class org.apache.flink.table.plan.logical.WindowAggregate
 
groupingToString(RelDataType, int[]) - Method in interface org.apache.flink.table.plan.nodes.CommonAggregate
 
groupingToString(RelDataType, int[]) - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
groupKey() - Method in class org.apache.flink.table.api.GroupedTable
 
groupKey() - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
groupKey(RexNode[]) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
groupKey(Iterable<? extends RexNode>) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
groupKey(Iterable<? extends RexNode>, boolean, Iterable<? extends Iterable<? extends RexNode>>) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
groupKey(int[]) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
groupKey(String[]) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
groupKey(ImmutableBitSet, boolean, ImmutableList<ImmutableBitSet>) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
groupKeys() - Method in class org.apache.flink.table.api.WindowGroupedTable
 
GroupReduceCombineDriver<IN,OUT> - Class in org.apache.flink.runtime.operators
Non-chained combine driver which is used for a CombineGroup transformation or a GroupReduce transformation where the user supplied a RichGroupReduceFunction with a combine method.
GroupReduceCombineDriver() - Constructor for class org.apache.flink.runtime.operators.GroupReduceCombineDriver
 
GroupReduceDriver<IT,OT> - Class in org.apache.flink.runtime.operators
GroupReduce task which is executed by a Task Manager.
GroupReduceDriver() - Constructor for class org.apache.flink.runtime.operators.GroupReduceDriver
 
GroupReduceFunction<T,O> - Interface in org.apache.flink.api.common.functions
The interface for group reduce functions.
GroupReduceIterator<IN,OUT> - Class in org.apache.flink.api.java.functions
 
GroupReduceIterator() - Constructor for class org.apache.flink.api.java.functions.GroupReduceIterator
 
GroupReduceNode - Class in org.apache.flink.optimizer.dag
The optimizer representation of a GroupReduce operation.
GroupReduceNode(GroupReduceOperatorBase<?, ?, ?>) - Constructor for class org.apache.flink.optimizer.dag.GroupReduceNode
Creates a new optimizer node for the given operator.
groupReduceOnEdges(EdgesFunctionWithVertexValue<K, VV, EV, T>, EdgeDirection) - Method in class org.apache.flink.graph.Graph
Groups by vertex and computes a GroupReduce transformation over the edge values of each vertex.
groupReduceOnEdges(EdgesFunctionWithVertexValue<K, VV, EV, T>, EdgeDirection, TypeInformation<T>) - Method in class org.apache.flink.graph.Graph
Groups by vertex and computes a GroupReduce transformation over the edge values of each vertex.
groupReduceOnEdges(EdgesFunction<K, EV, T>, EdgeDirection) - Method in class org.apache.flink.graph.Graph
Groups by vertex and computes a GroupReduce transformation over the edge values of each vertex.
groupReduceOnEdges(EdgesFunction<K, EV, T>, EdgeDirection, TypeInformation<T>) - Method in class org.apache.flink.graph.Graph
Groups by vertex and computes a GroupReduce transformation over the edge values of each vertex.
groupReduceOnEdges(EdgesFunctionWithVertexValue<K, VV, EV, T>, EdgeDirection, TypeInformation<T>, ClassTag<T>) - Method in class org.apache.flink.graph.scala.Graph
Compute an aggregate over the edges of each vertex.
groupReduceOnEdges(EdgesFunction<K, EV, T>, EdgeDirection, TypeInformation<T>, ClassTag<T>) - Method in class org.apache.flink.graph.scala.Graph
Compute an aggregate over the edges of each vertex.
groupReduceOnNeighbors(NeighborsFunctionWithVertexValue<K, VV, EV, T>, EdgeDirection) - Method in class org.apache.flink.graph.Graph
Groups by vertex and computes a GroupReduce transformation over the neighbors (both edges and vertices) of each vertex.
groupReduceOnNeighbors(NeighborsFunctionWithVertexValue<K, VV, EV, T>, EdgeDirection, TypeInformation<T>) - Method in class org.apache.flink.graph.Graph
Groups by vertex and computes a GroupReduce transformation over the neighbors (both edges and vertices) of each vertex.
groupReduceOnNeighbors(NeighborsFunction<K, VV, EV, T>, EdgeDirection) - Method in class org.apache.flink.graph.Graph
Groups by vertex and computes a GroupReduce transformation over the neighbors (both edges and vertices) of each vertex.
groupReduceOnNeighbors(NeighborsFunction<K, VV, EV, T>, EdgeDirection, TypeInformation<T>) - Method in class org.apache.flink.graph.Graph
Groups by vertex and computes a GroupReduce transformation over the neighbors (both edges and vertices) of each vertex.
groupReduceOnNeighbors(NeighborsFunctionWithVertexValue<K, VV, EV, T>, EdgeDirection, TypeInformation<T>, ClassTag<T>) - Method in class org.apache.flink.graph.scala.Graph
Compute an aggregate over the neighbors (edges and vertices) of each vertex.
groupReduceOnNeighbors(NeighborsFunction<K, VV, EV, T>, EdgeDirection, TypeInformation<T>, ClassTag<T>) - Method in class org.apache.flink.graph.scala.Graph
Compute an aggregate over the neighbors (edges and vertices) of each vertex.
GroupReduceOperator<IN,OUT> - Class in org.apache.flink.api.java.operators
This operator represents the application of a "reduceGroup" function on a data set, and the result data set produced by the function.
GroupReduceOperator(DataSet<IN>, TypeInformation<OUT>, GroupReduceFunction<IN, OUT>, String) - Constructor for class org.apache.flink.api.java.operators.GroupReduceOperator
Constructor for a non-grouped reduce (all reduce).
GroupReduceOperator(Grouping<IN>, TypeInformation<OUT>, GroupReduceFunction<IN, OUT>, String) - Constructor for class org.apache.flink.api.java.operators.GroupReduceOperator
Constructor for a grouped reduce.
GroupReduceOperatorBase<IN,OUT,FT extends GroupReduceFunction<IN,OUT>> - Class in org.apache.flink.api.common.operators.base
 
GroupReduceOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
 
GroupReduceOperatorBase(FT, UnaryOperatorInformation<IN, OUT>, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
 
GroupReduceOperatorBase(Class<? extends FT>, UnaryOperatorInformation<IN, OUT>, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
 
GroupReduceOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
 
GroupReduceOperatorBase(FT, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
 
GroupReduceOperatorBase(Class<? extends FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
 
GroupReduceProperties - Class in org.apache.flink.optimizer.operators
 
GroupReduceProperties(FieldSet) - Constructor for class org.apache.flink.optimizer.operators.GroupReduceProperties
 
GroupReduceProperties(FieldSet, Ordering) - Constructor for class org.apache.flink.optimizer.operators.GroupReduceProperties
 
GroupReduceProperties(FieldSet, Partitioner<?>) - Constructor for class org.apache.flink.optimizer.operators.GroupReduceProperties
 
GroupReduceProperties(FieldSet, Ordering, Partitioner<?>) - Constructor for class org.apache.flink.optimizer.operators.GroupReduceProperties
 
GroupReduceWithCombineProperties - Class in org.apache.flink.optimizer.operators
 
GroupReduceWithCombineProperties(FieldSet) - Constructor for class org.apache.flink.optimizer.operators.GroupReduceWithCombineProperties
 
GroupReduceWithCombineProperties(FieldSet, Ordering) - Constructor for class org.apache.flink.optimizer.operators.GroupReduceWithCombineProperties
 
GroupReduceWithCombineProperties(FieldSet, Partitioner<?>) - Constructor for class org.apache.flink.optimizer.operators.GroupReduceWithCombineProperties
 
GroupReduceWithCombineProperties(FieldSet, Ordering, Partitioner<?>) - Constructor for class org.apache.flink.optimizer.operators.GroupReduceWithCombineProperties
 
groupsFields(FieldSet) - Method in class org.apache.flink.api.common.operators.Ordering
 
GSAConfiguration - Class in org.apache.flink.graph.gsa
A GSAConfiguration object can be used to set the iteration name and degree of parallelism, to register aggregators and use broadcast sets in the GatherFunction, SumFunction as well as ApplyFunction.
GSAConfiguration() - Constructor for class org.apache.flink.graph.gsa.GSAConfiguration
 
GSAConnectedComponents<K,VV extends Comparable<VV>,EV> - Class in org.apache.flink.graph.library
A gather-sum-apply implementation of the Weakly Connected Components algorithm.
GSAConnectedComponents(Integer) - Constructor for class org.apache.flink.graph.library.GSAConnectedComponents
Creates an instance of the GSA Connected Components algorithm.
GSAPageRank<K> - Class in org.apache.flink.graph.examples
This is an implementation of a simple PageRank algorithm, using a gather-sum-apply iteration.
GSAPageRank(double, int) - Constructor for class org.apache.flink.graph.examples.GSAPageRank
Creates an instance of the GSA PageRank algorithm.
GSASingleSourceShortestPaths - Class in org.apache.flink.graph.examples
This example shows how to use Gelly's Gather-Sum-Apply iterations.
GSASingleSourceShortestPaths() - Constructor for class org.apache.flink.graph.examples.GSASingleSourceShortestPaths
 
GSASingleSourceShortestPaths<K,VV> - Class in org.apache.flink.graph.library
This is an implementation of the Single Source Shortest Paths algorithm, using a gather-sum-apply iteration
GSASingleSourceShortestPaths(K, Integer) - Constructor for class org.apache.flink.graph.library.GSASingleSourceShortestPaths
Creates an instance of the GSA SingleSourceShortestPaths algorithm.
GSASingleSourceShortestPaths - Class in org.apache.flink.graph.scala.examples
This example shows how to use Gelly's gather-sum-apply iterations.
GSASingleSourceShortestPaths() - Constructor for class org.apache.flink.graph.scala.examples.GSASingleSourceShortestPaths
 
GSASingleSourceShortestPaths$ - Class in org.apache.flink.graph.scala.examples
This example shows how to use Gelly's gather-sum-apply iterations.
GSASingleSourceShortestPaths$() - Constructor for class org.apache.flink.graph.scala.examples.GSASingleSourceShortestPaths$
 
GSASingleSourceShortestPaths.InitVerticesMapper<K,VV> - Class in org.apache.flink.graph.library
 
guard(Function0<Parsers.Parser<T>>) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
GzipInflaterInputStreamFactory - Class in org.apache.flink.api.common.io.compression
Factory for input streams that decompress the GZIP compression format.
GzipInflaterInputStreamFactory() - Constructor for class org.apache.flink.api.common.io.compression.GzipInflaterInputStreamFactory
 

H

HA_CLUSTER_ID - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
The ID of the Flink cluster, used to separate multiple Flink clusters Needs to be set for standalone clusters, is automatically inferred in YARN and Mesos.
HA_JOB_DELAY - Static variable in class org.apache.flink.configuration.ConfigConstants
The time before the JobManager recovers persisted jobs
HA_JOB_DELAY - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
The time before a JobManager after a fail over recovers the current jobs.
HA_JOB_MANAGER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
Ports used by the job manager if not in 'none' recovery mode
HA_JOB_MANAGER_PORT_RANGE - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
Optional port (range) used by the job manager in high-availability mode.
HA_MODE - Static variable in class org.apache.flink.configuration.ConfigConstants
Defines high availabilty mode used for the cluster execution ("NONE", "ZOOKEEPER")
HA_MODE - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
Defines high-availability mode used for the cluster execution.
HA_STORAGE_PATH - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
File system path (URI) where Flink persists metadata in high-availability setups
HA_ZOOKEEPER_CHECKPOINT_COUNTER_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
ZooKeeper root path (ZNode) for checkpoint counters.
HA_ZOOKEEPER_CHECKPOINTS_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
ZooKeeper root path (ZNode) for completed checkpoints.
HA_ZOOKEEPER_CLIENT_ACL - Static variable in class org.apache.flink.configuration.ConfigConstants
 
HA_ZOOKEEPER_CONNECTION_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
 
HA_ZOOKEEPER_DIR_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
ZooKeeper root path.
HA_ZOOKEEPER_JOBGRAPHS_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
ZooKeeper root path (ZNode) for job graphs.
HA_ZOOKEEPER_LATCH_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
 
HA_ZOOKEEPER_LEADER_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
 
HA_ZOOKEEPER_MAX_RETRY_ATTEMPTS - Static variable in class org.apache.flink.configuration.ConfigConstants
 
HA_ZOOKEEPER_MESOS_WORKERS_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
ZooKeeper root path (ZNode) for Mesos workers.
HA_ZOOKEEPER_NAMESPACE_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
 
HA_ZOOKEEPER_QUORUM - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
The ZooKeeper quorum to use, when running Flink in a high-availability mode with ZooKeeper.
HA_ZOOKEEPER_QUORUM_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
ZooKeeper servers.
HA_ZOOKEEPER_RETRY_WAIT - Static variable in class org.apache.flink.configuration.ConfigConstants
 
HA_ZOOKEEPER_ROOT - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
The root path under which Flink stores its entries in ZooKeeper
HA_ZOOKEEPER_SESSION_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
 
HA_ZOOKEEPER_STORAGE_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
File system state backend base path for recoverable state handles.
haDataDirectory - Variable in class org.apache.flink.yarn.highavailability.YarnHighAvailabilityServices
The directory for HA persistent data.
HADOOP_COPYING - Static variable in class org.apache.flink.api.common.io.FilePathFilter
Name of an unfinished Hadoop file
HadoopBlockLocation - Class in org.apache.flink.runtime.fs.hdfs
Implementation of the BlockLocation interface for the Hadoop Distributed File System.
HadoopBlockLocation(BlockLocation) - Constructor for class org.apache.flink.runtime.fs.hdfs.HadoopBlockLocation
Creates a new block location
HadoopConfOverlay - Class in org.apache.flink.runtime.clusterframework.overlays
Overlays a Hadoop configuration into a container, based on a supplied Hadoop configuration directory.
HadoopConfOverlay(File) - Constructor for class org.apache.flink.runtime.clusterframework.overlays.HadoopConfOverlay
 
HadoopConfOverlay.Builder - Class in org.apache.flink.runtime.clusterframework.overlays
A builder for the HadoopConfOverlay.
HadoopDataInputStream - Class in org.apache.flink.runtime.fs.hdfs
Concrete implementation of the FSDataInputStream for the Hadoop's input streams.
HadoopDataInputStream(FSDataInputStream) - Constructor for class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
Creates a new data input stream from the given Hadoop input stream
HadoopDataOutputStream - Class in org.apache.flink.runtime.fs.hdfs
 
HadoopDataOutputStream(FSDataOutputStream) - Constructor for class org.apache.flink.runtime.fs.hdfs.HadoopDataOutputStream
 
HadoopDummyProgressable - Class in org.apache.flink.api.java.hadoop.mapred.wrapper
This is a dummy progress
HadoopDummyProgressable() - Constructor for class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyProgressable
 
HadoopDummyReporter - Class in org.apache.flink.api.java.hadoop.mapred.wrapper
This is a dummy progress monitor / reporter
HadoopDummyReporter() - Constructor for class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyReporter
 
HadoopFileStatus - Class in org.apache.flink.runtime.fs.hdfs
Concrete implementation of the FileStatus interface for the Hadoop Distribution File System.
HadoopFileStatus(FileStatus) - Constructor for class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
Creates a new file status from a HDFS file status.
HadoopFileSystem - Class in org.apache.flink.runtime.fs.hdfs
Concrete implementation of the FileSystem base class for the Hadoop File System.
HadoopFileSystem(Class<? extends FileSystem>) - Constructor for class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
Creates a new DistributedFileSystem object to access HDFS, based on a class name and picking up the configuration from the class path or the Flink configuration.
HadoopFileSystem(Configuration, FileSystem) - Constructor for class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
Creates a new DistributedFileSystem that uses the given Hadoop FileSystem under the hood.
hadoopFileSystem - Variable in class org.apache.flink.yarn.highavailability.YarnHighAvailabilityServices
The Hadoop FileSystem object that represent the HDFS used by YARN
HadoopFileSystemWrapper - Interface in org.apache.flink.core.fs
 
HadoopInputFormat<K,V> - Class in org.apache.flink.api.java.hadoop.mapred
Wrapper for using HadoopInputFormats (mapred-variant) with Flink.
HadoopInputFormat(InputFormat<K, V>, Class<K>, Class<V>, JobConf) - Constructor for class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormat
 
HadoopInputFormat(InputFormat<K, V>, Class<K>, Class<V>) - Constructor for class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormat
 
HadoopInputFormat<K,V> - Class in org.apache.flink.api.java.hadoop.mapreduce
InputFormat implementation allowing to use Hadoop (mapreduce) InputFormats with Flink.
HadoopInputFormat(InputFormat<K, V>, Class<K>, Class<V>, Job) - Constructor for class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormat
 
HadoopInputFormat(InputFormat<K, V>, Class<K>, Class<V>) - Constructor for class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormat
 
HadoopInputFormat<K,V> - Class in org.apache.flink.api.scala.hadoop.mapred
 
HadoopInputFormat(InputFormat<K, V>, Class<K>, Class<V>, JobConf) - Constructor for class org.apache.flink.api.scala.hadoop.mapred.HadoopInputFormat
 
HadoopInputFormat(InputFormat<K, V>, Class<K>, Class<V>) - Constructor for class org.apache.flink.api.scala.hadoop.mapred.HadoopInputFormat
 
HadoopInputFormat<K,V> - Class in org.apache.flink.api.scala.hadoop.mapreduce
 
HadoopInputFormat(InputFormat<K, V>, Class<K>, Class<V>, Job) - Constructor for class org.apache.flink.api.scala.hadoop.mapreduce.HadoopInputFormat
 
HadoopInputFormat(InputFormat<K, V>, Class<K>, Class<V>) - Constructor for class org.apache.flink.api.scala.hadoop.mapreduce.HadoopInputFormat
 
HadoopInputFormatBase<K,V,T> - Class in org.apache.flink.api.java.hadoop.mapred
Common base for Java and Scala API for using Hadoop input formats with Flink.
HadoopInputFormatBase(InputFormat<K, V>, Class<K>, Class<V>, JobConf) - Constructor for class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
HadoopInputFormatBase<K,V,T> - Class in org.apache.flink.api.java.hadoop.mapreduce
Base class shared between the Java and Scala API of Flink
HadoopInputFormatBase(InputFormat<K, V>, Class<K>, Class<V>, Job) - Constructor for class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
HadoopInputFormatCommonBase<T,SPITTYPE extends InputSplit> - Class in org.apache.flink.api.java.hadoop.common
A common base for both "mapred" and "mapreduce" Hadoop input formats.
HadoopInputFormatCommonBase(Credentials) - Constructor for class org.apache.flink.api.java.hadoop.common.HadoopInputFormatCommonBase
 
HadoopInputs - Class in org.apache.flink.hadoopcompatibility
HadoopInputs is a utility class to use Apache Hadoop InputFormats with Apache Flink.
HadoopInputs() - Constructor for class org.apache.flink.hadoopcompatibility.HadoopInputs
 
HadoopInputs - Class in org.apache.flink.hadoopcompatibility.scala
HadoopInputs is a utility class to use Apache Hadoop InputFormats with Apache Flink.
HadoopInputs() - Constructor for class org.apache.flink.hadoopcompatibility.scala.HadoopInputs
 
HadoopInputs$ - Class in org.apache.flink.hadoopcompatibility.scala
HadoopInputs is a utility class to use Apache Hadoop InputFormats with Apache Flink.
HadoopInputs$() - Constructor for class org.apache.flink.hadoopcompatibility.scala.HadoopInputs$
 
HadoopInputSplit - Class in org.apache.flink.api.java.hadoop.mapred.wrapper
A wrapper that represents an input split from the Hadoop mapred API as a Flink InputSplit.
HadoopInputSplit(int, InputSplit, JobConf) - Constructor for class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopInputSplit
 
HadoopInputSplit - Class in org.apache.flink.api.java.hadoop.mapreduce.wrapper
A wrapper that represents an input split from the Hadoop mapreduce API as a Flink InputSplit.
HadoopInputSplit(int, InputSplit, JobContext) - Constructor for class org.apache.flink.api.java.hadoop.mapreduce.wrapper.HadoopInputSplit
 
HadoopMapFunction<KEYIN,VALUEIN,KEYOUT,VALUEOUT> - Class in org.apache.flink.hadoopcompatibility.mapred
This wrapper maps a Hadoop Mapper (mapred API) to a Flink FlatMapFunction.
HadoopMapFunction(Mapper<KEYIN, VALUEIN, KEYOUT, VALUEOUT>) - Constructor for class org.apache.flink.hadoopcompatibility.mapred.HadoopMapFunction
Maps a Hadoop Mapper (mapred API) to a Flink FlatMapFunction.
HadoopMapFunction(Mapper<KEYIN, VALUEIN, KEYOUT, VALUEOUT>, JobConf) - Constructor for class org.apache.flink.hadoopcompatibility.mapred.HadoopMapFunction
Maps a Hadoop Mapper (mapred API) to a Flink FlatMapFunction.
HadoopModule - Class in org.apache.flink.runtime.security.modules
Responsible for installing a Hadoop login user.
HadoopModule() - Constructor for class org.apache.flink.runtime.security.modules.HadoopModule
 
HadoopOutputCollector<KEY,VALUE> - Class in org.apache.flink.hadoopcompatibility.mapred.wrapper
A Hadoop OutputCollector that wraps a Flink OutputCollector.
HadoopOutputCollector() - Constructor for class org.apache.flink.hadoopcompatibility.mapred.wrapper.HadoopOutputCollector
 
HadoopOutputFormat<K,V> - Class in org.apache.flink.api.java.hadoop.mapred
Wrapper for using HadoopOutputFormats (mapred-variant) with Flink.
HadoopOutputFormat(OutputFormat<K, V>, JobConf) - Constructor for class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormat
 
HadoopOutputFormat(OutputFormat<K, V>, Class<OutputCommitter>, JobConf) - Constructor for class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormat
 
HadoopOutputFormat<K,V> - Class in org.apache.flink.api.java.hadoop.mapreduce
OutputFormat implementation allowing to use Hadoop (mapreduce) OutputFormats with Flink.
HadoopOutputFormat(OutputFormat<K, V>, Job) - Constructor for class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormat
 
HadoopOutputFormat<K,V> - Class in org.apache.flink.api.scala.hadoop.mapred
 
HadoopOutputFormat(OutputFormat<K, V>, JobConf) - Constructor for class org.apache.flink.api.scala.hadoop.mapred.HadoopOutputFormat
 
HadoopOutputFormat(OutputFormat<K, V>, Class<OutputCommitter>, JobConf) - Constructor for class org.apache.flink.api.scala.hadoop.mapred.HadoopOutputFormat
 
HadoopOutputFormat<K,V> - Class in org.apache.flink.api.scala.hadoop.mapreduce
 
HadoopOutputFormat(OutputFormat<K, V>, Job) - Constructor for class org.apache.flink.api.scala.hadoop.mapreduce.HadoopOutputFormat
 
HadoopOutputFormatBase<K,V,T> - Class in org.apache.flink.api.java.hadoop.mapred
Common base for the mapred HadoopOutputFormat wrappers.
HadoopOutputFormatBase(OutputFormat<K, V>, JobConf) - Constructor for class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
 
HadoopOutputFormatBase<K,V,T> - Class in org.apache.flink.api.java.hadoop.mapreduce
Base class shared between the Java and Scala API of Flink
HadoopOutputFormatBase(OutputFormat<K, V>, Job) - Constructor for class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
 
HadoopOutputFormatCommonBase<T> - Class in org.apache.flink.api.java.hadoop.common
A common base for both "mapred" and "mapreduce" Hadoop output formats.
HadoopOutputFormatCommonBase(Credentials) - Constructor for class org.apache.flink.api.java.hadoop.common.HadoopOutputFormatCommonBase
 
HadoopReduceCombineFunction<KEYIN,VALUEIN,KEYOUT,VALUEOUT> - Class in org.apache.flink.hadoopcompatibility.mapred
This wrapper maps a Hadoop Reducer and Combiner (mapred API) to a combinable Flink GroupReduceFunction.
HadoopReduceCombineFunction(Reducer<KEYIN, VALUEIN, KEYOUT, VALUEOUT>, Reducer<KEYIN, VALUEIN, KEYIN, VALUEIN>) - Constructor for class org.apache.flink.hadoopcompatibility.mapred.HadoopReduceCombineFunction
Maps two Hadoop Reducer (mapred API) to a combinable Flink GroupReduceFunction.
HadoopReduceCombineFunction(Reducer<KEYIN, VALUEIN, KEYOUT, VALUEOUT>, Reducer<KEYIN, VALUEIN, KEYIN, VALUEIN>, JobConf) - Constructor for class org.apache.flink.hadoopcompatibility.mapred.HadoopReduceCombineFunction
Maps two Hadoop Reducer (mapred API) to a combinable Flink GroupReduceFunction.
HadoopReduceFunction<KEYIN,VALUEIN,KEYOUT,VALUEOUT> - Class in org.apache.flink.hadoopcompatibility.mapred
This wrapper maps a Hadoop Reducer (mapred API) to a non-combinable Flink GroupReduceFunction.
HadoopReduceFunction(Reducer<KEYIN, VALUEIN, KEYOUT, VALUEOUT>) - Constructor for class org.apache.flink.hadoopcompatibility.mapred.HadoopReduceFunction
Maps a Hadoop Reducer (mapred API) to a non-combinable Flink GroupReduceFunction.
HadoopReduceFunction(Reducer<KEYIN, VALUEIN, KEYOUT, VALUEOUT>, JobConf) - Constructor for class org.apache.flink.hadoopcompatibility.mapred.HadoopReduceFunction
Maps a Hadoop Reducer (mapred API) to a non-combinable Flink GroupReduceFunction.
HadoopTupleUnwrappingIterator<KEY,VALUE> - Class in org.apache.flink.hadoopcompatibility.mapred.wrapper
Wraps a Flink Tuple2 (key-value-pair) iterator into an iterator over the second (value) field.
HadoopTupleUnwrappingIterator(TypeSerializer<KEY>) - Constructor for class org.apache.flink.hadoopcompatibility.mapred.wrapper.HadoopTupleUnwrappingIterator
 
HadoopUserOverlay - Class in org.apache.flink.runtime.clusterframework.overlays
Overlays a Hadoop user context into a container.
HadoopUserOverlay(UserGroupInformation) - Constructor for class org.apache.flink.runtime.clusterframework.overlays.HadoopUserOverlay
 
HadoopUserOverlay.Builder - Class in org.apache.flink.runtime.clusterframework.overlays
A builder for the HadoopUserOverlay.
HadoopUtils - Class in org.apache.flink.api.java.hadoop.mapred.utils
Utility class to work with Apache Hadoop MapRed classes.
HadoopUtils - Class in org.apache.flink.api.java.hadoop.mapreduce.utils
Utility class to work with next generation of Apache Hadoop MapReduce classes.
HadoopUtils - Class in org.apache.flink.hadoopcompatibility
Utility class to work with Apache Hadoop libraries.
HadoopUtils() - Constructor for class org.apache.flink.hadoopcompatibility.HadoopUtils
 
HalfUnfinishedKeyPairOperation<L,R,O> - Class in org.apache.flink.api.scala
 
HalfUnfinishedKeyPairOperation(UnfinishedKeyPairOperation<L, R, O>, Keys<L>) - Constructor for class org.apache.flink.api.scala.HalfUnfinishedKeyPairOperation
 
haMode() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
haMode() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
handIn(String, V) - Method in class org.apache.flink.runtime.iterative.concurrent.Broker
hand in the object to share
handle(BiFunction<? super T, Throwable, ? extends R>) - Method in interface org.apache.flink.runtime.concurrent.Future
Applies the given handle function to the result of the future.
handle(BiFunction<? super T, Throwable, ? extends R>) - Method in class org.apache.flink.runtime.concurrent.impl.FlinkFuture
 
handleAsync(BiFunction<? super T, Throwable, ? extends R>, Executor) - Method in interface org.apache.flink.runtime.concurrent.Future
Applies the given handle function to the result of the future.
handleAsync(BiFunction<? super T, Throwable, ? extends R>, Executor) - Method in class org.apache.flink.runtime.concurrent.impl.FlinkFuture
 
handleAsyncException(String, Throwable) - Method in interface org.apache.flink.streaming.runtime.tasks.AsyncExceptionHandler
Handles an exception thrown by another thread (e.g.
handleAsyncException(String, Throwable) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
Handles an exception thrown by another thread (e.g.
handleContainerMessage() - Method in class org.apache.flink.runtime.clusterframework.ContaineredJobManager
 
handleCustomMessage(Object) - Method in class org.apache.flink.runtime.client.JobAttachmentClientActor
 
handleCustomMessage(Object) - Method in class org.apache.flink.runtime.client.JobClientActor
Hook to handle custom client message which are not handled by the base class.
handleCustomMessage(Object) - Method in class org.apache.flink.runtime.client.JobSubmissionClientActor
 
handleDiscardedMessage(UUID, JobManagerMessages.LeaderSessionMessage) - Method in interface org.apache.flink.runtime.LeaderSessionMessageFilter
 
handleError(Exception) - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
handleError(Exception) - Method in class org.apache.flink.runtime.client.JobClientActor
 
handleError(Exception) - Method in class org.apache.flink.runtime.jobmanager.JobManager
Handles error occurring in the leader election service
handleError(Exception) - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
 
handleError(Exception) - Method in interface org.apache.flink.runtime.leaderelection.LeaderContender
Callback method which is called by LeaderElectionService in case of an error in the service thread.
handleError(Exception) - Method in interface org.apache.flink.runtime.leaderretrieval.LeaderRetrievalListener
This method is called by the LeaderRetrievalService in case of an exception.
handleError(Exception) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
handleError(Exception) - Method in class org.apache.flink.runtime.minicluster.OneTimeLeaderListenerFuture
 
handleError(Exception) - Method in class org.apache.flink.runtime.net.ConnectionUtils.LeaderConnectingAddressListener
 
handleError(Throwable) - Method in interface org.apache.flink.runtime.resourcemanager.JobLeaderIdActions
Callback to report occurring errors.
handleError(Exception) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
Handles error occurring in the leader election service
handleError(Throwable) - Method in interface org.apache.flink.runtime.taskexecutor.JobLeaderListener
Callback for errors which might occur in the JobLeaderService.
handleError(Exception) - Method in class org.apache.flink.runtime.taskmanager.TaskManager
 
handleError(Exception) - Method in class org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderConnectionInfoListener
 
handleError(Exception) - Method in class org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderGatewayListener
 
handleError(Exception) - Method in class org.apache.flink.runtime.webmonitor.JobManagerRetriever
 
handleError(Exception) - Method in class org.apache.flink.yarn.ApplicationClient
 
handleError(Exception) - Static method in class org.apache.flink.yarn.YarnTaskManager
 
handleEvent(AbstractEvent) - Method in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
Handles the event and returns whether the reader reached an end-of-stream event (either the end of the whole stream or the end of an superstep).
handleException(E) - Method in interface org.apache.flink.runtime.operators.sort.ExceptionHandler
This method is called when the handler should deal with an exception.
handleInvalidTupleAccess() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
handleJobManagerDisconnect(String) - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
handleJobManagerDisconnect(String) - Method in class org.apache.flink.runtime.taskmanager.TaskManager
 
handleJobManagerDisconnect(String) - Static method in class org.apache.flink.yarn.YarnTaskManager
 
handleJsonRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.AbstractExecutionGraphRequestHandler
 
handleJsonRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.AbstractJsonRequestHandler
Core method that handles the request and generates the response.
handleJsonRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.checkpoints.CheckpointStatsDetailsSubtasksHandler
 
handleJsonRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.ClusterOverviewHandler
 
handleJsonRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.CurrentJobIdsHandler
 
handleJsonRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.CurrentJobsOverviewHandler
 
handleJsonRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.DashboardConfigHandler
 
handleJsonRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.JarAccessDeniedHandler
 
handleJsonRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.JarDeleteHandler
 
handleJsonRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.JarListHandler
 
handleJsonRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.JarPlanHandler
 
handleJsonRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.JarRunHandler
 
handleJsonRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.JarUploadHandler
 
handleJsonRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobCancellationHandler
 
handleJsonRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobManagerConfigHandler
 
handleJsonRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobStoppingHandler
 
handleJsonRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.TaskManagersHandler
 
handleJsonRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.metrics.AbstractMetricsHandler
 
handleMessage(Object) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
 
handleMessage() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
handleMessage(Object) - Method in class org.apache.flink.runtime.akka.FlinkUntypedActor
This method contains the actor logic which defines how to react to incoming messages.
handleMessage(Object) - Method in class org.apache.flink.runtime.client.JobClientActor
 
handleMessage() - Method in class org.apache.flink.runtime.clusterframework.ContaineredJobManager
 
handleMessage(Object) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
This method receives the actor messages after they have been filtered for a match with the leader session.
handleMessage(Object) - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
 
handleMessage() - Method in interface org.apache.flink.runtime.FlinkActor
Handle incoming messages
handleMessage() - Method in class org.apache.flink.runtime.jobmanager.JobManager
Central work method of the JobManager actor.
handleMessage() - Method in class org.apache.flink.runtime.jobmanager.MemoryArchivist
 
handleMessage() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
Central handling of actor messages.
handleMessage() - Method in class org.apache.flink.yarn.ApplicationClient
 
handleMessage(Object) - Method in class org.apache.flink.yarn.YarnFlinkResourceManager
 
handleMessage() - Method in class org.apache.flink.yarn.YarnJobManager
 
handleMessage() - Method in class org.apache.flink.yarn.YarnTaskManager
 
handleName - Variable in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
A unique name of by which this state handle is identified and compared.
handleNoLeaderId(JobManagerMessages.LeaderSessionMessage) - Method in interface org.apache.flink.runtime.LeaderSessionMessageFilter
 
handleNullReturn() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
handleProcessedBuffer(T, IOException) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
Handles a processed Buffer.
handlePutStatic() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
handleRequest(AccessExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.AbstractExecutionGraphRequestHandler
 
handleRequest(AccessExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.AbstractJobVertexRequestHandler
 
handleRequest(AccessExecutionJobVertex, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.AbstractJobVertexRequestHandler
 
handleRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.AbstractJsonRequestHandler
 
handleRequest(AccessExecutionVertex, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.AbstractSubtaskAttemptRequestHandler
 
handleRequest(AccessExecution, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.AbstractSubtaskAttemptRequestHandler
 
handleRequest(AccessExecutionJobVertex, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.AbstractSubtaskRequestHandler
 
handleRequest(AccessExecutionVertex, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.AbstractSubtaskRequestHandler
 
handleRequest(AccessExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.checkpoints.CheckpointConfigHandler
 
handleRequest(AccessExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.checkpoints.CheckpointStatsDetailsHandler
 
handleRequest(AccessExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.checkpoints.CheckpointStatsDetailsSubtasksHandler
 
handleRequest(AccessExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.checkpoints.CheckpointStatsHandler
 
handleRequest(AccessExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobAccumulatorsHandler
 
handleRequest(AccessExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobConfigHandler
 
handleRequest(AccessExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobDetailsHandler
 
handleRequest(AccessExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobExceptionsHandler
 
handleRequest(AccessExecutionGraph, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobPlanHandler
 
handleRequest(AccessExecutionJobVertex, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobVertexAccumulatorsHandler
 
handleRequest(AccessExecutionJobVertex, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobVertexBackPressureHandler
 
handleRequest(AccessExecutionJobVertex, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobVertexDetailsHandler
 
handleRequest(AccessExecutionJobVertex, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.JobVertexTaskManagersHandler
 
handleRequest(Map<String, String>, Map<String, String>, ActorGateway) - Method in interface org.apache.flink.runtime.webmonitor.handlers.RequestHandler
Core method that handles the request and generates the response.
handleRequest(AccessExecutionVertex, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.SubtaskCurrentAttemptDetailsHandler
 
handleRequest(AccessExecution, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.SubtaskExecutionAttemptAccumulatorsHandler
 
handleRequest(AccessExecution, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.SubtaskExecutionAttemptDetailsHandler
 
handleRequest(AccessExecutionJobVertex, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.SubtasksAllAccumulatorsHandler
 
handleRequest(AccessExecutionJobVertex, Map<String, String>) - Method in class org.apache.flink.runtime.webmonitor.handlers.SubtasksTimesHandler
 
HandlerRedirectUtils - Class in org.apache.flink.runtime.webmonitor.handlers
Utilities to extract a redirect address.
HandlerRedirectUtils() - Constructor for class org.apache.flink.runtime.webmonitor.handlers.HandlerRedirectUtils
 
handleStateChange(ConnectionState) - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
 
handleStateChange(ConnectionState) - Method in class org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalService
 
handleStreamStatus(StreamStatus) - Method in interface org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve.ValveOutputHandler
 
handleViolation(long, long) - Method in class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.FailingHandler
 
handleViolation(long, long) - Method in class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.IgnoringHandler
 
handleViolation(long, long) - Method in class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.LoggingHandler
 
handleViolation(long, long) - Method in interface org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.MonotonyViolationHandler
Called when the property of monotonously ascending timestamps is violated, i.e., when elementTimestamp < lastTimestamp.
handleWatermark(Watermark) - Method in interface org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve.ValveOutputHandler
 
handleWhiteSpace(CharSequence, int) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
Handover - Class in org.apache.flink.streaming.connectors.kafka.internal
The Handover is a utility to hand over data (a buffer of records) and exception from a producer thread to a consumer thread.
Handover() - Constructor for class org.apache.flink.streaming.connectors.kafka.internal.Handover
 
Handover.ClosedException - Exception in org.apache.flink.streaming.connectors.kafka.internal
An exception thrown by the Handover in the Handover.pollNext() or Handover.produce(ConsumerRecords) method, after the Handover was closed via Handover.close().
Handover.WakeupException - Exception in org.apache.flink.streaming.connectors.kafka.internal
A special exception thrown bv the Handover in the Handover.produce(ConsumerRecords) method when the producer is woken up from a blocking call via Handover.wakeupProducer().
Hardware - Class in org.apache.flink.runtime.util
Convenience class to extract hardware specifics of the computer executing the running JVM.
HardwareDescription - Class in org.apache.flink.runtime.instance
A hardware description describes the resources available to a task manager.
HardwareDescription(int, long, long, long) - Constructor for class org.apache.flink.runtime.instance.HardwareDescription
Constructs a new hardware description object.
has(String) - Method in class org.apache.flink.api.java.utils.ParameterTool
Check if value is set.
hasAllocatedSlots(JobID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Check whether the job has allocated (not active) slots.
hasAlt() - Method in class org.apache.flink.api.java.utils.Option
 
hasBackPressure() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
 
hasBeenShutdown() - Method in class org.apache.flink.yarn.YarnClusterClient
 
hasBroadcastVariable(String) - Method in interface org.apache.flink.api.common.functions.RuntimeContext
Tests for the existence of the broadcast variable identified by the given name.
hasBroadcastVariable(String) - Method in class org.apache.flink.api.common.functions.util.RuntimeUDFContext
 
hasBroadcastVariable(String) - Method in class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
 
hasBroadcastVariable(String) - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
hasChildren() - Method in class org.apache.flink.runtime.instance.SharedSlot
Checks whether this shared slot has any sub slots.
hasDamOnPathDownTo(PlanNode) - Method in class org.apache.flink.optimizer.plan.BulkIterationPlanNode
 
hasDamOnPathDownTo(PlanNode) - Method in class org.apache.flink.optimizer.plan.BulkPartialSolutionPlanNode
 
hasDamOnPathDownTo(PlanNode) - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
 
hasDamOnPathDownTo(PlanNode) - Method in class org.apache.flink.optimizer.plan.NAryUnionPlanNode
 
hasDamOnPathDownTo(PlanNode) - Method in class org.apache.flink.optimizer.plan.PlanNode
Checks whether this node has a dam on the way down to the given source node.
hasDamOnPathDownTo(PlanNode) - Method in class org.apache.flink.optimizer.plan.SingleInputPlanNode
 
hasDamOnPathDownTo(PlanNode) - Method in class org.apache.flink.optimizer.plan.SolutionSetPlanNode
 
hasDamOnPathDownTo(PlanNode) - Method in class org.apache.flink.optimizer.plan.SourcePlanNode
 
hasDamOnPathDownTo(PlanNode) - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
 
hasDamOnPathDownTo(PlanNode) - Method in class org.apache.flink.optimizer.plan.WorksetPlanNode
 
hasData() - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
Determines whether data is left, either in the current target buffer or in any internal state set up for the record to serialize.
hasData() - Method in class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
 
hasData() - Method in class org.apache.flink.runtime.operators.sort.LargeRecordHandler
 
hasDefaultValue() - Method in class org.apache.flink.api.java.utils.Option
 
hasDefaultValue() - Method in class org.apache.flink.configuration.ConfigOption
Checks if this option has a default value.
hasDefaultValue - Variable in class org.apache.flink.graph.drivers.parameter.SimpleParameter
 
hasDeprecatedKeys() - Method in class org.apache.flink.configuration.ConfigOption
Checks whether this option has deprecated keys.
hasDeterministicFieldOrder() - Method in class org.apache.flink.api.common.typeutils.CompositeType
True if this type has an inherent ordering of the fields, such that a user can always be sure in which order the fields will be in.
hasDeterministicFieldOrder() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
hasDeterministicFieldOrder() - Static method in class org.apache.flink.table.runtime.types.CRowTypeInfo
 
hasField(String) - Method in class org.apache.flink.api.common.typeutils.CompositeType
Returns true when this type has a composite field with the given name.
hasField(String) - Static method in class org.apache.flink.table.runtime.types.CRowTypeInfo
 
hasFoundWorkset() - Method in class org.apache.flink.optimizer.traversals.StepFunctionValidator
 
hasFurtherInput() - Method in class org.apache.flink.runtime.operators.resettable.BlockResettableMutableObjectIterator
Checks, whether the input that is blocked by this iterator, has further elements available.
hasFurtherInput() - Method in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
Checks, whether the input that is blocked by this iterator, has further elements available.
hasGenericTypesDisabled() - Method in class org.apache.flink.api.common.ExecutionConfig
Checks whether generic types are supported.
hash(boolean[]) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArrayComparator
 
hash(byte[]) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArrayComparator
 
hash(char[]) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArrayComparator
 
hash(double[]) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArrayComparator
 
hash(float[]) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArrayComparator
 
hash(int[]) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArrayComparator
 
hash(long[]) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArrayComparator
 
hash(short[]) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArrayComparator
 
hash(T) - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
hash(BooleanValue) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
hash(ByteValue) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
hash(CharValue) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
hash(DoubleValue) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
hash(FloatValue) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
hash(IntValue) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
hash(LongValue) - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
hash(NullValue) - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
hash(ShortValue) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
hash(StringValue) - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
hash(T) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Computes a hash value for the given record.
hash(T) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
hash(T) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
hash(T) - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
hash(T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
hash(Row) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
 
hash(T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
 
hash(T) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
hash(T) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
 
hash(T) - Method in class org.apache.flink.api.scala.typeutils.CaseClassComparator
 
hash(Enumeration.Value) - Method in class org.apache.flink.api.scala.typeutils.EnumValueComparator
 
hash(Option<A>) - Method in class org.apache.flink.api.scala.typeutils.OptionTypeComparator
 
hash(String) - Method in class org.apache.flink.graph.drivers.ClusteringCoefficient
 
hash(String) - Method in class org.apache.flink.graph.drivers.ConnectedComponents
 
hash(String) - Method in class org.apache.flink.graph.drivers.EdgeList
 
hash(String) - Method in class org.apache.flink.graph.drivers.GraphMetrics
 
Hash - Interface in org.apache.flink.graph.drivers.output
Print hash of algorithm output.
hash(String) - Method in interface org.apache.flink.graph.drivers.output.Hash
Print hash of execution results.
hash(String) - Method in class org.apache.flink.graph.drivers.SimpleDriver
Print hash of execution results.
hash(String) - Method in class org.apache.flink.graph.drivers.TriangleListing
 
hash(IntValueArray) - Method in class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
 
hash(LongValueArray) - Method in class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
 
hash(NullValueArray) - Method in class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
 
hash(StringValueArray) - Method in class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
 
hash(double) - Method in class org.apache.flink.graph.utils.Murmur3_32
Process a double value.
hash(float) - Method in class org.apache.flink.graph.utils.Murmur3_32
Process a float value.
hash(int) - Method in class org.apache.flink.graph.utils.Murmur3_32
Process an integer value.
hash(long) - Method in class org.apache.flink.graph.utils.Murmur3_32
Process a long value.
hash() - Method in class org.apache.flink.graph.utils.Murmur3_32
Finalize and return the MurmurHash output.
hash(int, int) - Static method in class org.apache.flink.runtime.operators.hash.MutableHashTable
The level parameter is needed so that we can have different hash functions when we recursively apply the partitioning, so that the working set eventually fits into memory.
hash(CRow) - Method in class org.apache.flink.table.runtime.types.CRowComparator
 
HASH_SALT - Static variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
A sequence of prime numbers to be used for salting the computed hash values.
HASH_SEED - Static variable in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient.Result
 
HASH_SEED - Static variable in class org.apache.flink.graph.library.link_analysis.HITS.Result
 
HASH_SEED - Static variable in class org.apache.flink.graph.library.link_analysis.PageRank.Result
 
HASH_SEED - Static variable in class org.apache.flink.graph.library.similarity.AdamicAdar.Result
 
HASH_SEED - Static variable in class org.apache.flink.graph.library.similarity.JaccardIndex.Result
 
hashCode() - Method in class org.apache.flink.api.common.ExecutionConfig
 
hashCode() - Method in class org.apache.flink.api.common.operators.Ordering
 
hashCode() - Method in class org.apache.flink.api.common.operators.ResourceSpec
 
hashCode() - Method in class org.apache.flink.api.common.operators.util.FieldSet
 
hashCode() - Method in class org.apache.flink.api.common.operators.util.TypeComparable
 
hashCode() - Method in class org.apache.flink.api.common.restartstrategy.RestartStrategies.FixedDelayRestartStrategyConfiguration
 
hashCode() - Method in class org.apache.flink.api.common.state.AggregatingStateDescriptor
 
hashCode() - Method in class org.apache.flink.api.common.state.FoldingStateDescriptor
Deprecated.
 
hashCode() - Method in class org.apache.flink.api.common.state.ListStateDescriptor
 
hashCode() - Method in class org.apache.flink.api.common.state.MapStateDescriptor
 
hashCode() - Method in class org.apache.flink.api.common.state.ReducingStateDescriptor
 
hashCode() - Method in class org.apache.flink.api.common.state.StateDescriptor
 
hashCode() - Method in class org.apache.flink.api.common.state.ValueStateDescriptor
 
hashCode() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
hashCode() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
hashCode() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
hashCode() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
hashCode() - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
hashCode() - Method in class org.apache.flink.api.common.typeinfo.TypeHint
 
hashCode() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializerConfigSnapshot
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.CompositeType
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.GenericTypeSerializerConfigSnapshot
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
 
hashCode() - Method in interface org.apache.flink.api.common.typeutils.TypeDeserializer
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.TypeDeserializerAdapter
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.TypeSerializerConfigSnapshot
 
hashCode() - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple0
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple1
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple10
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple11
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple12
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple13
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple14
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple15
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple16
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple17
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple18
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple19
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple2
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple20
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple21
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple22
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple23
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple24
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple25
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple3
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple4
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple5
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple6
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple7
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple8
 
hashCode() - Method in class org.apache.flink.api.java.tuple.Tuple9
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.ListTypeInfo
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.PojoField
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerConfigSnapshot
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
hashCode() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
 
hashCode() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
 
hashCode() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.ArrayDescriptor
 
hashCode() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.BoxedPrimitiveDescriptor
 
hashCode() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.CaseClassDescriptor
 
hashCode() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.JavaTupleDescriptor
 
hashCode() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.PojoDescriptor
 
hashCode() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.TraversableDescriptor
 
hashCode() - Method in class org.apache.flink.api.scala.typeutils.CaseClassTypeInfo
 
hashCode() - Method in class org.apache.flink.api.scala.typeutils.EitherSerializer
 
hashCode() - Method in class org.apache.flink.api.scala.typeutils.EitherTypeInfo
 
hashCode() - Method in class org.apache.flink.api.scala.typeutils.EnumValueSerializer
 
hashCode() - Method in class org.apache.flink.api.scala.typeutils.EnumValueSerializer.ScalaEnumSerializerConfigSnapshot
 
hashCode() - Method in class org.apache.flink.api.scala.typeutils.EnumValueTypeInfo
 
hashCode() - Method in class org.apache.flink.api.scala.typeutils.NothingSerializer
 
hashCode() - Method in class org.apache.flink.api.scala.typeutils.OptionSerializer
 
hashCode() - Method in class org.apache.flink.api.scala.typeutils.OptionTypeInfo
 
hashCode() - Method in class org.apache.flink.api.scala.typeutils.ScalaNothingTypeInfo
 
hashCode() - Method in class org.apache.flink.api.scala.typeutils.TraversableSerializer
 
hashCode() - Method in class org.apache.flink.api.scala.typeutils.TraversableTypeInfo
 
hashCode() - Method in class org.apache.flink.api.scala.typeutils.TrySerializer
 
hashCode() - Method in class org.apache.flink.api.scala.typeutils.TryTypeInfo
 
hashCode() - Method in class org.apache.flink.api.scala.typeutils.UnitSerializer
 
hashCode() - Method in class org.apache.flink.api.scala.typeutils.UnitTypeInfo
 
hashCode() - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
 
hashCode() - Method in class org.apache.flink.cep.nfa.DeweyNumber
 
hashCode() - Method in class org.apache.flink.cep.nfa.NFA
 
hashCode() - Method in class org.apache.flink.cep.nfa.NFA.NFASerializer
 
hashCode() - Method in class org.apache.flink.cep.nfa.SharedBuffer
 
hashCode() - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferEdge
 
hashCode() - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
 
hashCode() - Method in class org.apache.flink.cep.nfa.State
 
hashCode() - Method in class org.apache.flink.cep.nfa.StateTransition
 
hashCode() - Method in class org.apache.flink.cep.NonDuplicatingTypeSerializer
 
hashCode() - Method in class org.apache.flink.cep.pattern.Quantifier
 
hashCode() - Method in class org.apache.flink.configuration.ConfigOption
 
hashCode() - Method in class org.apache.flink.configuration.Configuration
 
hashCode() - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
hashCode() - Method in class org.apache.flink.configuration.MemorySize
 
hashCode() - Method in class org.apache.flink.core.fs.ClosingFSDataInputStream
 
hashCode() - Method in class org.apache.flink.core.fs.ClosingFSDataOutputStream
 
hashCode() - Method in class org.apache.flink.core.fs.FileInputSplit
 
hashCode() - Method in class org.apache.flink.core.fs.Path
 
hashCode() - Method in class org.apache.flink.core.io.GenericInputSplit
 
hashCode() - Method in class org.apache.flink.core.io.LocatableInputSplit
 
hashCode() - Method in class org.apache.flink.graph.asm.dataset.ChecksumHashCode.Checksum
 
hashCode() - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees.Degrees
 
hashCode() - Method in class org.apache.flink.graph.library.clustering.directed.AverageClusteringCoefficient.Result
 
hashCode() - Method in class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient.Result
 
hashCode() - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient.Result
 
hashCode() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
 
hashCode() - Method in class org.apache.flink.graph.library.clustering.undirected.AverageClusteringCoefficient.Result
 
hashCode() - Method in class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient.Result
 
hashCode() - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient.Result
 
hashCode() - Method in class org.apache.flink.graph.library.clustering.undirected.TriadicCensus.Result
 
hashCode() - Method in class org.apache.flink.graph.library.link_analysis.HITS.Result
 
hashCode() - Method in class org.apache.flink.graph.library.link_analysis.PageRank.Result
 
hashCode() - Method in class org.apache.flink.graph.library.metric.directed.EdgeMetrics.Result
 
hashCode() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
 
hashCode() - Method in class org.apache.flink.graph.library.metric.undirected.EdgeMetrics.Result
 
hashCode() - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics.Result
 
hashCode() - Method in class org.apache.flink.graph.library.similarity.AdamicAdar.Result
 
hashCode() - Method in class org.apache.flink.graph.library.similarity.JaccardIndex.Result
 
hashCode() - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
 
hashCode() - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
 
hashCode() - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
 
hashCode() - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
 
hashCode() - Method in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
 
hashCode() - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingDataSet
 
hashCode() - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingGraph
 
hashCode() - Method in class org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore.Worker
 
hashCode() - Method in class org.apache.flink.migration.api.common.state.ListStateDescriptor
Deprecated.
 
hashCode() - Method in class org.apache.flink.migration.MigrationNamespaceSerializerProxy
Deprecated.
 
hashCode() - Method in class org.apache.flink.migration.runtime.checkpoint.KeyGroupState
Deprecated.
 
hashCode() - Method in class org.apache.flink.migration.runtime.checkpoint.savepoint.SavepointV0
 
hashCode() - Method in class org.apache.flink.migration.runtime.checkpoint.SubtaskState
Deprecated.
 
hashCode() - Method in class org.apache.flink.migration.runtime.checkpoint.TaskState
Deprecated.
 
hashCode() - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer
 
hashCode() - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.StreamRecordSerializer
 
hashCode() - Method in class org.apache.flink.migration.util.SerializedValue
Deprecated.
 
hashCode() - Method in class org.apache.flink.ml.math.DenseMatrix
 
hashCode() - Method in class org.apache.flink.ml.math.DenseVector
 
hashCode() - Method in class org.apache.flink.ml.math.SparseMatrix
 
hashCode() - Method in class org.apache.flink.ml.math.SparseVector
 
hashCode() - Method in class org.apache.flink.optimizer.costs.Costs
 
hashCode() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
 
hashCode() - Method in class org.apache.flink.optimizer.dataproperties.InterestingProperties
 
hashCode() - Method in class org.apache.flink.optimizer.dataproperties.LocalProperties
 
hashCode() - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
 
hashCode() - Method in class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
 
hashCode() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual.GlobalPropertiesPair
 
hashCode() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual.LocalPropertiesPair
 
hashCode() - Static method in class org.apache.flink.runtime.akka.RemoteAddressExtension
 
hashCode() - Method in class org.apache.flink.runtime.blob.BlobKey
 
hashCode() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableKey
 
hashCode() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetaData
 
hashCode() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
hashCode() - Method in class org.apache.flink.runtime.checkpoint.CheckpointProperties
 
hashCode() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
hashCode() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
 
hashCode() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
 
hashCode() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
 
hashCode() - Method in class org.apache.flink.runtime.checkpoint.TaskState
Deprecated.
 
hashCode() - Method in class org.apache.flink.runtime.clusterframework.messages.CheckAndAllocateContainers
 
hashCode() - Method in class org.apache.flink.runtime.clusterframework.messages.GetClusterStatus
 
hashCode() - Method in class org.apache.flink.runtime.clusterframework.messages.RegisterInfoMessageListener
 
hashCode() - Method in class org.apache.flink.runtime.clusterframework.messages.RegisterInfoMessageListenerSuccessful
 
hashCode() - Method in class org.apache.flink.runtime.clusterframework.messages.SetWorkerPoolSize
 
hashCode() - Method in class org.apache.flink.runtime.clusterframework.messages.UnRegisterInfoMessageListener
 
hashCode() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceID
 
hashCode() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
 
hashCode() - Method in class org.apache.flink.runtime.clusterframework.types.SlotID
 
hashCode() - Method in class org.apache.flink.runtime.instance.Slot
Slots must always has based on reference identity.
hashCode() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
 
hashCode() - Method in class org.apache.flink.runtime.io.network.api.CancelCheckpointMarker
 
hashCode() - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
 
hashCode() - Method in class org.apache.flink.runtime.io.network.api.EndOfPartitionEvent
 
hashCode() - Method in class org.apache.flink.runtime.io.network.api.EndOfSuperstepEvent
 
hashCode() - Method in class org.apache.flink.runtime.io.network.ConnectionID
 
hashCode() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionID
 
hashCode() - Method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
 
hashCode() - Method in class org.apache.flink.runtime.jobmanager.JobInfo
 
hashCode() - Method in exception org.apache.flink.runtime.jobmanager.scheduler.NoResourceAvailableException
 
hashCode() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
hashCode() - Method in class org.apache.flink.runtime.jobmanager.slots.AllocatedSlot
This always returns a reference hash code.
hashCode() - Method in class org.apache.flink.runtime.leaderelection.LeaderAddressAndId
 
hashCode() - Method in class org.apache.flink.runtime.messages.Acknowledge
 
hashCode() - Method in class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
 
hashCode() - Method in class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
 
hashCode() - Method in class org.apache.flink.runtime.messages.checkpoint.NotifyCheckpointComplete
 
hashCode() - Method in class org.apache.flink.runtime.messages.checkpoint.TriggerCheckpoint
 
hashCode() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
 
hashCode() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
 
hashCode() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsWithIDsOverview
 
hashCode() - Method in class org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails
 
hashCode() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
 
hashCode() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobsOverview
 
hashCode() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobsWithIDsOverview
 
hashCode() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestStatusOverview
 
hashCode() - Method in class org.apache.flink.runtime.messages.webmonitor.StatusOverview
 
hashCode() - Method in class org.apache.flink.runtime.query.KvStateLocation
 
hashCode() - Method in class org.apache.flink.runtime.query.KvStateServerAddress
 
hashCode() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
hashCode() - Method in class org.apache.flink.runtime.state.ChainedStateHandle
 
hashCode() - Method in class org.apache.flink.runtime.state.filesystem.FileStateHandle
 
hashCode() - Method in class org.apache.flink.runtime.state.HashMapSerializer
 
hashCode() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
This method should only be called in tests! This should never serve as key in a hash map.
hashCode() - Method in class org.apache.flink.runtime.state.KeyGroupRange
 
hashCode() - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
 
hashCode() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
 
hashCode() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
 
hashCode() - Method in class org.apache.flink.runtime.state.OperatorStateHandle
 
hashCode() - Method in class org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo
 
hashCode() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo
 
hashCode() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo.Snapshot
 
hashCode() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo
 
hashCode() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo.Snapshot
 
hashCode() - Method in class org.apache.flink.runtime.state.TaskStateHandles
 
hashCode() - Method in class org.apache.flink.runtime.state.VoidNamespace
 
hashCode() - Method in class org.apache.flink.runtime.taskexecutor.slot.SlotOffer
 
hashCode() - Method in class org.apache.flink.runtime.taskexecutor.SlotStatus
 
hashCode() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
hashCode() - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
 
hashCode() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
 
hashCode() - Method in class org.apache.flink.storm.wrappers.StormTuple
 
hashCode() - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
 
hashCode() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
 
hashCode() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
hashCode() - Method in class org.apache.flink.streaming.api.operators.InternalTimer
 
hashCode() - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
 
hashCode() - Static method in class org.apache.flink.streaming.api.scala.OutputTag
 
hashCode() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
 
hashCode() - Method in class org.apache.flink.streaming.api.watermark.Watermark
 
hashCode() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow
 
hashCode() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
 
hashCode() - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
 
hashCode() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartition
 
hashCode() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionLeader
 
hashCode() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
 
hashCode() - Method in class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
 
hashCode() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
hashCode() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
 
hashCode() - Method in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
hashCode() - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
hashCode() - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
hashCode() - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
hashCode() - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
hashCode() - Method in class org.apache.flink.table.plan.cost.DataSetCost
 
hashCode() - Static method in class org.apache.flink.table.plan.nodes.datastream.AccModeTrait
 
hashCode() - Static method in class org.apache.flink.table.plan.nodes.datastream.UpdateAsRetractionTrait
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.dataSet.BatchTableSourceScanRule
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateRule
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateWithNullValuesRule
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetCalcRule
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetCorrelateRule
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetDistinctRule
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetIntersectRule
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetJoinRule
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetLogicalWindowAggregateRule
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetMinusRule
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetScanRule
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetSingleRowJoinRule
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetSortRule
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetUnionRule
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetValuesRule
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetWindowAggregateRule
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamCalcRule
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamCorrelateRule
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupAggregateRule
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupWindowAggregateRule
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamLogicalWindowAggregateRule
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamOverAggregateRule
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamScanRule
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamUnionRule
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamValuesRule
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.datastream.StreamTableSourceScanRule
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.logical.EnumerableToLogicalTableScan
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.logical.LogicalUnnestRule
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.logical.PushFilterIntoTableSourceScanRule
 
hashCode() - Static method in class org.apache.flink.table.plan.rules.logical.PushProjectIntoTableSourceScanRule
 
hashCode() - Method in class org.apache.flink.table.plan.schema.ArrayRelDataType
 
hashCode() - Method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
hashCode() - Method in class org.apache.flink.table.plan.schema.GenericRelDataType
 
hashCode() - Method in class org.apache.flink.table.plan.schema.MapRelDataType
 
hashCode() - Method in class org.apache.flink.table.plan.schema.TimeIndicatorRelDataType
 
hashCode() - Method in class org.apache.flink.table.runtime.types.CRowSerializer
 
hashCode() - Static method in class org.apache.flink.table.runtime.types.CRowTypeInfo
 
hashCode() - Method in class org.apache.flink.table.sources.CsvTableSource
 
hashCode() - Method in class org.apache.flink.table.typeutils.InternalTypeInfo
 
hashCode() - Static method in class org.apache.flink.table.typeutils.RowIntervalTypeInfo
 
hashCode() - Static method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
 
hashCode() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
 
hashCode() - Method in class org.apache.flink.types.BooleanValue
 
hashCode() - Method in class org.apache.flink.types.ByteValue
 
hashCode() - Method in class org.apache.flink.types.CharValue
 
hashCode() - Method in class org.apache.flink.types.DoubleValue
 
hashCode() - Method in class org.apache.flink.types.Either.Left
 
hashCode() - Method in class org.apache.flink.types.Either.Right
 
hashCode() - Method in class org.apache.flink.types.FloatValue
 
hashCode() - Method in class org.apache.flink.types.IntValue
 
hashCode() - Method in interface org.apache.flink.types.Key
Deprecated.
All keys must override the hash-code function to generate proper deterministic hash codes, based on their contents.
hashCode() - Method in class org.apache.flink.types.ListValue
 
hashCode() - Method in class org.apache.flink.types.LongValue
 
hashCode() - Method in class org.apache.flink.types.MapValue
 
hashCode() - Method in class org.apache.flink.types.NullValue
 
hashCode() - Method in class org.apache.flink.types.Row
 
hashCode() - Method in class org.apache.flink.types.ShortValue
 
hashCode() - Method in class org.apache.flink.types.StringValue
 
hashCode() - Method in class org.apache.flink.util.AbstractID
 
hashCode() - Method in class org.apache.flink.util.OutputTag
 
hashCode() - Method in class org.apache.flink.util.SerializedValue
 
hashCode() - Method in class org.apache.flink.util.StringBasedID
 
hasHDFSDelegationToken() - Static method in class org.apache.flink.api.java.hadoop.mapred.utils.HadoopUtils
Indicates whether the current user has an HDFS delegation token.
HashFullOuterJoinBuildFirstDescriptor - Class in org.apache.flink.optimizer.operators
 
HashFullOuterJoinBuildFirstDescriptor(FieldList, FieldList) - Constructor for class org.apache.flink.optimizer.operators.HashFullOuterJoinBuildFirstDescriptor
 
HashFullOuterJoinBuildSecondDescriptor - Class in org.apache.flink.optimizer.operators
 
HashFullOuterJoinBuildSecondDescriptor(FieldList, FieldList) - Constructor for class org.apache.flink.optimizer.operators.HashFullOuterJoinBuildSecondDescriptor
 
hashJoin - Variable in class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstHashJoinIterator
 
hashJoin - Variable in class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondHashJoinIterator
 
hashJoin - Variable in class org.apache.flink.runtime.operators.hash.ReusingBuildFirstHashJoinIterator
 
hashJoin - Variable in class org.apache.flink.runtime.operators.hash.ReusingBuildSecondHashJoinIterator
 
HashJoinBuildFirstProperties - Class in org.apache.flink.optimizer.operators
 
HashJoinBuildFirstProperties(FieldList, FieldList) - Constructor for class org.apache.flink.optimizer.operators.HashJoinBuildFirstProperties
 
HashJoinBuildFirstProperties(FieldList, FieldList, boolean, boolean, boolean) - Constructor for class org.apache.flink.optimizer.operators.HashJoinBuildFirstProperties
 
HashJoinBuildSecondProperties - Class in org.apache.flink.optimizer.operators
 
HashJoinBuildSecondProperties(FieldList, FieldList) - Constructor for class org.apache.flink.optimizer.operators.HashJoinBuildSecondProperties
 
HashJoinBuildSecondProperties(FieldList, FieldList, boolean, boolean, boolean) - Constructor for class org.apache.flink.optimizer.operators.HashJoinBuildSecondProperties
 
HashJoinIteratorBase - Class in org.apache.flink.runtime.operators.hash
Common methods for all Hash Join Iterators.
HashJoinIteratorBase() - Constructor for class org.apache.flink.runtime.operators.hash.HashJoinIteratorBase
 
HashLeftOuterJoinBuildFirstDescriptor - Class in org.apache.flink.optimizer.operators
 
HashLeftOuterJoinBuildFirstDescriptor(FieldList, FieldList, boolean, boolean) - Constructor for class org.apache.flink.optimizer.operators.HashLeftOuterJoinBuildFirstDescriptor
 
HashLeftOuterJoinBuildSecondDescriptor - Class in org.apache.flink.optimizer.operators
 
HashLeftOuterJoinBuildSecondDescriptor(FieldList, FieldList, boolean, boolean) - Constructor for class org.apache.flink.optimizer.operators.HashLeftOuterJoinBuildSecondDescriptor
 
HashMapSerializer<K,V> - Class in org.apache.flink.runtime.state
A serializer for HashMap.
HashMapSerializer(TypeSerializer<K>, TypeSerializer<V>) - Constructor for class org.apache.flink.runtime.state.HashMapSerializer
Creates a map serializer that uses the given serializers to serialize the key-value pairs in the map.
HashPartition<BT,PT> - Class in org.apache.flink.runtime.operators.hash
 
HashPartition.BuildSideBuffer - Class in org.apache.flink.runtime.operators.hash
 
HashPartitionIterator<BT,PT> - Class in org.apache.flink.runtime.iterative.io
Iterator over the build side entries of a HashPartition
HashPartitionIterator(Iterator<HashPartition<BT, PT>>, TypeSerializer<BT>) - Constructor for class org.apache.flink.runtime.iterative.io.HashPartitionIterator
 
HashRightOuterJoinBuildFirstDescriptor - Class in org.apache.flink.optimizer.operators
 
HashRightOuterJoinBuildFirstDescriptor(FieldList, FieldList, boolean, boolean) - Constructor for class org.apache.flink.optimizer.operators.HashRightOuterJoinBuildFirstDescriptor
 
HashRightOuterJoinBuildSecondDescriptor - Class in org.apache.flink.optimizer.operators
 
HashRightOuterJoinBuildSecondDescriptor(FieldList, FieldList, boolean, boolean) - Constructor for class org.apache.flink.optimizer.operators.HashRightOuterJoinBuildSecondDescriptor
 
HashTableProber(TypeComparator<PT>, TypePairComparator<PT, T>) - Constructor for class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.HashTableProber
 
HashTags - Class in org.apache.flink.contrib.tweetinputformat.model.tweet.entities
Represents hashtags which have been parsed out of the Tweet text.
HashTags() - Constructor for class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.HashTags
 
hashTagsObjectStatePrimitiveHandler(Object) - Method in class org.apache.flink.contrib.tweetinputformat.io.TweetHandler
 
hasImportantDependencies(List<? extends BasicValue>, boolean) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
 
hasImportantDependencies(BasicValue) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
 
hasKeyedState() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotResult
 
hasLeadership() - Method in class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
 
hasLeadership() - Method in interface org.apache.flink.runtime.leaderelection.LeaderElectionService
Returns true if the LeaderContender with which the service has been started owns currently the leadership.
hasLeadership() - Method in class org.apache.flink.runtime.leaderelection.StandaloneLeaderElectionService
 
hasLeadership() - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
 
hasNewNetworkBufConf(Configuration) - Static method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
Returns whether the new network buffer memory configuration is present in the configuration object, i.e.
hasNext() - Method in class org.apache.flink.api.common.functions.util.CopyingIterator
 
hasNext() - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase.SimpleListIterable.SimpleListIterator
 
hasNext() - Method in class org.apache.flink.api.common.operators.util.ListKeyGroupedIterator.ValuesIterator
 
hasNext - Variable in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
hasNext - Variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
hasNext() - Method in class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
 
hasNext() - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
 
hasNext() - Method in class org.apache.flink.graph.pregel.MessageIterator
 
hasNext() - Method in class org.apache.flink.graph.spargel.MessageIterator
 
hasNext() - Method in class org.apache.flink.hadoopcompatibility.mapred.wrapper.HadoopTupleUnwrappingIterator
 
hasNext() - Method in interface org.apache.flink.runtime.io.network.api.reader.Reader
 
hasNext() - Method in class org.apache.flink.runtime.io.network.api.reader.RecordReader
 
hasNext() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable.SimpleIterator
 
hasNext() - Method in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
hasNext() - Method in class org.apache.flink.runtime.operators.resettable.ReusingBlockResettableIterator
 
hasNext() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
hasNext() - Method in class org.apache.flink.runtime.operators.util.metrics.CountingIterator
 
hasNext() - Method in class org.apache.flink.runtime.util.EmptyIterator
Always returns false, since this iterator is empty.
hasNext() - Method in class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator.ValuesIterator
 
hasNext() - Method in class org.apache.flink.runtime.util.NonReusingMutableToRegularIteratorWrapper
 
hasNext() - Method in class org.apache.flink.runtime.util.ReusingKeyGroupedIterator.ValuesIterator
 
hasNext() - Method in class org.apache.flink.runtime.util.ReusingMutableToRegularIteratorWrapper
 
hasNext() - Method in class org.apache.flink.runtime.util.SingleElementIterator
 
hasNext() - Method in class org.apache.flink.streaming.examples.join.WindowJoinSampleData.GradeSource
 
hasNext() - Method in class org.apache.flink.streaming.examples.join.WindowJoinSampleData.SalarySource
 
hasNext() - Method in class org.apache.flink.streaming.examples.utils.ThrottledIterator
 
hasNext() - Method in class org.apache.flink.streaming.scala.examples.join.WindowJoinSampleData.GradeSource
 
hasNext() - Method in class org.apache.flink.streaming.scala.examples.join.WindowJoinSampleData.SalarySource
 
hasNext() - Method in class org.apache.flink.table.runtime.aggregate.SingleElementIterable.SingleElementIterator
 
hasNext() - Method in class org.apache.flink.util.LongValueSequenceIterator
 
hasNext() - Method in class org.apache.flink.util.NumberSequenceIterator
 
hasNext() - Method in class org.apache.flink.util.UnionIterator
 
hasNoConnectedInputs() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
hasNonEmptyNFA(KEY) - Method in class org.apache.flink.cep.operator.AbstractKeyedCEPPatternOperator
 
hasNonEmptyPQ(KEY) - Method in class org.apache.flink.cep.operator.AbstractKeyedCEPPatternOperator
 
hasNonPartitionedState() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
 
hasNonPartitionedState() - Method in class org.apache.flink.runtime.checkpoint.TaskState
Deprecated.
 
hasObject() - Method in class org.apache.flink.api.common.operators.util.UserCodeClassWrapper
 
hasObject() - Method in class org.apache.flink.api.common.operators.util.UserCodeObjectWrapper
 
hasObject() - Method in interface org.apache.flink.api.common.operators.util.UserCodeWrapper
Checks whether the wrapper already has an object, or whether it needs to instantiate it.
hasOperatorState() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotResult
 
hasPendingSlotRequest() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
hasProperty(Quantifier.QuantifierProperty) - Method in class org.apache.flink.cep.pattern.Quantifier
 
hasPublicNullaryConstructor(Class<?>) - Static method in class org.apache.flink.util.InstantiationUtil
Checks, whether the given class has a public nullary constructor.
hasQuarantined(String, ActorSystem) - Method in class org.apache.flink.runtime.akka.DefaultQuarantineHandler
 
hasQuarantined(String, ActorSystem) - Method in interface org.apache.flink.runtime.akka.QuarantineHandler
Callback when the given actor system has quarantined the given remote actor system.
hasReachedEndOfFile() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileReader
 
hasReachedEndOfFile() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileSegmentReader
 
hasReachedEndOfFile() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BufferFileReader
 
hasReachedEndOfFile() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BufferFileSegmentReader
 
hasReachedEndOfFile() - Method in class org.apache.flink.runtime.io.disk.iomanager.SynchronousBufferFileReader
 
hasReachedEndOfSuperstep() - Method in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
 
hasReachedEndOfSuperstep() - Method in interface org.apache.flink.runtime.io.network.api.reader.ReaderBase
 
hasResourcesAvailable() - Method in class org.apache.flink.runtime.instance.Instance
 
hasState() - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotResult
 
hasStubWrapper() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
hasTimestamp() - Method in interface org.apache.flink.streaming.api.operators.async.queue.AsyncCollectionResult
 
hasTimestamp() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamRecordQueueEntry
 
hasTimestamp() - Method in class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
Checks whether this record has a timestamp.
hasTimestamp() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
Checks whether this record has a timestamp.
hasType() - Method in class org.apache.flink.api.java.utils.Option
 
hasUdfCollector() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
hasUdfIterableInput() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
hasUnclosedBranches() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
hasUnfinishedData() - Method in class org.apache.flink.runtime.io.network.api.serialization.AdaptiveSpanningRecordDeserializer
 
hasUnfinishedData() - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
 
hasUnfinishedData() - Method in class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
 
hasUsercodeJarFiles() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Checks whether the JobGraph has user code JAR files attached.
hasUserJarFiles(List<URL>) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
Returns true if the descriptor has the job jars to include in the classpath.
hasUserJarsInClassPath(List<URL>) - Method in class org.apache.flink.client.program.ClusterClient
Returns true if the client already has the user jar and providing it again would result in duplicate uploading of the jar.
hasUserJarsInClassPath(List<URL>) - Method in class org.apache.flink.client.program.StandaloneClusterClient
 
hasUserJarsInClassPath(List<URL>) - Method in class org.apache.flink.yarn.YarnClusterClient
 
hasUserJarsInClassPath(List<URL>) - Method in class org.apache.flink.yarn.YarnClusterClientV2
 
hasWindowsDrive() - Method in class org.apache.flink.core.fs.Path
Checks if the provided path string contains a windows drive letter.
haveAllOutputConnectionInterestingProperties() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
Checks, if all outgoing connections have their interesting properties set from their target nodes.
haystack() - Method in class org.apache.flink.table.expressions.Position
 
HBaseRowInputFormat - Class in org.apache.flink.addons.hbase
InputFormat subclass that wraps the access for HTables.
HBaseRowInputFormat(Configuration, String, HBaseTableSchema) - Constructor for class org.apache.flink.addons.hbase.HBaseRowInputFormat
 
HBaseTableSchema - Class in org.apache.flink.addons.hbase
Helps to specify an HBase Table's schema
HBaseTableSchema() - Constructor for class org.apache.flink.addons.hbase.HBaseTableSchema
 
HBaseTableSource - Class in org.apache.flink.addons.hbase
Creates a TableSource to scan an HBase table.
HBaseTableSource(Configuration, String) - Constructor for class org.apache.flink.addons.hbase.HBaseTableSource
The HBase configuration and the name of the table to read.
HCatInputFormat<T> - Class in org.apache.flink.hcatalog.java
A InputFormat to read from HCatalog tables.
HCatInputFormat() - Constructor for class org.apache.flink.hcatalog.java.HCatInputFormat
 
HCatInputFormat(String, String) - Constructor for class org.apache.flink.hcatalog.java.HCatInputFormat
 
HCatInputFormat(String, String, Configuration) - Constructor for class org.apache.flink.hcatalog.java.HCatInputFormat
 
HCatInputFormat<T> - Class in org.apache.flink.hcatalog.scala
A InputFormat to read from HCatalog tables.
HCatInputFormat(String, String, Configuration) - Constructor for class org.apache.flink.hcatalog.scala.HCatInputFormat
 
HCatInputFormat(String, String) - Constructor for class org.apache.flink.hcatalog.scala.HCatInputFormat
 
HCatInputFormatBase<T> - Class in org.apache.flink.hcatalog
A InputFormat to read from HCatalog tables.
HCatInputFormatBase() - Constructor for class org.apache.flink.hcatalog.HCatInputFormatBase
 
HCatInputFormatBase(String, String) - Constructor for class org.apache.flink.hcatalog.HCatInputFormatBase
Creates a HCatInputFormat for the given database and table.
HCatInputFormatBase(String, String, Configuration) - Constructor for class org.apache.flink.hcatalog.HCatInputFormatBase
Creates a HCatInputFormat for the given database, table, and Configuration.
HDFS_DEFAULT_CONFIG - Static variable in class org.apache.flink.configuration.ConfigConstants
Path to hdfs-defaul.xml file
HDFS_SITE_CONFIG - Static variable in class org.apache.flink.configuration.ConfigConstants
Path to hdfs-site.xml file
HDFSCopyFromLocal - Class in org.apache.flink.streaming.util
Utility for copying from local file system to a HDFS FileSystem.
HDFSCopyFromLocal() - Constructor for class org.apache.flink.streaming.util.HDFSCopyFromLocal
 
HDFSCopyToLocal - Class in org.apache.flink.streaming.util
Utility for copying from a HDFS FileSystem to the local file system.
HDFSCopyToLocal() - Constructor for class org.apache.flink.streaming.util.HDFSCopyToLocal
 
HEAD_BLOCK_LENGTH_OFFSET - Static variable in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
The offset to the header field indicating the number of bytes in the block
HEADER_FLAGS_OFFSET - Static variable in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
The offset to the flags in the header;
HEADER_LENGTH - Static variable in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
The length of the header put into the blocks.
HEADER_MAGIC_NUMBER - Static variable in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
The magic number that identifies blocks as blocks from a ChannelWriterOutputView.
headerLength - Variable in class org.apache.flink.runtime.memory.AbstractPagedInputView
 
headerLength - Variable in class org.apache.flink.runtime.memory.AbstractPagedOutputView
 
HeaderlessChannelReaderInputView - Class in org.apache.flink.runtime.io.disk.iomanager
A DataInputView that is backed by a BlockChannelReader, making it effectively a data input stream.
HeaderlessChannelReaderInputView(BlockChannelReader<MemorySegment>, List<MemorySegment>, int, int, boolean) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.HeaderlessChannelReaderInputView
Creates a new channel reader that reads from the given channel, expecting a specified number of blocks in the channel, and returns only a specified number of bytes from the last block.
headOperator - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
the head operator that consumes the input streams of this task.
HeapAggregatingState<K,N,IN,ACC,OUT> - Class in org.apache.flink.runtime.state.heap
Heap-backed partitioned ReducingState that is snapshotted into files.
HeapAggregatingState(AggregatingStateDescriptor<IN, ACC, OUT>, StateTable<K, N, ACC>, TypeSerializer<K>, TypeSerializer<N>) - Constructor for class org.apache.flink.runtime.state.heap.HeapAggregatingState
Creates a new key/value state for the given hash map of key/value pairs.
heapBuffer() - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
 
heapBuffer(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
 
heapBuffer(int, int) - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
 
HeapFoldingState<K,N,T,ACC> - Class in org.apache.flink.runtime.state.heap
Deprecated.
will be removed in a future version
HeapFoldingState(FoldingStateDescriptor<T, ACC>, StateTable<K, N, ACC>, TypeSerializer<K>, TypeSerializer<N>) - Constructor for class org.apache.flink.runtime.state.heap.HeapFoldingState
Deprecated.
Creates a new key/value state for the given hash map of key/value pairs.
HeapInternalTimerService<K,N> - Class in org.apache.flink.streaming.api.operators
InternalTimerService that stores timers on the Java heap.
HeapInternalTimerService(int, KeyGroupsList, KeyContext, ProcessingTimeService) - Constructor for class org.apache.flink.streaming.api.operators.HeapInternalTimerService
 
HeapKeyedStateBackend<K> - Class in org.apache.flink.runtime.state.heap
A AbstractKeyedStateBackend that keeps state on the Java Heap and will serialize state to streams provided by a CheckpointStreamFactory upon checkpointing.
HeapKeyedStateBackend(TaskKvStateRegistry, TypeSerializer<K>, ClassLoader, int, KeyGroupRange, boolean, ExecutionConfig) - Constructor for class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
HeapListState<K,N,V> - Class in org.apache.flink.runtime.state.heap
Heap-backed partitioned ListState that is snapshotted into files.
HeapListState(ListStateDescriptor<V>, StateTable<K, N, ArrayList<V>>, TypeSerializer<K>, TypeSerializer<N>) - Constructor for class org.apache.flink.runtime.state.heap.HeapListState
Creates a new key/value state for the given hash map of key/value pairs.
HeapMapState<K,N,UK,UV> - Class in org.apache.flink.runtime.state.heap
Heap-backed partitioned MapState that is snapshotted into files.
HeapMapState(MapStateDescriptor<UK, UV>, StateTable<K, N, HashMap<UK, UV>>, TypeSerializer<K>, TypeSerializer<N>) - Constructor for class org.apache.flink.runtime.state.heap.HeapMapState
Creates a new key/value state for the given hash map of key/value pairs.
heapMemory - Variable in class org.apache.flink.core.memory.MemorySegment
The heap byte array object relative to which we access the memory.
HeapMemorySegment - Class in org.apache.flink.core.memory
This class represents a piece of heap memory managed by Flink.
HeapMemorySegment.HeapMemorySegmentFactory - Class in org.apache.flink.core.memory
A memory segment factory that produces heap memory segments.
HeapReducingState<K,N,V> - Class in org.apache.flink.runtime.state.heap
Heap-backed partitioned ReducingState that is snapshotted into files.
HeapReducingState(ReducingStateDescriptor<V>, StateTable<K, N, V>, TypeSerializer<K>, TypeSerializer<N>) - Constructor for class org.apache.flink.runtime.state.heap.HeapReducingState
Creates a new key/value state for the given hash map of key/value pairs.
HeapSort - Class in org.apache.flink.runtime.operators.sort
 
HeapSort() - Constructor for class org.apache.flink.runtime.operators.sort.HeapSort
 
HeapValueState<K,N,V> - Class in org.apache.flink.runtime.state.heap
Heap-backed partitioned ValueState that is snapshotted into files.
HeapValueState(ValueStateDescriptor<V>, StateTable<K, N, V>, TypeSerializer<K>, TypeSerializer<N>) - Constructor for class org.apache.flink.runtime.state.heap.HeapValueState
Creates a new key/value state for the given hash map of key/value pairs.
Heartbeat(InstanceID, Seq<AccumulatorSnapshot>) - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages.Heartbeat
 
Heartbeat$() - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages.Heartbeat$
 
HEARTBEAT_INTERVAL - Static variable in class org.apache.flink.configuration.HeartbeatManagerOptions
Time interval for requesting heartbeat from sender side
HEARTBEAT_INTERVAL() - Method in class org.apache.flink.runtime.taskmanager.TaskManager$
 
HEARTBEAT_INTERVAL() - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
 
HEARTBEAT_TIMEOUT - Static variable in class org.apache.flink.configuration.HeartbeatManagerOptions
Timeout for requesting and receiving heartbeat for both sender and receiver sides
heartbeatFromJobManager(ResourceID) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
heartbeatFromJobManager(ResourceID) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Sends the heartbeat to resource manager from job manager
heartbeatFromJobManager(ResourceID) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
heartbeatFromJobManager(ResourceID) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Heartbeat request from the job manager
heartbeatFromResourceManager(ResourceID) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
heartbeatFromResourceManager(ResourceID) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
Heartbeat request from the resource manager
heartbeatFromResourceManager(ResourceID) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
heartbeatFromResourceManager(ResourceID) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Heartbeat request from the resource manager
heartbeatFromTaskManager(ResourceID) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
heartbeatFromTaskManager(ResourceID) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
Send the heartbeat to job manager from task manager
heartbeatFromTaskManager(ResourceID) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
heartbeatFromTaskManager(ResourceID) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Sends the heartbeat to resource manager from task manager
heartbeatInterval - Variable in class org.apache.flink.runtime.heartbeat.HeartbeatServices
Heartbeat interval for the created services
HeartbeatListener<I,O> - Interface in org.apache.flink.runtime.heartbeat
Interface for the interaction with the HeartbeatManager.
HeartbeatManager<I,O> - Interface in org.apache.flink.runtime.heartbeat
A heartbeat manager has to be able to do the following things: Monitor HeartbeatTarget and report heartbeat timeouts for this target Stop monitoring a HeartbeatTarget
HeartbeatManagerImpl<I,O> - Class in org.apache.flink.runtime.heartbeat
Heartbeat manager implementation.
HeartbeatManagerImpl(long, ResourceID, HeartbeatListener<I, O>, Executor, ScheduledExecutor, Logger) - Constructor for class org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
 
HeartbeatManagerOptions - Class in org.apache.flink.configuration
The set of configuration options relating to heartbeat manager settings.
HeartbeatManagerSenderImpl<I,O> - Class in org.apache.flink.runtime.heartbeat
HeartbeatManager implementation which regularly requests a heartbeat response from its monitored HeartbeatTarget.
HeartbeatManagerSenderImpl(long, long, ResourceID, HeartbeatListener<I, O>, Executor, ScheduledExecutor, Logger) - Constructor for class org.apache.flink.runtime.heartbeat.HeartbeatManagerSenderImpl
 
HeartbeatServices - Class in org.apache.flink.runtime.heartbeat
HeartbeatServices gives access to all services needed for heartbeating.
HeartbeatServices(long, long) - Constructor for class org.apache.flink.runtime.heartbeat.HeartbeatServices
 
HeartbeatTarget<I> - Interface in org.apache.flink.runtime.heartbeat
Interface for components which can be sent heartbeats and from which one can request a heartbeat response.
heartbeatTimeout - Variable in class org.apache.flink.runtime.heartbeat.HeartbeatServices
Heartbeat timeout for the created services
HeartbeatWithYarn$() - Constructor for class org.apache.flink.yarn.YarnMessages.HeartbeatWithYarn$
 
help(String) - Method in class org.apache.flink.api.java.utils.Option
Add a help text, explaining the parameter.
hereJoinedBranches - Variable in class org.apache.flink.optimizer.dag.OptimizerNode
 
hexStringToByte(String) - Static method in class org.apache.flink.util.StringUtils
Given a hex string this will return the byte array corresponding to the string .
hflushOrSync(FSDataOutputStream) - Method in class org.apache.flink.streaming.connectors.fs.StreamWriterBase
If hflush is available in this version of HDFS, then this method calls hflush, else it calls sync.
hierarchy() - Method in class org.apache.flink.runtime.instance.Slot
 
HIGH_BIT - Static variable in class org.apache.flink.graph.types.valuearray.StringValueArray
 
HighAvailabilityMode - Enum in org.apache.flink.runtime.jobmanager
High availability mode for Flink's cluster execution.
HighAvailabilityOptions - Class in org.apache.flink.configuration
The set of configuration options relating to high-availability settings.
highAvailabilityServices - Variable in class org.apache.flink.client.program.ClusterClient
Service factory for high available
highAvailabilityServices() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
HighAvailabilityServices - Interface in org.apache.flink.runtime.highavailability
The HighAvailabilityServices give access to all services needed for a highly-available setup.
highAvailabilityServices() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
highAvailabilityServices() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
 
highAvailabilityServices() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
HighAvailabilityServicesUtils - Class in org.apache.flink.runtime.highavailability
Utils class to instantiate HighAvailabilityServices implementations.
HighAvailabilityServicesUtils() - Constructor for class org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils
 
HighAvailabilityServicesUtils.AddressResolution - Enum in org.apache.flink.runtime.highavailability
 
HingeLoss - Class in org.apache.flink.ml.optimization
Hinge loss function which can be used with the GenericLossFunction
HingeLoss() - Constructor for class org.apache.flink.ml.optimization.HingeLoss
 
HingeLoss$ - Class in org.apache.flink.ml.optimization
Hinge loss function which can be used with the GenericLossFunction
HingeLoss$() - Constructor for class org.apache.flink.ml.optimization.HingeLoss$
 
HINT_LOCAL_STRATEGY - Static variable in class org.apache.flink.optimizer.Optimizer
Compiler hint key for the operator's local strategy.
HINT_LOCAL_STRATEGY_COMBINING_SORT - Static variable in class org.apache.flink.optimizer.Optimizer
Value for the local strategy compiler hint that enforces a sort based local strategy.
HINT_LOCAL_STRATEGY_HASH_BUILD_FIRST - Static variable in class org.apache.flink.optimizer.Optimizer
Value for the local strategy compiler hint that enforces a hash based local strategy.
HINT_LOCAL_STRATEGY_HASH_BUILD_SECOND - Static variable in class org.apache.flink.optimizer.Optimizer
Value for the local strategy compiler hint that enforces a hash based local strategy.
HINT_LOCAL_STRATEGY_MERGE - Static variable in class org.apache.flink.optimizer.Optimizer
Value for the local strategy compiler hint that enforces a merge based local strategy.
HINT_LOCAL_STRATEGY_NESTEDLOOP_BLOCKED_OUTER_FIRST - Static variable in class org.apache.flink.optimizer.Optimizer
Value for the local strategy compiler hint that chooses the outer side of the nested-loop local strategy.
HINT_LOCAL_STRATEGY_NESTEDLOOP_BLOCKED_OUTER_SECOND - Static variable in class org.apache.flink.optimizer.Optimizer
Value for the local strategy compiler hint that chooses the outer side of the nested-loop local strategy.
HINT_LOCAL_STRATEGY_NESTEDLOOP_STREAMED_OUTER_FIRST - Static variable in class org.apache.flink.optimizer.Optimizer
Value for the local strategy compiler hint that chooses the outer side of the nested-loop local strategy.
HINT_LOCAL_STRATEGY_NESTEDLOOP_STREAMED_OUTER_SECOND - Static variable in class org.apache.flink.optimizer.Optimizer
Value for the local strategy compiler hint that chooses the outer side of the nested-loop local strategy.
HINT_LOCAL_STRATEGY_SORT - Static variable in class org.apache.flink.optimizer.Optimizer
Value for the local strategy compiler hint that enforces a sort based local strategy.
HINT_LOCAL_STRATEGY_SORT_BOTH_MERGE - Static variable in class org.apache.flink.optimizer.Optimizer
Value for the local strategy compiler hint that enforces a sort merge based local strategy on both inputs with subsequent merging of inputs.
HINT_LOCAL_STRATEGY_SORT_FIRST_MERGE - Static variable in class org.apache.flink.optimizer.Optimizer
Value for the local strategy compiler hint that enforces a sort merge based local strategy.
HINT_LOCAL_STRATEGY_SORT_SECOND_MERGE - Static variable in class org.apache.flink.optimizer.Optimizer
Value for the local strategy compiler hint that enforces a sort merge based local strategy.
HINT_SHIP_STRATEGY - Static variable in class org.apache.flink.optimizer.Optimizer
Compiler hint key for the input channel's shipping strategy.
HINT_SHIP_STRATEGY_BROADCAST - Static variable in class org.apache.flink.optimizer.Optimizer
Value for the shipping strategy compiler hint that enforces a broadcast strategy on the input channel.
HINT_SHIP_STRATEGY_FIRST_INPUT - Static variable in class org.apache.flink.optimizer.Optimizer
Compiler hint key for the first input channel's shipping strategy.
HINT_SHIP_STRATEGY_FORWARD - Static variable in class org.apache.flink.optimizer.Optimizer
Value for the shipping strategy compiler hint that enforces a Forward strategy on the input channel, i.e.
HINT_SHIP_STRATEGY_REPARTITION - Static variable in class org.apache.flink.optimizer.Optimizer
Value for the shipping strategy compiler hint that enforces a random repartition strategy.
HINT_SHIP_STRATEGY_REPARTITION_HASH - Static variable in class org.apache.flink.optimizer.Optimizer
Value for the shipping strategy compiler hint that enforces a hash-partition strategy.
HINT_SHIP_STRATEGY_REPARTITION_RANGE - Static variable in class org.apache.flink.optimizer.Optimizer
Value for the shipping strategy compiler hint that enforces a range-partition strategy.
HINT_SHIP_STRATEGY_SECOND_INPUT - Static variable in class org.apache.flink.optimizer.Optimizer
Compiler hint key for the second input channel's shipping strategy.
Histogram - Class in org.apache.flink.api.common.accumulators
Histogram accumulator, which builds a histogram in a distributed manner.
Histogram() - Constructor for class org.apache.flink.api.common.accumulators.Histogram
 
histogram(int, H) - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
 
histogram(String, H) - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
 
Histogram - Interface in org.apache.flink.metrics
Histogram interface to be used with Flink's metrics system.
histogram(String, H) - Method in interface org.apache.flink.metrics.MetricGroup
Registers a new Histogram with Flink.
histogram(int, H) - Method in interface org.apache.flink.metrics.MetricGroup
Registers a new Histogram with Flink.
histogram(int, H) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
histogram(String, H) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
histogram(String, H) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
histogram(int, H) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
HISTOGRAM_AGG - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
HISTOGRAM aggregate function support.
HISTOGRAM_FIRST_VALUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
HISTOGRAM_FIRST_VALUE window aggregate function.
HISTOGRAM_LAST_VALUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
HISTOGRAM_LAST_VALUE window aggregate function.
HISTOGRAM_MAX - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
HISTOGRAM_MAX window aggregate function.
HISTOGRAM_MIN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
HISTOGRAM_MIN window aggregate function.
HistogramDump(QueryScopeInfo, String, long, long, double, double, double, double, double, double, double, double, double) - Constructor for class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
histograms - Variable in class org.apache.flink.metrics.reporter.AbstractReporter
 
HistogramStatistics - Class in org.apache.flink.metrics
Histogram statistics represent the current snapshot of elements recorded in the histogram.
HistogramStatistics() - Constructor for class org.apache.flink.metrics.HistogramStatistics
 
HISTORY_SERVER_ARCHIVE_DIRS - Static variable in class org.apache.flink.configuration.HistoryServerOptions
Comma-separated list of directories which the HistoryServer polls for new archives.
HISTORY_SERVER_ARCHIVE_REFRESH_INTERVAL - Static variable in class org.apache.flink.configuration.HistoryServerOptions
The interval at which the HistoryServer polls HistoryServerOptions.HISTORY_SERVER_ARCHIVE_DIRS for new archives.
HISTORY_SERVER_WEB_ADDRESS - Static variable in class org.apache.flink.configuration.HistoryServerOptions
The address under which the HistoryServer web-frontend is accessible.
HISTORY_SERVER_WEB_DIR - Static variable in class org.apache.flink.configuration.HistoryServerOptions
The local directory used by the HistoryServer web-frontend.
HISTORY_SERVER_WEB_PORT - Static variable in class org.apache.flink.configuration.HistoryServerOptions
The port under which the HistoryServer web-frontend is accessible.
HISTORY_SERVER_WEB_REFRESH_INTERVAL - Static variable in class org.apache.flink.configuration.HistoryServerOptions
The refresh interval for the HistoryServer web-frontend in milliseconds.
HISTORY_SERVER_WEB_SSL_ENABLED - Static variable in class org.apache.flink.configuration.HistoryServerOptions
Enables/Disables SSL support for the HistoryServer web-frontend.
HistoryServer - Class in org.apache.flink.runtime.webmonitor.history
The HistoryServer provides a WebInterface and REST API to retrieve information about finished jobs for which the JobManager may have already shut down.
HistoryServer(Configuration) - Constructor for class org.apache.flink.runtime.webmonitor.history.HistoryServer
 
HistoryServer(Configuration, CountDownLatch) - Constructor for class org.apache.flink.runtime.webmonitor.history.HistoryServer
 
HistoryServerOptions - Class in org.apache.flink.configuration
The set of configuration options relating to the HistoryServer.
HistoryServerStaticFileServerHandler - Class in org.apache.flink.runtime.webmonitor.history
Simple file server handler used by the HistoryServer that serves requests to web frontend's static files, such as HTML, CSS, JS or JSON files.
HistoryServerStaticFileServerHandler(File) - Constructor for class org.apache.flink.runtime.webmonitor.history.HistoryServerStaticFileServerHandler
 
HITS<K,VV,EV> - Class in org.apache.flink.graph.drivers
Driver for HITS.
HITS() - Constructor for class org.apache.flink.graph.drivers.HITS
 
HITS<K,VV,EV> - Class in org.apache.flink.graph.library.link_analysis
Hyperlink-Induced Topic Search computes two interdependent scores for every vertex in a directed graph.
HITS(int) - Constructor for class org.apache.flink.graph.library.link_analysis.HITS
Hyperlink-Induced Topic Search with a fixed number of iterations.
HITS(double) - Constructor for class org.apache.flink.graph.library.link_analysis.HITS
Hyperlink-Induced Topic Search with a convergence threshold.
HITS(int, double) - Constructor for class org.apache.flink.graph.library.link_analysis.HITS
Hyperlink-Induced Topic Search with a convergence threshold and a maximum iteration count.
HITS.Result<T> - Class in org.apache.flink.graph.library.link_analysis
Wraps the Tuple3 to encapsulate results from the HITS algorithm.
holdout() - Method in class org.apache.flink.ml.preprocessing.Splitter.TrainTestHoldoutDataSet
 
HOP - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The HOP group function.
HOP_END - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The HOP_END auxiliary function of the HOP group function.
HOP_START - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The HOP_START auxiliary function of the HOP group function.
host - Variable in class org.apache.flink.api.java.RemoteEnvironment
The hostname of the JobManager
host() - Method in class org.apache.flink.api.scala.FlinkILoop
 
host() - Method in class org.apache.flink.api.scala.FlinkShell.Config
 
hostAndPortToUrlString(String, int) - Static method in class org.apache.flink.util.NetUtils
Normalizes and encodes a hostname and port to be included in URL.
hostname() - Method in class org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore.Worker
Get the worker's assigned hostname.
hostname() - Method in class org.apache.flink.mesos.scheduler.LaunchCoordinator.Unassign
 
hostname() - Method in class org.apache.flink.mesos.scheduler.messages.AcceptOffers
 
hostname() - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
 
hostname() - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
 
hostname() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
HOUR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The SQL HOUR operator.
hour() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Creates an interval of the given number of hours.
HOUR() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
HOUR() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
HOUR() - Method in class org.apache.flink.table.expressions.TimeIntervalUnit$
 
HOUR() - Static method in class org.apache.flink.table.expressions.TimeIntervalUnit
 
HOUR() - Method in class org.apache.flink.table.expressions.TimePointUnit$
 
HOUR() - Static method in class org.apache.flink.table.expressions.TimePointUnit
 
HOUR_TO_MINUTE() - Method in class org.apache.flink.table.expressions.TimeIntervalUnit$
 
HOUR_TO_MINUTE() - Static method in class org.apache.flink.table.expressions.TimeIntervalUnit
 
HOUR_TO_SECOND() - Method in class org.apache.flink.table.expressions.TimeIntervalUnit$
 
HOUR_TO_SECOND() - Static method in class org.apache.flink.table.expressions.TimeIntervalUnit
 
hours(long) - Static method in class org.apache.flink.api.common.time.Time
Creates a new Time that represents the given number of hours.
hours(long) - Static method in class org.apache.flink.streaming.api.windowing.time.Time
Creates a new Time that represents the given number of hours.
hours() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Creates an interval of the given number of hours.
HOURS() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
HOURS() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
HTTP_DATE_FORMAT - Static variable in class org.apache.flink.runtime.webmonitor.files.StaticFileServerHandler
Date format for HTTP
HttpRequestHandler - Class in org.apache.flink.runtime.webmonitor
Simple code which handles all HTTP requests from the user, and passes them to the Router handler directly if they do not involve file upload requests.
HttpRequestHandler(File) - Constructor for class org.apache.flink.runtime.webmonitor.HttpRequestHandler
 
httpsEnabled - Variable in class org.apache.flink.runtime.webmonitor.RuntimeMonitorHandlerBase
Whether the web service has https enabled
Huge() - Method in class org.apache.flink.table.plan.cost.DataSetCost$
 
Huge() - Static method in class org.apache.flink.table.plan.cost.DataSetCost
 
HybridMemorySegment - Class in org.apache.flink.core.memory
This class represents a piece of memory managed by Flink.
HybridMemorySegment.HybridMemorySegmentFactory - Class in org.apache.flink.core.memory
Base factory for hybrid memory segments.
HypercubeGraph - Class in org.apache.flink.graph.drivers.input
Generate a HypercubeGraph.
HypercubeGraph() - Constructor for class org.apache.flink.graph.drivers.input.HypercubeGraph
 
HypercubeGraph - Class in org.apache.flink.graph.generator
 
HypercubeGraph(ExecutionEnvironment, long) - Constructor for class org.apache.flink.graph.generator.HypercubeGraph
An undirected Graph where edges form an n-dimensional hypercube.

I

i() - Method in class org.apache.flink.table.codegen.CodeGenUtils.ProductAccessor
 
id() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.ArrayDescriptor
 
id() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.BoxedPrimitiveDescriptor
 
id() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.CaseClassDescriptor
 
id() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.EitherDescriptor
 
id() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.EnumValueDescriptor
 
id() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.FactoryTypeDescriptor
 
id() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.GenericClassDescriptor
 
id() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.JavaTupleDescriptor
 
id() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.NothingDescriptor
 
id() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.OptionDescriptor
 
id() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.PojoDescriptor
 
id() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.PrimitiveDescriptor
 
id() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.RecursiveDescriptor
 
id() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.TraversableDescriptor
 
id() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.TryDescriptor
 
id() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.TypeParameterDescriptor
 
id() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.UDTDescriptor
 
id() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.UnitDescriptor
 
id() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.UnsupportedDescriptor
 
id() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.ValueDescriptor
 
id() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.WritableDescriptor
 
id - Variable in class org.apache.flink.examples.java.clustering.KMeans.Centroid
 
id() - Method in class org.apache.flink.examples.scala.clustering.KMeans.Centroid
 
id() - Method in class org.apache.flink.ml.recommendation.ALS.Factors
 
id - Variable in class org.apache.flink.optimizer.dag.OptimizerNode
 
id - Variable in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
The ID of the underlying channel.
ID(File, int) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
 
ID(File, int, Random) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
 
id() - Method in class org.apache.flink.runtime.messages.JobClientMessages.ConnectionTimeout
 
ID - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
 
id - Variable in class org.apache.flink.streaming.api.transformations.StreamTransformation
 
id() - Method in class org.apache.flink.table.examples.scala.TPCHQuery3Table.Customer
 
id() - Method in class org.apache.flink.table.examples.scala.TPCHQuery3Table.Lineitem
 
IdAndEstimatesVisitor - Class in org.apache.flink.optimizer.traversals
This traversal of the optimizer DAG assigns IDs to each node (in a pre-order fashion), and calls each node to compute its estimates.
IdAndEstimatesVisitor(DataStatistics) - Constructor for class org.apache.flink.optimizer.traversals.IdAndEstimatesVisitor
 
idCounter - Static variable in class org.apache.flink.streaming.api.transformations.StreamTransformation
 
ident() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
identifier - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
identifier() - Method in class org.apache.flink.runtime.akka.serialization.IOReadableWritableSerializer
 
identifier() - Method in class org.apache.flink.runtime.akka.serialization.WritableSerializer
 
identifyDynamicPath(int) - Method in class org.apache.flink.optimizer.dag.AbstractPartialSolutionNode
 
identifyDynamicPath(int) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
identity() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
identity() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
IdentityGroupReduce<IN> - Class in org.apache.flink.python.api.functions.util
 
IdentityGroupReduce() - Constructor for class org.apache.flink.python.api.functions.util.IdentityGroupReduce
 
IdentityMapper() - Constructor for class org.apache.flink.graph.utils.GraphUtils.IdentityMapper
 
IDLE - Static variable in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
Idle$() - Constructor for class org.apache.flink.mesos.scheduler.LaunchCoordinator.Idle$
 
Idle$() - Constructor for class org.apache.flink.mesos.scheduler.ReconciliationCoordinator.Idle$
 
IDLE_STATUS - Static variable in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
IdPartitioner - Class in org.apache.flink.api.java.functions
 
IdPartitioner() - Constructor for class org.apache.flink.api.java.functions.IdPartitioner
 
idx() - Method in class org.apache.flink.ml.outlier.StochasticOutlierSelection.BreezeLabeledVector
 
IF() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
IF() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
If - Class in org.apache.flink.table.expressions
 
If(Expression, Expression, Expression) - Constructor for class org.apache.flink.table.expressions.If
 
If$ - Class in org.apache.flink.table.expressions
 
If$() - Constructor for class org.apache.flink.table.expressions.If$
 
ifFalse() - Method in class org.apache.flink.table.expressions.If
 
ifMethodExistInFunction(String, UserDefinedFunction) - Method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils$
Check if a given method exists in the given function
ifMethodExistInFunction(String, UserDefinedFunction) - Static method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils
Check if a given method exists in the given function
ifTrue() - Method in class org.apache.flink.table.expressions.If
 
ignoreComments(String) - Method in class org.apache.flink.api.java.io.CsvReader
Configures the string that starts comments.
ignoreCommentsEdges(String) - Method in class org.apache.flink.graph.GraphCsvReader
Configures the string that starts comments for the Edge Csv Reader.
ignoreCommentsVertices(String) - Method in class org.apache.flink.graph.GraphCsvReader
Configures the string that starts comments for the Vertex Csv Reader.
ignoreFirstLine() - Method in class org.apache.flink.api.java.io.CsvReader
Sets the CSV reader to ignore the first line.
ignoreFirstLine() - Method in class org.apache.flink.table.sources.CsvTableSource.Builder
Ignore the first line.
ignoreFirstLineEdges() - Method in class org.apache.flink.graph.GraphCsvReader
Sets the CSV reader for the Edges file to ignore the first line.
ignoreFirstLineVertices() - Method in class org.apache.flink.graph.GraphCsvReader
Sets the CSV reader for the Vertices file to ignore the first line.
ignoreInvalidLines - Variable in class org.apache.flink.api.java.io.CsvReader
 
ignoreInvalidLines() - Method in class org.apache.flink.api.java.io.CsvReader
Sets the CSV reader to ignore any invalid lines.
ignoreInvalidLinesEdges() - Method in class org.apache.flink.graph.GraphCsvReader
Sets the CSV reader for the Edges file to ignore any invalid lines.
ignoreInvalidLinesVertices() - Method in class org.apache.flink.graph.GraphCsvReader
Sets the CSV reader Vertices file to ignore any invalid lines.
ignoreParseErrors() - Method in class org.apache.flink.table.sources.CsvTableSource.Builder
Skip records with parse error instead to fail.
IgnoringHandler() - Constructor for class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.IgnoringHandler
 
IllegalConfigurationException - Exception in org.apache.flink.configuration
An IllegalConfigurationException is thrown when the values in a given Configuration are not valid.
IllegalConfigurationException(String) - Constructor for exception org.apache.flink.configuration.IllegalConfigurationException
Constructs an new IllegalConfigurationException with the given error message.
IllegalConfigurationException(String, Throwable) - Constructor for exception org.apache.flink.configuration.IllegalConfigurationException
Constructs an new IllegalConfigurationException with the given error message and a given cause.
IllegalExecutionStateException - Exception in org.apache.flink.runtime.executiongraph
A special IllegalStateException indicating a mismatch in the expected and actual ExecutionState of an Execution.
IllegalExecutionStateException(ExecutionState, ExecutionState) - Constructor for exception org.apache.flink.runtime.executiongraph.IllegalExecutionStateException
Creates a new IllegalExecutionStateException with the error message indicating the expected and actual state.
IllegalExecutionStateException(Execution, ExecutionState, ExecutionState) - Constructor for exception org.apache.flink.runtime.executiongraph.IllegalExecutionStateException
Creates a new IllegalExecutionStateException with the error message indicating the expected and actual state.
ILoopCompat - Class in org.apache.flink.api.scala
 
ILoopCompat(Option<BufferedReader>, PrintWriter) - Constructor for class org.apache.flink.api.scala.ILoopCompat
 
ImmutableMaxAgg() - Constructor for class org.apache.flink.api.java.aggregation.MaxAggregationFunction.ImmutableMaxAgg
 
ImmutableMinAgg() - Constructor for class org.apache.flink.api.java.aggregation.MinAggregationFunction.ImmutableMinAgg
 
Impl(SqlFunction) - Constructor for class org.apache.calcite.sql2rel.AuxiliaryConverter.Impl
 
ImplicitExpressionConversions - Interface in org.apache.flink.table.api.scala
Implicit conversions from Scala Literals to Expression Literal and from Expression to ImplicitExpressionOperations.
ImplicitExpressionConversions.LiteralBooleanExpression - Class in org.apache.flink.table.api.scala
 
ImplicitExpressionConversions.LiteralByteExpression - Class in org.apache.flink.table.api.scala
 
ImplicitExpressionConversions.LiteralDoubleExpression - Class in org.apache.flink.table.api.scala
 
ImplicitExpressionConversions.LiteralFloatExpression - Class in org.apache.flink.table.api.scala
 
ImplicitExpressionConversions.LiteralIntExpression - Class in org.apache.flink.table.api.scala
 
ImplicitExpressionConversions.LiteralJavaDecimalExpression - Class in org.apache.flink.table.api.scala
 
ImplicitExpressionConversions.LiteralLongExpression - Class in org.apache.flink.table.api.scala
 
ImplicitExpressionConversions.LiteralScalaDecimalExpression - Class in org.apache.flink.table.api.scala
 
ImplicitExpressionConversions.LiteralShortExpression - Class in org.apache.flink.table.api.scala
 
ImplicitExpressionConversions.LiteralSqlDateExpression - Class in org.apache.flink.table.api.scala
 
ImplicitExpressionConversions.LiteralSqlTimeExpression - Class in org.apache.flink.table.api.scala
 
ImplicitExpressionConversions.LiteralSqlTimestampExpression - Class in org.apache.flink.table.api.scala
 
ImplicitExpressionConversions.LiteralStringExpression - Class in org.apache.flink.table.api.scala
 
ImplicitExpressionConversions.UnresolvedFieldExpression - Class in org.apache.flink.table.api.scala
 
ImplicitExpressionConversions.WithOperations - Class in org.apache.flink.table.api.scala
 
ImplicitExpressionOperations - Interface in org.apache.flink.table.api.scala
These are all the operations that can be used to construct an Expression AST for expression operations.
IN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
IN operator tests for a value's membership in a sub-query or a list of values.
in - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
IN_FENNEL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Use of the IN_FENNEL operator forces the argument to be evaluated in Fennel.
InBlockInformation(long[], ALS.BlockRating[]) - Constructor for class org.apache.flink.ml.recommendation.ALS.InBlockInformation
 
InBlockInformation$() - Constructor for class org.apache.flink.ml.recommendation.ALS.InBlockInformation$
 
inc() - Method in interface org.apache.flink.metrics.Counter
Increment the current count by 1.
inc(long) - Method in interface org.apache.flink.metrics.Counter
Increment the current count by the given value.
inc() - Method in class org.apache.flink.metrics.SimpleCounter
Increment the current count by 1.
inc(long) - Method in class org.apache.flink.metrics.SimpleCounter
Increment the current count by the given value.
includeAlternativeOperatorIDs(Map<OperatorID, ExecutionJobVertex>) - Static method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
includedMask - Variable in class org.apache.flink.api.java.io.CsvReader
 
includeFields(boolean...) - Method in class org.apache.flink.api.java.io.CsvReader
Configures which fields of the CSV file should be included and which should be skipped.
includeFields(String) - Method in class org.apache.flink.api.java.io.CsvReader
Configures which fields of the CSV file should be included and which should be skipped.
includeFields(long) - Method in class org.apache.flink.api.java.io.CsvReader
Configures which fields of the CSV file should be included and which should be skipped.
includeFieldsEdges(boolean...) - Method in class org.apache.flink.graph.GraphCsvReader
Configures which fields of the CSV file containing edges data should be included and which should be skipped.
includeFieldsEdges(String) - Method in class org.apache.flink.graph.GraphCsvReader
Configures which fields of the CSV file containing edges data should be included and which should be skipped.
includeFieldsEdges(long) - Method in class org.apache.flink.graph.GraphCsvReader
Configures which fields of the CSV file containing edges data should be included and which should be skipped.
includeFieldsVertices(boolean...) - Method in class org.apache.flink.graph.GraphCsvReader
Configures which fields of the CSV file containing vertices data should be included and which should be skipped.
includeFieldsVertices(String) - Method in class org.apache.flink.graph.GraphCsvReader
Configures which fields of the CSV file containing vertices data should be included and which should be skipped.
includeFieldsVertices(long) - Method in class org.apache.flink.graph.GraphCsvReader
Configures which fields of the CSV file containing vertices data should be included and which should be skipped.
includeLegacyJobVertexIDs(Map<JobVertexID, ExecutionJobVertex>) - Static method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
includeManifest() - Method in class org.apache.flink.runtime.akka.serialization.IOReadableWritableSerializer
 
includeManifest() - Method in class org.apache.flink.runtime.akka.serialization.WritableSerializer
 
includeRegionInScan(byte[], byte[]) - Method in class org.apache.flink.addons.hbase.AbstractTableInputFormat
Test if the given region is to be included in the scan while splitting the regions of a table.
IncompatibleKeysException(String) - Constructor for exception org.apache.flink.api.common.operators.Keys.IncompatibleKeysException
 
IncompatibleKeysException(TypeInformation<?>, TypeInformation<?>) - Constructor for exception org.apache.flink.api.common.operators.Keys.IncompatibleKeysException
 
inConn - Variable in class org.apache.flink.optimizer.dag.SingleInputNode
 
incrCounter(Enum<?>, long) - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyReporter
 
incrCounter(String, String, long) - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyReporter
 
increase() - Method in class org.apache.flink.cep.nfa.DeweyNumber
Creates a new dewey number from this such that its last digit is increased by one.
increase(int) - Method in class org.apache.flink.cep.nfa.DeweyNumber
Creates a new dewey number from this such that its last digit is increased by the supplied number
increaseBackoff() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
Increases the current backoff and returns whether the operation was successful.
increaseNumConnectionsThatContributed() - Method in class org.apache.flink.optimizer.postpass.AbstractSchema
 
increment() - Method in class org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
Increments the reference count and returns whether it was successful.
IncrementalAggregateAllTimeWindowFunction - Class in org.apache.flink.table.runtime.aggregate
Computes the final aggregate value from incrementally computed aggregates.
IncrementalAggregateAllTimeWindowFunction(Option<Object>, Option<Object>, int) - Constructor for class org.apache.flink.table.runtime.aggregate.IncrementalAggregateAllTimeWindowFunction
 
IncrementalAggregateAllWindowFunction<W extends Window> - Class in org.apache.flink.table.runtime.aggregate
Computes the final aggregate value from incrementally computed aggregates.
IncrementalAggregateAllWindowFunction(int) - Constructor for class org.apache.flink.table.runtime.aggregate.IncrementalAggregateAllWindowFunction
 
IncrementalAggregateTimeWindowFunction - Class in org.apache.flink.table.runtime.aggregate
Computes the final aggregate value from incrementally computed aggreagtes.
IncrementalAggregateTimeWindowFunction(int, int, Option<Object>, Option<Object>, int) - Constructor for class org.apache.flink.table.runtime.aggregate.IncrementalAggregateTimeWindowFunction
 
IncrementalAggregateWindowFunction<W extends Window> - Class in org.apache.flink.table.runtime.aggregate
Computes the final aggregate value from incrementally computed aggreagtes.
IncrementalAggregateWindowFunction(int, int, int) - Constructor for class org.apache.flink.table.runtime.aggregate.IncrementalAggregateWindowFunction
 
IncrementalKeyedStateHandle - Class in org.apache.flink.runtime.state
The handle to states of an incremental snapshot.
IncrementalKeyedStateHandle(UUID, KeyGroupRange, long, Map<StateHandleID, StreamStateHandle>, Map<StateHandleID, StreamStateHandle>, StreamStateHandle) - Constructor for class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
 
IncrementalLearningSkeleton - Class in org.apache.flink.streaming.examples.ml
Skeleton for incremental machine learning algorithm consisting of a pre-computed model, which gets updated for the new inputs and new input data for which the job provides predictions.
IncrementalLearningSkeleton() - Constructor for class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton
 
IncrementalLearningSkeleton.FiniteNewDataSource - Class in org.apache.flink.streaming.examples.ml
Feeds new data for newData.
IncrementalLearningSkeleton.FiniteTrainingDataSource - Class in org.apache.flink.streaming.examples.ml
Feeds new training data for the partial model builder.
IncrementalLearningSkeleton.LinearTimestamp - Class in org.apache.flink.streaming.examples.ml
 
IncrementalLearningSkeleton.PartialModelBuilder - Class in org.apache.flink.streaming.examples.ml
Builds up-to-date partial models on new training data.
IncrementalLearningSkeleton.Predictor - Class in org.apache.flink.streaming.examples.ml
Creates newData using the model produced in batch-processing and the up-to-date partial model.
IncrementalLearningSkeletonData - Class in org.apache.flink.streaming.examples.ml.util
 
IncrementalSSSP - Class in org.apache.flink.graph.examples
This example illustrates how to create a Graph directly from CSV files use the scatter-gather iteration's messaging direction configuration option Incremental Single Sink Shortest Paths Example.
IncrementalSSSP() - Constructor for class org.apache.flink.graph.examples.IncrementalSSSP
 
IncrementalSSSP.InvalidateMessenger - Class in org.apache.flink.graph.examples
 
IncrementalSSSP.VertexDistanceUpdater - Class in org.apache.flink.graph.examples
 
IncrementalSSSPData - Class in org.apache.flink.graph.examples.data
Provides the default data sets used for the IncrementalSSSP example program.
incrementIterationCounter() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
incrNewOperationCounters(boolean) - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
inDegrees() - Method in class org.apache.flink.graph.Graph
Return the in-degree of all vertices in the graph
inDegrees() - Method in class org.apache.flink.graph.scala.Graph
Return the in-degree of all vertices in the graph
Indenter - Class in org.apache.flink.table.codegen
 
Indenter() - Constructor for class org.apache.flink.table.codegen.Indenter
 
Indenter$ - Class in org.apache.flink.table.codegen
 
Indenter$() - Constructor for class org.apache.flink.table.codegen.Indenter$
 
IndentStringContext - Class in org.apache.flink.table.codegen
 
IndentStringContext(StringContext) - Constructor for class org.apache.flink.table.codegen.IndentStringContext
 
index() - Method in class org.apache.flink.ml.common.Block
 
index - Variable in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
The index of the subpartition at the parent partition.
index() - Method in class org.apache.flink.table.expressions.ArrayElementAt
 
IndexedRow - Class in org.apache.flink.ml.math.distributed
Represents a row in row-major matrix.
IndexedRow(int, Vector) - Constructor for class org.apache.flink.ml.math.distributed.IndexedRow
 
IndexedRow$ - Class in org.apache.flink.ml.math.distributed
 
IndexedRow$() - Constructor for class org.apache.flink.ml.math.distributed.IndexedRow$
 
IndexedSortable - Interface in org.apache.flink.runtime.operators.sort
 
IndexedSorter - Interface in org.apache.flink.runtime.operators.sort
 
indexes - Variable in class org.apache.flink.api.common.operators.Ordering
 
indexOf(Object) - Method in class org.apache.flink.types.ListValue
 
IndexRequestBuilder<T> - Interface in org.apache.flink.streaming.connectors.elasticsearch
Deprecated.
Deprecated since version 1.2, to be removed at version 2.0. Please create a ElasticsearchSink using a ElasticsearchSinkFunction instead.
indices() - Method in class org.apache.flink.ml.math.SparseVector
 
INDIVIDUAL_RESTART_STRATEGY_NAME - Static variable in class org.apache.flink.runtime.executiongraph.failover.FailoverStrategyLoader
Config name for the RestartIndividualStrategy
INF_TIMEOUT() - Method in class org.apache.flink.runtime.akka.AkkaUtils$
 
INF_TIMEOUT() - Static method in class org.apache.flink.runtime.akka.AkkaUtils
 
inferReturnType(SqlOperatorBinding) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
inferReturnType(RelDataTypeFactory, List<RelDataType>) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
inferReturnType(SqlOperatorBinding) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
inferReturnType(RelDataTypeFactory, List<RelDataType>) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
inferReturnType(SqlOperatorBinding) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
inferReturnType(RelDataTypeFactory, List<RelDataType>) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
inferReturnType(SqlOperatorBinding) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
inferReturnType(RelDataTypeFactory, List<RelDataType>) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
Infinity() - Method in class org.apache.flink.table.plan.cost.DataSetCost$
 
Infinity() - Static method in class org.apache.flink.table.plan.cost.DataSetCost
 
inFirstIteration() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
INFLATER_INPUT_STREAM_FACTORIES - Static variable in class org.apache.flink.api.common.io.FileInputFormat
A mapping of file extensions to decompression algorithms based on DEFLATE.
InflaterInputStreamFactory<T extends InputStream> - Interface in org.apache.flink.api.common.io.compression
Creates a new instance of a certain subclass of InflaterInputStream.
info(String[]) - Method in class org.apache.flink.client.CliFrontend
Executes the info action.
INFO_CATEGORY_JM - Static variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
Categories to be returned by QueryScopeInfo.getCategory() to avoid instanceof checks.
INFO_CATEGORY_JOB - Static variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
 
INFO_CATEGORY_OPERATOR - Static variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
 
INFO_CATEGORY_TASK - Static variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
 
INFO_CATEGORY_TM - Static variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
 
InfoMessage - Class in org.apache.flink.runtime.clusterframework.messages
A simple informational message sent by the resource master to the client.
InfoMessage(String) - Constructor for class org.apache.flink.runtime.clusterframework.messages.InfoMessage
 
InfoMessage(String, Date) - Constructor for class org.apache.flink.runtime.clusterframework.messages.InfoMessage
 
InfoMessage - Interface in org.apache.flink.runtime.messages.webmonitor
Abstract base interface of all info messages exchanged between the JobManager an for example the runtime monitor.
InfoMessageListenerRpcGateway - Interface in org.apache.flink.runtime.resourcemanager
A gateway to listen for info messages from ResourceManager
InfoOptions - Class in org.apache.flink.client.cli
Command line options for the INFO command
InfoOptions(CommandLine) - Constructor for class org.apache.flink.client.cli.InfoOptions
 
IngestionTimeExtractor<T> - Class in org.apache.flink.streaming.api.functions
A timestamp assigner that assigns timestamps based on the machine's wall clock.
IngestionTimeExtractor() - Constructor for class org.apache.flink.streaming.api.functions.IngestionTimeExtractor
 
init(Frame) - Method in class org.apache.flink.api.java.sca.ModifiedASMFrame
 
init(IterationRuntimeContext) - Method in class org.apache.flink.graph.gsa.ApplyFunction
 
init(IterationRuntimeContext) - Method in class org.apache.flink.graph.gsa.GatherFunction
 
init(IterationRuntimeContext) - Method in class org.apache.flink.graph.gsa.SumFunction
 
init(int, double) - Method in class org.apache.flink.ml.math.DenseVector$
 
init(int, double) - Static method in class org.apache.flink.ml.math.DenseVector
 
init() - Method in class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
 
init() - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
 
init() - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
 
init() - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationTail
 
init() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
init() - Method in class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
 
INIT_ERROR_EXIT_CODE - Static variable in class org.apache.flink.yarn.AbstractYarnFlinkApplicationMasterRunner
The exit code returned if the initialization of the application master failed
initArray() - Method in class org.apache.flink.api.scala.typeutils.CaseClassSerializer
 
initBroadcastInputReaders() - Method in class org.apache.flink.runtime.operators.BatchTask
Creates the record readers for the extra broadcast inputs as configured by TaskConfig.getNumBroadcastInputs().
initBroadcastInputsSerializers(int) - Method in class org.apache.flink.runtime.operators.BatchTask
Creates all the serializers and iterators for the broadcast inputs.
INITCAP - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
initCap() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Converts the initial letter of each word in a string to uppercase.
InitCap - Class in org.apache.flink.table.expressions
Returns str with the first letter of each word in uppercase.
InitCap(Expression) - Constructor for class org.apache.flink.table.expressions.InitCap
 
InitCap$ - Class in org.apache.flink.table.expressions
 
InitCap$() - Constructor for class org.apache.flink.table.expressions.InitCap$
 
initCause(Throwable) - Static method in exception org.apache.flink.table.api.AmbiguousTableSourceConverterException
 
initCause(Throwable) - Static method in exception org.apache.flink.table.api.CatalogAlreadyExistException
 
initCause(Throwable) - Static method in exception org.apache.flink.table.api.CatalogNotExistException
 
initCause(Throwable) - Static method in exception org.apache.flink.table.api.ExpressionParserException
 
initCause(Throwable) - Static method in exception org.apache.flink.table.api.ExternalCatalogAlreadyExistException
 
initCause(Throwable) - Static method in exception org.apache.flink.table.api.ExternalCatalogNotExistException
 
initCause(Throwable) - Static method in exception org.apache.flink.table.api.NoMatchedTableSourceConverterException
 
initCause(Throwable) - Static method in exception org.apache.flink.table.api.SqlParserException
 
initCause(Throwable) - Static method in exception org.apache.flink.table.api.TableAlreadyExistException
 
initCause(Throwable) - Static method in exception org.apache.flink.table.api.TableException
 
initCause(Throwable) - Static method in exception org.apache.flink.table.api.TableNotExistException
 
initCause(Throwable) - Static method in exception org.apache.flink.table.api.UnresolvedException
 
initCause(Throwable) - Static method in exception org.apache.flink.table.api.ValidationException
 
initCleanupTimeState(String) - Method in class org.apache.flink.table.runtime.aggregate.ProcessFunctionWithCleanupState
 
initFunction() - Method in class org.apache.flink.table.runtime.aggregate.AggregateAggFunction
 
INITIAL_BUFFER_SIZE() - Method in class org.apache.flink.runtime.akka.serialization.IOReadableWritableSerializer
 
INITIAL_BUFFER_SIZE() - Method in class org.apache.flink.runtime.akka.serialization.WritableSerializer
 
INITIAL_CENTERS - Static variable in class org.apache.flink.test.testdata.KMeansData
 
INITIAL_CENTERS_2D - Static variable in class org.apache.flink.test.testdata.KMeansData
 
INITIAL_POLLING_DELAY() - Method in class org.apache.flink.yarn.ApplicationClient
 
INITIAL_RECONCILIATION_TIMEOUT() - Method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator$
 
INITIAL_RECONCILIATION_TIMEOUT() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
INITIAL_REGISTRATION_TIMEOUT() - Method in class org.apache.flink.yarn.ApplicationClient$
 
INITIAL_REGISTRATION_TIMEOUT() - Static method in class org.apache.flink.yarn.ApplicationClient
 
InitializationTypeConflictException - Exception in org.apache.flink.runtime.broadcast
 
InitializationTypeConflictException(Class<?>) - Constructor for exception org.apache.flink.runtime.broadcast.InitializationTypeConflictException
 
initialize(URI) - Method in class org.apache.flink.core.fs.FileSystem
Called after a new FileSystem instance is constructed.
initialize(URI) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
initialize(URI) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
initialize() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
 
initialize() - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
initialize() - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
initialize() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
initialize() - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
initialize() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Initializes the framework specific components.
initialize() - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
 
initialize(URI) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
 
initialize(URI) - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
 
initialize() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
initialize() - Method in class org.apache.flink.runtime.iterative.task.IterationIntermediateTask
 
initialize() - Method in class org.apache.flink.runtime.iterative.task.IterationTailTask
 
initialize() - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
 
initialize() - Method in class org.apache.flink.runtime.operators.BatchTask
 
initialize() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
 
initialize() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
 
initialize() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
 
initialize() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
 
initialize() - Method in interface org.apache.flink.runtime.operators.ResettableDriver
 
initialize() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
Initializes the framework specific components.
initialize() - Method in class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
 
initialize(FlinkLocalCluster.LocalClusterFactory) - Static method in class org.apache.flink.storm.api.FlinkLocalCluster
Sets a different factory for FlinkLocalClusters to be used for execution.
initialize() - Method in class org.apache.flink.yarn.YarnFlinkResourceManager
 
initialize() - Method in class org.apache.flink.yarn.YarnResourceManager
 
initialize(ActorRef) - Method in class org.apache.flink.yarn.YarnResourceManagerCallbackHandler
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.AggregationFunction
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.MaxAggregationFunction.ImmutableMaxAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.MaxAggregationFunction.MutableMaxAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.MinAggregationFunction.ImmutableMinAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.MinAggregationFunction.MutableMinAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.ByteSumAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.ByteValueSumAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.DoubleSumAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.DoubleValueSumAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.FloatSumAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.FloatValueSumAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.IntSumAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.IntValueSumAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.LongSumAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.LongValueSumAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.ShortSumAgg
 
initializeAggregate() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction.ShortValueSumAgg
 
initializeBroadcastVariable(Iterable<T>) - Method in interface org.apache.flink.api.common.functions.BroadcastVariableInitializer
The method that reads the data elements from the broadcast variable and creates the transformed data structure.
initializeBroadcastVariable(Iterable<T>) - Method in class org.apache.flink.runtime.broadcast.DefaultBroadcastVariableInitializer
 
initializeBufferMetrics(Task) - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
Initialize Buffer Metrics for a task
initializeContextEnvironment(ExecutionEnvironmentFactory) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Sets a context environment factory, that creates the context environment for running programs with pre-configured environments.
initializeContextEnvironment(StreamExecutionEnvironmentFactory) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
 
initializeFields(T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
initializeGlobal(int) - Method in class org.apache.flink.api.common.io.FileOutputFormat
Initialization of the distributed file system if it is used.
initializeGlobal(int) - Method in interface org.apache.flink.api.common.io.InitializeOnMaster
The method is invoked on the master (JobManager) before the distributed program execution starts.
initializeIfNotInitialized(MemorySegmentFactory.Factory) - Static method in class org.apache.flink.core.memory.MemorySegmentFactory
Initializes this factory with the given concrete factory, iff it is not yet initialized.
initializeIOFormatClasses(Configuration) - Method in class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
InitializeOnMaster - Interface in org.apache.flink.api.common.io
This interface may be implemented by OutputFormats to have the master initialize them globally.
initializeOnMaster(ClassLoader) - Method in class org.apache.flink.runtime.jobgraph.InputFormatVertex
 
initializeOnMaster(ClassLoader) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
A hook that can be overwritten by sub classes to implement logic that is called by the master when the job starts.
initializeOnMaster(ClassLoader) - Method in class org.apache.flink.runtime.jobgraph.OutputFormatVertex
 
initializeSafetyNetForThread() - Static method in class org.apache.flink.core.fs.FileSystemSafetyNet
Activates the safety net for a thread.
initializeSerializerUnlessSet(ExecutionConfig) - Method in class org.apache.flink.api.common.state.StateDescriptor
Initializes the serializer, unless it has been initialized before.
initializeState(StateInitializationContext) - Method in class org.apache.flink.cep.operator.AbstractKeyedCEPPatternOperator
 
initializeState(FunctionInitializationContext) - Method in interface org.apache.flink.streaming.api.checkpoint.CheckpointedFunction
This method is called when the parallel function instance is created during distributed execution.
initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
 
initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
 
initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
 
initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
 
initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
 
initializeState(OperatorStateHandles) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
Stream operators with state which can be restored need to override this hook method.
initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
initializeState(OperatorStateHandles) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
Provides state handles to restore the operator state.
initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase
 
initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
 
initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
Deprecated.
 
initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
 
initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
 
initializeState(FunctionInitializationContext) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
 
initializeState(StateInitializationContext) - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
 
initializeSubscribedPartitionsToStartOffsets(List<KafkaTopicPartition>, int, int, StartupMode, Map<KafkaTopicPartition, Long>) - Static method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
initializeTypeComparatorBuilder(int) - Method in interface org.apache.flink.api.common.typeutils.CompositeType.TypeComparatorBuilder
 
initialPartitionBuffersCount - Variable in class org.apache.flink.runtime.operators.hash.ReOpenableHashPartition
 
initId(int) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
Sets the ID of this node.
initInputReaders() - Method in class org.apache.flink.runtime.operators.BatchTask
Creates the record readers for the number of inputs as defined by BatchTask.getNumTaskInputs().
initInputsSerializersAndComparators(int, int) - Method in class org.apache.flink.runtime.operators.BatchTask
Creates all the serializers and comparators.
initLocalStrategies(int) - Method in class org.apache.flink.runtime.operators.BatchTask
NOTE: This method must be invoked after the invocation of #initInputReaders() and #initInputSerializersAndComparators(int)!
initMax() - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator
 
initMax() - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator
 
initMax() - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator
 
initMax() - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator
 
initMax() - Method in class org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
 
initMax() - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
 
initMaxDepth() - Method in class org.apache.flink.optimizer.dag.DagConnection
 
initMin() - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator
 
initMin() - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator
 
initMin() - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator
 
initMin() - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator
 
initMin() - Method in class org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
 
initMin() - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
 
initOutPathDistFS(Path, FileSystem.WriteMode, boolean) - Method in class org.apache.flink.core.fs.FileSystem
Initializes output directories on distributed file systems according to the given write mode.
initOutPathDistFS(Path, FileSystem.WriteMode, boolean) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
initOutPathLocalFS(Path, FileSystem.WriteMode, boolean) - Method in class org.apache.flink.core.fs.FileSystem
Initializes output directories on local file systems according to the given write mode.
initOutPathLocalFS(Path, FileSystem.WriteMode, boolean) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
initOutputs() - Method in class org.apache.flink.runtime.iterative.task.IterationHeadTask
 
initOutputs() - Method in class org.apache.flink.runtime.operators.BatchTask
Creates a writer for each output.
initOutputs(AbstractInvokable, ClassLoader, TaskConfig, List<ChainedDriver<?, ?>>, List<RecordWriter<?>>, ExecutionConfig, Map<String, Accumulator<?, ?>>) - Static method in class org.apache.flink.runtime.operators.BatchTask
Creates a writer for each output.
initPrimitiveAggregator() - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.BooleanValueSummaryAggregator
 
initPrimitiveAggregator() - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.DoubleValueSummaryAggregator
 
initPrimitiveAggregator() - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.FloatValueSummaryAggregator
 
initPrimitiveAggregator() - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator
Initialize an aggregator that can be used for the underlying primitive in the Value type.
initPrimitiveAggregator() - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.IntegerValueSummaryAggregator
 
initPrimitiveAggregator() - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.LongValueSummaryAggregator
 
initPrimitiveAggregator() - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.ShortValueSummaryAggregator
 
initPrimitiveAggregator() - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.StringValueSummaryAggregator
 
initProperties(GlobalProperties, LocalProperties) - Method in class org.apache.flink.optimizer.plan.PlanNode
 
initStub(Class<? super S>) - Method in class org.apache.flink.runtime.operators.BatchTask
 
initSum() - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator
 
initSum() - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator
 
initSum() - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator
 
initSum() - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator
 
initSum() - Method in class org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
 
initSum() - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
 
initTable(int, byte) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
InitVerticesMapper(K) - Constructor for class org.apache.flink.graph.library.GSASingleSourceShortestPaths.InitVerticesMapper
 
InitVerticesMapper(K) - Constructor for class org.apache.flink.graph.library.SingleSourceShortestPaths.InitVerticesMapper
 
injectTableSourceConverter(String, Class<? extends TableSourceConverter<?>>) - Method in class org.apache.flink.table.catalog.ExternalTableSourceUtil$
 
injectTableSourceConverter(String, Class<? extends TableSourceConverter<?>>) - Static method in class org.apache.flink.table.catalog.ExternalTableSourceUtil
 
InMemoryExternalCatalog - Class in org.apache.flink.table.catalog
This class is an in-memory implementation of ExternalCatalog.
InMemoryExternalCatalog(String) - Constructor for class org.apache.flink.table.catalog.InMemoryExternalCatalog
 
InMemoryPartition<T> - Class in org.apache.flink.runtime.operators.hash
In-memory partition with overflow buckets for CompactingHashTable
InMemoryPartition(TypeSerializer<T>, int, ListMemorySegmentSource, int, int) - Constructor for class org.apache.flink.runtime.operators.hash.InMemoryPartition
Creates a new partition, in memory, with one buffer.
InMemorySorter<T> - Interface in org.apache.flink.runtime.operators.sort
 
InMemorySpout<T> - Class in org.apache.flink.storm.util
Implements a Spout that reads data stored in memory.
InMemorySpout(T[]) - Constructor for class org.apache.flink.storm.util.InMemorySpout
 
InnerClosureFinder - Class in org.apache.flink.api.scala
 
InnerClosureFinder(Set<Class<?>>) - Constructor for class org.apache.flink.api.scala.InnerClosureFinder
 
InnerJoinOperatorBase<IN1,IN2,OUT,FT extends FlatJoinFunction<IN1,IN2,OUT>> - Class in org.apache.flink.api.common.operators.base
 
InnerJoinOperatorBase(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.InnerJoinOperatorBase
 
InnerJoinOperatorBase(FT, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.InnerJoinOperatorBase
 
InnerJoinOperatorBase(Class<? extends FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.InnerJoinOperatorBase
 
InPlaceMutableHashTable<T> - Class in org.apache.flink.runtime.operators.hash
This hash table supports updating elements.
InPlaceMutableHashTable(TypeSerializer<T>, TypeComparator<T>, List<MemorySegment>) - Constructor for class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
 
InPlaceMutableHashTable.EntryIterator - Class in org.apache.flink.runtime.operators.hash
WARNING: Doing any other operation on the table invalidates the iterator! (Even using getMatchFor of a prober!)
InPlaceMutableHashTable.HashTableProber<PT> - Class in org.apache.flink.runtime.operators.hash
A prober for accessing the table.
InPlaceMutableHashTable.ReduceFacade - Class in org.apache.flink.runtime.operators.hash
A facade for doing such operations on the hash table that are needed for a reduce operator driver.
input - Variable in class org.apache.flink.api.common.operators.GenericDataSinkBase
 
input - Variable in class org.apache.flink.api.common.operators.SingleInputOperator
The input which produces the data consumed by this operator.
Input<K,VV,EV> - Interface in org.apache.flink.graph.drivers.input
Input source for a Graph, for example a file reader or GraphGenerator.
input - Variable in class org.apache.flink.optimizer.dag.DataSinkNode
 
input - Variable in class org.apache.flink.optimizer.plan.SingleInputPlanNode
 
input - Variable in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
input - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
input - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
input - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
 
input1 - Variable in class org.apache.flink.api.common.operators.DualInputOperator
The operator producing the first input.
input1 - Variable in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
 
input1 - Variable in class org.apache.flink.optimizer.dag.TwoInputNode
 
input1 - Variable in class org.apache.flink.optimizer.plan.DualInputPlanNode
 
input1Term() - Method in class org.apache.flink.table.codegen.CodeGenerator
 
input2 - Variable in class org.apache.flink.api.common.operators.DualInputOperator
The operator producing the second input.
input2 - Variable in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
 
input2 - Variable in class org.apache.flink.optimizer.dag.TwoInputNode
 
input2 - Variable in class org.apache.flink.optimizer.plan.DualInputPlanNode
 
input2Term() - Method in class org.apache.flink.table.codegen.CodeGenerator
 
INPUT_FILE_PATH - Static variable in class org.apache.flink.storm.util.FileSpout
 
INPUT_PAIRS - Static variable in class org.apache.flink.streaming.examples.iteration.util.IterateExampleData
 
InputChannel - Class in org.apache.flink.runtime.io.network.partition.consumer
An input channel consumes a single ResultSubpartitionView.
InputChannel(SingleInputGate, int, ResultPartitionID, int, int, Counter) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
 
InputChannel.BufferAndAvailability - Class in org.apache.flink.runtime.io.network.partition.consumer
A combination of a Buffer and a flag indicating availability of further buffers.
InputChannelDeploymentDescriptor - Class in org.apache.flink.runtime.deployment
Deployment descriptor for a single input channel instance.
InputChannelDeploymentDescriptor(ResultPartitionID, ResultPartitionLocation) - Constructor for class org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor
 
InputChannelID - Class in org.apache.flink.runtime.io.network.partition.consumer
 
InputChannelID() - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.InputChannelID
 
InputChannelID(long, long) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.InputChannelID
 
InputChannelID(AbstractID) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.InputChannelID
 
InputChannelStatus() - Constructor for class org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve.InputChannelStatus
 
inputComparators - Variable in class org.apache.flink.runtime.operators.BatchTask
The comparators for the central driver.
inputDataSet - Variable in class org.apache.flink.api.java.operators.Grouping
 
InputEndOfStreamException - Exception in org.apache.flink.runtime.checkpoint.decline
Exception indicating that a checkpoint was declined because one of the input stream reached its end before the alignment was complete.
InputEndOfStreamException() - Constructor for exception org.apache.flink.runtime.checkpoint.decline.InputEndOfStreamException
 
InputFormat<OT,T extends InputSplit> - Interface in org.apache.flink.api.common.io
The base interface for data sources that produces records.
InputFormatSourceFunction<OUT> - Class in org.apache.flink.streaming.api.functions.source
A SourceFunction that reads data using an InputFormat.
InputFormatSourceFunction(InputFormat<OUT, ?>, TypeInformation<OUT>) - Constructor for class org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
 
InputFormatVertex - Class in org.apache.flink.runtime.jobgraph
 
InputFormatVertex(String) - Constructor for class org.apache.flink.runtime.jobgraph.InputFormatVertex
 
InputFormatVertex(String, JobVertexID) - Constructor for class org.apache.flink.runtime.jobgraph.InputFormatVertex
 
InputFormatVertex(String, JobVertexID, List<JobVertexID>, List<OperatorID>, List<OperatorID>) - Constructor for class org.apache.flink.runtime.jobgraph.InputFormatVertex
 
inputGate - Variable in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
The input gate to read from.
inputGate - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
 
InputGate - Interface in org.apache.flink.runtime.io.network.partition.consumer
An input gate consumes one or more partitions of a single produced intermediate result.
InputGateDeploymentDescriptor - Class in org.apache.flink.runtime.deployment
Deployment descriptor for a single input gate instance.
InputGateDeploymentDescriptor(IntermediateDataSetID, ResultPartitionType, int, InputChannelDeploymentDescriptor[]) - Constructor for class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
 
InputGateListener - Interface in org.apache.flink.runtime.io.network.partition.consumer
Listener interface implemented by consumers of InputGate instances that want to be notified of availability of buffer or event instances.
InputGateMetrics - Class in org.apache.flink.runtime.io.network.partition.consumer
Collects metrics of an input gate.
InputGateUtil - Class in org.apache.flink.streaming.runtime.io
Utility for dealing with input gates.
inputIterators - Variable in class org.apache.flink.runtime.operators.BatchTask
The inputs reader, wrapped in an iterator.
InputMap() - Constructor for class org.apache.flink.streaming.examples.iteration.IterateExample.InputMap
 
inputReaders - Variable in class org.apache.flink.runtime.operators.BatchTask
The input readers of this task.
InputRefVisitor - Class in org.apache.flink.table.plan.util
An RexVisitor to extract all referenced input fields
InputRefVisitor() - Constructor for class org.apache.flink.table.plan.util.InputRefVisitor
 
InputRewriter - Class in org.apache.flink.table.plan.util
A RexShuttle to rewrite field accesses of a RexProgram.
InputRewriter(int[]) - Constructor for class org.apache.flink.table.plan.util.InputRewriter
 
inputs - Variable in class org.apache.flink.runtime.operators.BatchTask
The inputs to the operator.
inputSerializers - Variable in class org.apache.flink.runtime.operators.BatchTask
The serializers for the input data type.
InputSplit - Interface in org.apache.flink.core.io
This interface must be implemented by all kind of input splits that can be assigned to input formats.
InputSplitAssigner - Interface in org.apache.flink.core.io
An input split assigner distributes the InputSplits among the instances on which a data source exists.
InputSplitOpenThread(FileInputSplit, long) - Constructor for class org.apache.flink.api.common.io.FileInputFormat.InputSplitOpenThread
 
InputSplitProvider - Interface in org.apache.flink.runtime.jobgraph.tasks
An input split provider can be successively queried to provide a series of InputSplit objects a task is supposed to consume in the course of its execution.
InputSplitProviderException - Exception in org.apache.flink.runtime.jobgraph.tasks
 
InputSplitProviderException(String) - Constructor for exception org.apache.flink.runtime.jobgraph.tasks.InputSplitProviderException
 
InputSplitProviderException(String, Throwable) - Constructor for exception org.apache.flink.runtime.jobgraph.tasks.InputSplitProviderException
 
InputSplitProviderException(Throwable) - Constructor for exception org.apache.flink.runtime.jobgraph.tasks.InputSplitProviderException
 
InputSplitSource<T extends InputSplit> - Interface in org.apache.flink.core.io
InputSplitSources create InputSplits that define portions of data to be produced by InputFormats.
inputStream - Variable in class org.apache.flink.core.fs.FSDataInputStreamWrapper
 
inputStream1 - Variable in class org.apache.flink.streaming.api.datastream.ConnectedStreams
 
inputStream2 - Variable in class org.apache.flink.streaming.api.datastream.ConnectedStreams
 
InputStreamFSInputWrapper - Class in org.apache.flink.api.common.io
This class wraps an InputStream and exposes it as FSDataInputStream.
InputStreamFSInputWrapper(InputStream) - Constructor for class org.apache.flink.api.common.io.InputStreamFSInputWrapper
 
inputStreamStatus(StreamStatus, int) - Method in class org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve
Feed a StreamStatus into the valve.
inputType - Variable in class org.apache.flink.api.common.operators.UnaryOperatorInformation
Input Type of the operator
inputType1 - Variable in class org.apache.flink.api.common.operators.BinaryOperatorInformation
Input type of the first input
inputType2 - Variable in class org.apache.flink.api.common.operators.BinaryOperatorInformation
Input type of the second input
InputTypeConfigurable - Interface in org.apache.flink.api.java.typeutils
OutputFormats can implement this interface to be configured with the data type they will operate on.
InputTypeSpec - Interface in org.apache.flink.table.expressions
Expressions that have specification on its inputs.
inputView - Variable in class org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
 
InputViewIterator<E> - Class in org.apache.flink.runtime.io.disk
 
InputViewIterator(DataInputView, TypeSerializer<E>) - Constructor for class org.apache.flink.runtime.io.disk.InputViewIterator
 
inputWatermark(Watermark, int) - Method in class org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve
Feed a Watermark into the valve.
insert(Vector) - Method in class org.apache.flink.ml.nn.QuadTree
Recursively adds an object to the tree
insert(T) - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
 
insert(T) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
 
insert(T) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
Inserts the given record into the hash table.
insertAfterNoMatch(T) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.HashTableProber
This method can be called after getMatchFor returned null.
insertIntoBuildBuffer(BT) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
Inserts the given object into the current buffer.
insertIntoProbeBuffer(PT) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
Inserts the given record into the probe side buffers.
insertIntoTable(BT, int) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
insertOrReplace(BT) - Method in class org.apache.flink.api.common.operators.util.JoinHashMap
 
insertOrReplaceRecord(T) - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
 
insertOrReplaceRecord(T) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
Replaces record in hash table if record already present or append record if not.
insertOrReplaceRecord(T) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
Searches the hash table for a record with the given key.
install(SecurityUtils.SecurityConfiguration) - Method in class org.apache.flink.runtime.security.modules.HadoopModule
 
install(SecurityUtils.SecurityConfiguration) - Method in class org.apache.flink.runtime.security.modules.JaasModule
 
install(SecurityUtils.SecurityConfiguration) - Method in interface org.apache.flink.runtime.security.modules.SecurityModule
Install the security module.
install(SecurityUtils.SecurityConfiguration) - Method in class org.apache.flink.runtime.security.modules.ZooKeeperModule
 
install(SecurityUtils.SecurityConfiguration) - Static method in class org.apache.flink.runtime.security.SecurityUtils
Installs a process-wide security configuration.
install(SecurityUtils.SecurityConfiguration, Map<String, TestingSecurityContext.ClientSecurityConfiguration>) - Static method in class org.apache.flink.test.util.TestingSecurityContext
 
installAsShutdownHook(Logger) - Static method in class org.apache.flink.runtime.util.JvmShutdownSafeguard
Installs the safeguard shutdown hook.
installAsShutdownHook(Logger, long) - Static method in class org.apache.flink.runtime.util.JvmShutdownSafeguard
Installs the safeguard shutdown hook.
instance() - Static method in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Returns the standard operator table, creating it if necessary.
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.ByteSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.CharSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.DateSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.FloatSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.IntSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.LongSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.ShortSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.StringSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.common.typeutils.base.VoidSerializer
 
INSTANCE - Static variable in class org.apache.flink.api.java.tuple.Tuple0
An immutable reusable Tuple0 instance
INSTANCE - Static variable in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
INSTANCE - Static variable in class org.apache.flink.client.program.DetachedEnvironment.DetachedJobExecutionResult
 
INSTANCE - Static variable in class org.apache.flink.migration.MigrationNamespaceSerializerProxy
Deprecated.
 
INSTANCE - Static variable in class org.apache.flink.migration.runtime.checkpoint.savepoint.SavepointV0Serializer
 
INSTANCE - Static variable in class org.apache.flink.optimizer.util.NoOpUnaryUdfOp
 
instance() - Static method in class org.apache.flink.runtime.broadcast.DefaultBroadcastVariableInitializer
 
INSTANCE - Static variable in class org.apache.flink.runtime.checkpoint.RoundRobinOperatorStateRepartitioner
 
INSTANCE - Static variable in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
Instance - Class in org.apache.flink.runtime.instance
An instance represents a TaskManager registered at a JobManager and ready to receive work.
Instance(TaskManagerGateway, TaskManagerLocation, InstanceID, HardwareDescription, int) - Constructor for class org.apache.flink.runtime.instance.Instance
Constructs an instance reflecting a registered TaskManager.
INSTANCE - Static variable in class org.apache.flink.runtime.io.network.api.EndOfPartitionEvent
The singleton instance of this event
INSTANCE - Static variable in class org.apache.flink.runtime.io.network.api.EndOfSuperstepEvent
The singleton instance of this event
INSTANCE - Static variable in class org.apache.flink.runtime.io.network.buffer.FreeingBufferRecycler
 
instance() - Static method in class org.apache.flink.runtime.iterative.concurrent.BlockingBackChannelBroker
retrieve singleton instance
instance() - Static method in class org.apache.flink.runtime.iterative.concurrent.IterationAggregatorBroker
retrieve singleton instance
instance() - Static method in class org.apache.flink.runtime.iterative.concurrent.SolutionSetBroker
Retrieve the singleton instance.
instance() - Static method in class org.apache.flink.runtime.iterative.concurrent.SolutionSetUpdateBarrierBroker
 
instance() - Static method in class org.apache.flink.runtime.iterative.concurrent.SuperstepKickoffLatchBroker
 
INSTANCE - Static variable in class org.apache.flink.runtime.iterative.event.TerminationEvent
 
instance() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.TaskManagerInstance
 
INSTANCE - Static variable in class org.apache.flink.runtime.state.VoidNamespace
The singleton instance
INSTANCE - Static variable in class org.apache.flink.runtime.state.VoidNamespaceSerializer
 
INSTANCE - Static variable in class org.apache.flink.runtime.util.FatalExitExceptionHandler
 
INSTANCE - Static variable in class org.apache.flink.streaming.runtime.io.BlockingQueueBroker
Singleton instance.
INSTANCE() - Method in class org.apache.flink.table.plan.cost.FlinkDefaultRelMetadataProvider$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.cost.FlinkDefaultRelMetadataProvider
 
INSTANCE() - Method in class org.apache.flink.table.plan.nodes.datastream.AccModeTraitDef$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.nodes.datastream.AccModeTraitDef
 
INSTANCE() - Method in class org.apache.flink.table.plan.nodes.datastream.UpdateAsRetractionTraitDef$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.nodes.datastream.UpdateAsRetractionTraitDef
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.common.WindowStartEndPropertiesHavingRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.common.WindowStartEndPropertiesHavingRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.common.WindowStartEndPropertiesRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.common.WindowStartEndPropertiesRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.dataSet.BatchTableSourceScanRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.dataSet.BatchTableSourceScanRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateWithNullValuesRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateWithNullValuesRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetCalcRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetCalcRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetCorrelateRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetCorrelateRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetDistinctRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetDistinctRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetIntersectRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetIntersectRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetJoinRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetJoinRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetLogicalWindowAggregateRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetLogicalWindowAggregateRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetMinusRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetMinusRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetScanRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetScanRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetSingleRowJoinRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetSingleRowJoinRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetSortRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetSortRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetUnionRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetUnionRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetValuesRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetValuesRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetWindowAggregateRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetWindowAggregateRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamCalcRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamCalcRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamCorrelateRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamCorrelateRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupAggregateRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupAggregateRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupWindowAggregateRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupWindowAggregateRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamLogicalWindowAggregateRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamLogicalWindowAggregateRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamOverAggregateRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamOverAggregateRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamScanRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamScanRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamUnionRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamUnionRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamValuesRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamValuesRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.datastream.StreamTableSourceScanRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.datastream.StreamTableSourceScanRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.logical.EnumerableToLogicalTableScan$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.logical.EnumerableToLogicalTableScan
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.logical.LogicalUnnestRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.logical.LogicalUnnestRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.logical.PushFilterIntoTableSourceScanRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.logical.PushFilterIntoTableSourceScanRule
 
INSTANCE() - Method in class org.apache.flink.table.plan.rules.logical.PushProjectIntoTableSourceScanRule$
 
INSTANCE() - Static method in class org.apache.flink.table.plan.rules.logical.PushProjectIntoTableSourceScanRule
 
instanceCreationFailed() - Method in class org.apache.flink.api.scala.typeutils.CaseClassSerializer
 
instanceDied(Instance) - Method in interface org.apache.flink.runtime.instance.InstanceListener
Called when an instance died.
instanceDied(Instance) - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
InstanceDiedException - Exception in org.apache.flink.runtime.instance
A special instance signaling that an attempted operation on an instance is not possible, because the instance has died.
InstanceDiedException(Instance) - Constructor for exception org.apache.flink.runtime.instance.InstanceDiedException
 
InstanceID - Class in org.apache.flink.runtime.instance
Class for statistically unique instance IDs.
InstanceID() - Constructor for class org.apache.flink.runtime.instance.InstanceID
 
InstanceID(byte[]) - Constructor for class org.apache.flink.runtime.instance.InstanceID
 
instanceID() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RequestStackTrace
 
instanceID() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RequestTaskManagerInstance
 
instanceId() - Method in class org.apache.flink.runtime.messages.Messages.Disconnect
 
instanceID() - Method in class org.apache.flink.runtime.messages.RegistrationMessages.AcknowledgeRegistration
 
instanceID() - Method in class org.apache.flink.runtime.messages.RegistrationMessages.AlreadyRegistered
 
instanceID() - Method in class org.apache.flink.runtime.messages.TaskManagerMessages.Heartbeat
 
instanceID() - Method in class org.apache.flink.runtime.messages.TaskManagerMessages.StackTrace
 
InstanceListener - Interface in org.apache.flink.runtime.instance
Classes implementing the InstanceListener interface can be notified about the availability disappearance of instances.
InstanceManager - Class in org.apache.flink.runtime.instance
Simple manager that keeps track of which TaskManager are available and alive.
InstanceManager() - Constructor for class org.apache.flink.runtime.instance.InstanceManager
Creates an new instance manager.
instanceManager() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.dag.PartitionNode.PartitionDescriptor
 
instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.dag.SortPartitionNode.SortPartitionDescriptor
 
instantiate(OperatorDescriptorDual, Channel, Channel, List<Set<? extends NamedChannel>>, List<PlanNode>, CostEstimator, RequestedGlobalProperties, RequestedGlobalProperties, RequestedLocalProperties, RequestedLocalProperties) - Method in class org.apache.flink.optimizer.dag.TwoInputNode
 
instantiate(OperatorDescriptorDual, Channel, Channel, List<Set<? extends NamedChannel>>, List<PlanNode>, CostEstimator, RequestedGlobalProperties, RequestedGlobalProperties, RequestedLocalProperties, RequestedLocalProperties) - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
 
instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.AbstractSortMergeJoinDescriptor
 
instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.AllGroupCombineProperties
 
instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.AllGroupReduceProperties
 
instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.AllGroupWithPartialPreGroupProperties
 
instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.AllReduceProperties
 
instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.BinaryUnionOpDescriptor
 
instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.CartesianProductDescriptor
 
instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.CoGroupDescriptor
 
instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.CoGroupRawDescriptor
 
instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.CoGroupWithSolutionSetFirstDescriptor
 
instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.FilterDescriptor
 
instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.FlatMapDescriptor
 
instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.GroupCombineProperties
 
instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.GroupReduceProperties
 
instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.GroupReduceWithCombineProperties
 
instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.HashFullOuterJoinBuildFirstDescriptor
 
instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.HashFullOuterJoinBuildSecondDescriptor
 
instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.HashJoinBuildFirstProperties
 
instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.HashJoinBuildSecondProperties
 
instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.HashLeftOuterJoinBuildFirstDescriptor
 
instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.HashLeftOuterJoinBuildSecondDescriptor
 
instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.HashRightOuterJoinBuildFirstDescriptor
 
instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.HashRightOuterJoinBuildSecondDescriptor
 
instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.MapDescriptor
 
instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.MapPartitionDescriptor
 
instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.NoOpDescriptor
 
instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
 
instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorSingle
 
instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.PartialGroupProperties
 
instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.ReduceProperties
 
instantiate(Channel, SingleInputNode) - Method in class org.apache.flink.optimizer.operators.SolutionSetDeltaOperator
 
instantiate(Channel, Channel, TwoInputNode) - Method in class org.apache.flink.optimizer.operators.UtilSinkJoinOpDescriptor
 
instantiate(Class<T>, Class<? super T>) - Static method in class org.apache.flink.util.InstantiationUtil
Creates a new instance of the given class.
instantiate(Class<T>) - Static method in class org.apache.flink.util.InstantiationUtil
Creates a new instance of the given class.
instantiateCandidate(OperatorDescriptorSingle, Channel, List<Set<? extends NamedChannel>>, List<PlanNode>, CostEstimator, RequestedGlobalProperties, RequestedLocalProperties) - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
 
instantiateCandidate(OperatorDescriptorSingle, Channel, List<Set<? extends NamedChannel>>, List<PlanNode>, CostEstimator, RequestedGlobalProperties, RequestedLocalProperties) - Method in class org.apache.flink.optimizer.dag.SingleInputNode
 
instantiateDeserializationUtils() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
instantiateJobContext(JobConf, JobID) - Static method in class org.apache.flink.api.java.hadoop.mapred.utils.HadoopUtils
 
instantiateJobContext(Configuration, JobID) - Static method in class org.apache.flink.api.java.hadoop.mapreduce.utils.HadoopUtils
 
instantiateMetrics(TaskIOMetricGroup) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
Instantiates all metrics.
instantiateMetrics(TaskIOMetricGroup) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
 
instantiateNetworkMetrics(MetricGroup, NetworkEnvironment) - Static method in class org.apache.flink.runtime.metrics.util.MetricUtils
 
instantiateStatusMetrics(MetricGroup) - Static method in class org.apache.flink.runtime.metrics.util.MetricUtils
 
instantiateStatusMetrics(MetricGroup, NetworkEnvironment) - Static method in class org.apache.flink.runtime.taskexecutor.utils.TaskExecutorMetricsInitializer
 
instantiateTaskAttemptContext(JobConf, TaskAttemptID) - Static method in class org.apache.flink.api.java.hadoop.mapred.utils.HadoopUtils
 
instantiateTaskAttemptContext(Configuration, TaskAttemptID) - Static method in class org.apache.flink.api.java.hadoop.mapreduce.utils.HadoopUtils
 
instantiateUserCode(TaskConfig, ClassLoader, Class<? super T>) - Static method in class org.apache.flink.runtime.operators.BatchTask
Instantiates a user code class from is definition in the task configuration.
InstantiationUtil - Class in org.apache.flink.util
Utility class to create instances from class objects and checking failure reasons.
InstantiationUtil.ClassLoaderObjectInputStream - Class in org.apache.flink.util
A custom ObjectInputStream that can load classes using a specific ClassLoader.
INT - Static variable in class org.apache.flink.api.common.typeinfo.Types
 
INT() - Method in class org.apache.flink.table.api.Types$
 
INT() - Static method in class org.apache.flink.table.api.Types
 
INT() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
INT() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
int2Literal(int) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionConversions
 
INT_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
INT_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
INT_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
INT_VALUE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
 
INT_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
IntArrayList - Class in org.apache.flink.runtime.util
Minimal implementation of an array-backed list of ints
IntArrayList(int) - Constructor for class org.apache.flink.runtime.util.IntArrayList
 
IntAvgAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Int Avg aggregate function
IntAvgAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.IntAvgAggFunction
 
IntComparator - Class in org.apache.flink.api.common.typeutils.base
 
IntComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.IntComparator
 
intComparator() - Method in class org.apache.flink.api.scala.typeutils.EnumValueComparator
 
IntCounter - Class in org.apache.flink.api.common.accumulators
An accumulator that sums up Integer values.
IntCounter() - Constructor for class org.apache.flink.api.common.accumulators.IntCounter
 
IntCounter(int) - Constructor for class org.apache.flink.api.common.accumulators.IntCounter
 
IntegerSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
Aggregator that can handle Integer types
IntegerSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator
 
IntegerSummaryAggregator.MaxIntegerAggregator - Class in org.apache.flink.api.java.summarize.aggregation
 
IntegerSummaryAggregator.MinIntegerAggregator - Class in org.apache.flink.api.java.summarize.aggregation
 
IntegerSummaryAggregator.SumIntegerAggregator - Class in org.apache.flink.api.java.summarize.aggregation
 
IntegerTypeInfo<T> - Class in org.apache.flink.api.common.typeinfo
Type information for numeric integer primitive types: int, long, byte, short, character.
IntegerTypeInfo(Class<T>, Class<?>[], TypeSerializer<T>, Class<? extends TypeComparator<T>>) - Constructor for class org.apache.flink.api.common.typeinfo.IntegerTypeInfo
 
IntegerValueSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.IntegerValueSummaryAggregator
 
IntegralAvgAccumulator - Class in org.apache.flink.table.functions.aggfunctions
The initial accumulator for Integral Avg aggregate function
IntegralAvgAccumulator() - Constructor for class org.apache.flink.table.functions.aggfunctions.IntegralAvgAccumulator
 
IntegralAvgAggFunction<T> - Class in org.apache.flink.table.functions.aggfunctions
Base class for built-in Integral Avg aggregate function
IntegralAvgAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.IntegralAvgAggFunction
 
intercept() - Method in class org.apache.flink.ml.common.WeightVector
 
InterestingProperties - Class in org.apache.flink.optimizer.dataproperties
Interesting properties are propagated from parent operators to child operators.
InterestingProperties() - Constructor for class org.apache.flink.optimizer.dataproperties.InterestingProperties
 
InterestingPropertyVisitor - Class in org.apache.flink.optimizer.traversals
Visitor that computes the interesting properties for each node in the optimizer DAG.
InterestingPropertyVisitor(CostEstimator) - Constructor for class org.apache.flink.optimizer.traversals.InterestingPropertyVisitor
Creates a new visitor that computes the interesting properties for all nodes in the plan.
IntermediateDataSet - Class in org.apache.flink.runtime.jobgraph
An intermediate data set is the data set produced by an operator - either a source or any intermediate operation.
IntermediateDataSet(IntermediateDataSetID, ResultPartitionType, JobVertex) - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateDataSet
 
IntermediateDataSetID - Class in org.apache.flink.runtime.jobgraph
 
IntermediateDataSetID() - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateDataSetID
Creates an new random intermediate data set ID.
IntermediateDataSetID(AbstractID) - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateDataSetID
Creates a new intermediate data set ID with the bytes of the given ID.
IntermediateDataSetID(UUID) - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateDataSetID
Creates a new intermediate data set ID with the bytes of the given UUID.
intermediateDataSetId() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RequestPartitionProducerState
 
IntermediateResult - Class in org.apache.flink.runtime.executiongraph
 
IntermediateResult(IntermediateDataSetID, ExecutionJobVertex, int, ResultPartitionType) - Constructor for class org.apache.flink.runtime.executiongraph.IntermediateResult
 
IntermediateResultPartition - Class in org.apache.flink.runtime.executiongraph
 
IntermediateResultPartition(IntermediateResult, ExecutionVertex, int) - Constructor for class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
 
IntermediateResultPartitionID - Class in org.apache.flink.runtime.jobgraph
 
IntermediateResultPartitionID() - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateResultPartitionID
Creates an new random intermediate result partition ID.
IntermediateResultPartitionID(long, long) - Constructor for class org.apache.flink.runtime.jobgraph.IntermediateResultPartitionID
 
intermediateRow() - Method in class org.apache.flink.table.runtime.aggregate.DataSetSlideTimeWindowAggReduceGroupFunction
 
intermediateRowType() - Method in class org.apache.flink.table.runtime.aggregate.DataSetSessionWindowAggregatePreProcessor
 
IntermediateSampleData<T> - Class in org.apache.flink.api.java.sampling
The data structure which is transferred between partitions and the coordinator for distributed random sampling.
IntermediateSampleData(double, T) - Constructor for class org.apache.flink.api.java.sampling.IntermediateSampleData
 
Internal - Annotation Type in org.apache.flink.annotation
Interface to mark methods within stable, public APIs as an internal developer API.
InternalAggregateProcessAllWindowFunction<T,ACC,V,R,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
Internal window function for wrapping a ProcessAllWindowFunction that takes an Iterable and an AggregateFunction.
InternalAggregateProcessAllWindowFunction(AggregateFunction<T, ACC, V>, ProcessAllWindowFunction<V, R, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
 
InternalAggregateProcessWindowFunction<T,ACC,V,R,K,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
Internal window function for wrapping a ProcessWindowFunction that takes an Iterable and an AggregateFunction.
InternalAggregateProcessWindowFunction(AggregateFunction<T, ACC, V>, ProcessWindowFunction<V, R, K, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
 
InternalAggregatingState<N,IN,OUT> - Interface in org.apache.flink.runtime.state.internal
The peer to the AggregatingState in the internal state type hierarchy.
InternalAppendingState<N,IN,OUT> - Interface in org.apache.flink.runtime.state.internal
The peer to the AppendingState in the internal state type hierarchy.
InternalFoldingState<N,T,ACC> - Interface in org.apache.flink.runtime.state.internal
Deprecated.
will be removed in a future version
internalHandleException(IOException) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
Internally handles an exception and makes sure that this method returns without a problem.
InternalIterableAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
Internal window function for wrapping an AllWindowFunction that takes an Iterable when the window state also is an Iterable.
InternalIterableAllWindowFunction(AllWindowFunction<IN, OUT, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
 
InternalIterableProcessAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
Internal window function for wrapping a ProcessAllWindowFunction that takes an Iterable when the window state also is an Iterable.
InternalIterableProcessAllWindowFunction(ProcessAllWindowFunction<IN, OUT, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
 
InternalIterableProcessWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
Internal window function for wrapping a ProcessWindowFunction that takes an Iterable when the window state also is an Iterable.
InternalIterableProcessWindowFunction(ProcessWindowFunction<IN, OUT, KEY, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
 
InternalIterableWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
Internal window function for wrapping a WindowFunction that takes an Iterable when the window state also is an Iterable.
InternalIterableWindowFunction(WindowFunction<IN, OUT, KEY, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
 
InternalKeyContext<K> - Interface in org.apache.flink.runtime.state.heap
This interface is the current context of a keyed state.
InternalKvState<N> - Interface in org.apache.flink.runtime.state.internal
The InternalKvState is the root of the internal state type hierarchy, similar to the State being the root of the public API state hierarchy.
InternalListState<N,T> - Interface in org.apache.flink.runtime.state.internal
The peer to the ListState in the internal state type hierarchy.
InternalMapState<N,UK,UV> - Interface in org.apache.flink.runtime.state.internal
The peer to the MapState in the internal state type hierarchy.
InternalMergingState<N,IN,OUT> - Interface in org.apache.flink.runtime.state.internal
The peer to the MergingState in the internal state type hierarchy.
InternalProcessAllWindowContext<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
Internal reusable context wrapper.
InternalProcessApplyAllWindowContext<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
Internal reusable context wrapper.
InternalProcessApplyWindowContext<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
Internal reusable context wrapper.
InternalProcessWindowContext<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
Internal reusable context wrapper.
InternalReducingState<N,T> - Interface in org.apache.flink.runtime.state.internal
The peer to the ReducingState in the internal state type hierarchy.
InternalSingleValueAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
Internal window function for wrapping an AllWindowFunction that takes an Iterable when the window state is a single value.
InternalSingleValueAllWindowFunction(AllWindowFunction<IN, OUT, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
 
InternalSingleValueProcessAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
Internal window function for wrapping a ProcessAllWindowFunction that takes an Iterable when the window state is a single value.
InternalSingleValueProcessAllWindowFunction(ProcessAllWindowFunction<IN, OUT, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
 
InternalSingleValueProcessWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
Internal window function for wrapping a ProcessWindowFunction that takes an Iterable when the window state is a single value.
InternalSingleValueProcessWindowFunction(ProcessWindowFunction<IN, OUT, KEY, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
 
InternalSingleValueWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing.functions
Internal window function for wrapping a WindowFunction that takes an Iterable when the window state is a single value.
InternalSingleValueWindowFunction(WindowFunction<IN, OUT, KEY, W>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
 
InternalTimer<K,N> - Class in org.apache.flink.streaming.api.operators
Internal class for keeping track of in-flight timers.
InternalTimer(long, K, N) - Constructor for class org.apache.flink.streaming.api.operators.InternalTimer
 
InternalTimer.TimerSerializer<K,N> - Class in org.apache.flink.streaming.api.operators
A TypeSerializer used to serialize/deserialize a InternalTimer.
InternalTimerService<N> - Interface in org.apache.flink.streaming.api.operators
Interface for working with time and timers.
internalTimerService - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
internalToTimePointCode(TypeInformation<?>, String) - Method in class org.apache.flink.table.codegen.CodeGenUtils$
 
internalToTimePointCode(TypeInformation<?>, String) - Static method in class org.apache.flink.table.codegen.CodeGenUtils
 
InternalTypeInfo<T> - Class in org.apache.flink.table.typeutils
TypeInformation for internal types of the Table API that are for translation purposes only and should not be contained in final plan.
InternalTypeInfo(Class<T>) - Constructor for class org.apache.flink.table.typeutils.InternalTypeInfo
 
InternalValueState<N,T> - Interface in org.apache.flink.runtime.state.internal
The peer to the ValueState in the internal state type hierarchy.
InternalWindowFunction<IN,OUT,KEY,W extends Window> - Interface in org.apache.flink.streaming.runtime.operators.windowing.functions
Internal interface for functions that are evaluated over keyed (grouped) windows.
InternalWindowFunction.InternalWindowContext - Interface in org.apache.flink.streaming.runtime.operators.windowing.functions
A context for InternalWindowFunction, similar to ProcessWindowFunction.Context but for internal use.
INTERSECT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
intersect(Graph<K, VV, EV>, boolean) - Method in class org.apache.flink.graph.Graph
Performs intersect on the edge sets of the input graphs.
intersect(Graph<K, VV, EV>, boolean) - Method in class org.apache.flink.graph.scala.Graph
Performs intersect on the edge sets of the input graphs.
intersect(Table) - Method in class org.apache.flink.table.api.Table
Intersects two Tables with duplicate records removed.
intersect(boolean) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
intersect(boolean, int) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
Intersect - Class in org.apache.flink.table.plan.logical
 
Intersect(LogicalNode, LogicalNode, boolean) - Constructor for class org.apache.flink.table.plan.logical.Intersect
 
Intersect$ - Class in org.apache.flink.table.plan.logical
 
Intersect$() - Constructor for class org.apache.flink.table.plan.logical.Intersect$
 
INTERSECT_ALL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
intersectAll(Table) - Method in class org.apache.flink.table.api.Table
Intersects two Tables.
IntersectCoGroupFunction<T> - Class in org.apache.flink.table.runtime
 
IntersectCoGroupFunction(boolean) - Constructor for class org.apache.flink.table.runtime.IntersectCoGroupFunction
 
intersects(TimeWindow) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
Returns true if this window intersects the given window.
INTERVAL_MILLIS() - Method in class org.apache.flink.table.api.Types$
 
INTERVAL_MILLIS() - Static method in class org.apache.flink.table.api.Types
 
INTERVAL_MILLIS() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
INTERVAL_MILLIS() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
INTERVAL_MILLIS() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo$
 
INTERVAL_MILLIS() - Static method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
 
INTERVAL_MONTHS() - Method in class org.apache.flink.table.api.Types$
 
INTERVAL_MONTHS() - Static method in class org.apache.flink.table.api.Types
 
INTERVAL_MONTHS() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
INTERVAL_MONTHS() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
INTERVAL_MONTHS() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo$
 
INTERVAL_MONTHS() - Static method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
 
INTERVAL_ROWS() - Method in class org.apache.flink.table.typeutils.RowIntervalTypeInfo$
 
INTERVAL_ROWS() - Static method in class org.apache.flink.table.typeutils.RowIntervalTypeInfo
 
IntExplodeTableFunc - Class in org.apache.flink.table.plan.util
 
IntExplodeTableFunc() - Constructor for class org.apache.flink.table.plan.util.IntExplodeTableFunc
 
IntMaxAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Int Max aggregate function
IntMaxAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.IntMaxAggFunction
 
IntMaximum - Class in org.apache.flink.api.common.accumulators
An accumulator that finds the maximum integer value.
IntMaximum() - Constructor for class org.apache.flink.api.common.accumulators.IntMaximum
 
IntMaximum(int) - Constructor for class org.apache.flink.api.common.accumulators.IntMaximum
 
IntMaxWithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Int Max with retraction aggregate function
IntMaxWithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.IntMaxWithRetractAggFunction
 
IntMinAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Int Min aggregate function
IntMinAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.IntMinAggFunction
 
IntMinimum - Class in org.apache.flink.api.common.accumulators
An accumulator that finds the minimum integer value.
IntMinimum() - Constructor for class org.apache.flink.api.common.accumulators.IntMinimum
 
IntMinimum(int) - Constructor for class org.apache.flink.api.common.accumulators.IntMinimum
 
IntMinWithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Int Min with retraction aggregate function
IntMinWithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.IntMinWithRetractAggFunction
 
IntParser - Class in org.apache.flink.types.parser
Parses a decimal text field into a IntValue.
IntParser() - Constructor for class org.apache.flink.types.parser.IntParser
 
IntPrimitiveArrayComparator - Class in org.apache.flink.api.common.typeutils.base.array
 
IntPrimitiveArrayComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArrayComparator
 
IntPrimitiveArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
A serializer for int arrays.
IntPrimitiveArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
IntSerializer - Class in org.apache.flink.api.common.typeutils.base
 
IntSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.IntSerializer
 
intSerializer() - Method in class org.apache.flink.api.scala.typeutils.EnumValueSerializer
 
IntSerializer() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.IntSerializer
 
IntSum0AggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Int Sum0 aggregate function
IntSum0AggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.IntSum0AggFunction
 
IntSum0WithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Int Sum0 with retract aggregate function
IntSum0WithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.IntSum0WithRetractAggFunction
 
IntSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.IntSumAgg
 
IntSumAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Int Sum aggregate function
IntSumAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.IntSumAggFunction
 
IntSumWithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Int Sum with retract aggregate function
IntSumWithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.IntSumWithRetractAggFunction
 
IntValue - Class in org.apache.flink.types
Boxed serializable and comparable integer type, representing the primitive type int.
IntValue() - Constructor for class org.apache.flink.types.IntValue
Initializes the encapsulated int with 0.
IntValue(int) - Constructor for class org.apache.flink.types.IntValue
Initializes the encapsulated int with the provided value.
IntValueArray - Class in org.apache.flink.graph.types.valuearray
An array of IntValue.
IntValueArray() - Constructor for class org.apache.flink.graph.types.valuearray.IntValueArray
Initializes an expandable array with default capacity.
IntValueArray(int) - Constructor for class org.apache.flink.graph.types.valuearray.IntValueArray
Initializes a fixed-size array with the provided number of bytes.
IntValueArrayComparator - Class in org.apache.flink.graph.types.valuearray
Specialized comparator for IntValueArray based on CopyableValueComparator.
IntValueArrayComparator(boolean) - Constructor for class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
 
IntValueArraySerializer - Class in org.apache.flink.graph.types.valuearray
Specialized serializer for IntValueArray.
IntValueArraySerializer() - Constructor for class org.apache.flink.graph.types.valuearray.IntValueArraySerializer
 
IntValueComparator - Class in org.apache.flink.api.common.typeutils.base
Specialized comparator for IntValue based on CopyableValueComparator.
IntValueComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
IntValueParser - Class in org.apache.flink.types.parser
Parses a decimal text field into a IntValue.
IntValueParser() - Constructor for class org.apache.flink.types.parser.IntValueParser
 
IntValueSerializer - Class in org.apache.flink.api.common.typeutils.base
 
IntValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
IntValueSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.IntValueSumAgg
 
InvalidateMessenger(Edge<Long, Double>) - Constructor for class org.apache.flink.graph.examples.IncrementalSSSP.InvalidateMessenger
 
InvalidFieldReferenceException(String) - Constructor for exception org.apache.flink.api.common.typeutils.CompositeType.InvalidFieldReferenceException
 
invalidLineCount - Variable in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
InvalidProgramException - Exception in org.apache.flink.api.common
An exception thrown to indicate that the composed program is invalid.
InvalidProgramException() - Constructor for exception org.apache.flink.api.common.InvalidProgramException
Creates a new exception with no message.
InvalidProgramException(String) - Constructor for exception org.apache.flink.api.common.InvalidProgramException
Creates a new exception with the given message.
InvalidProgramException(String, Throwable) - Constructor for exception org.apache.flink.api.common.InvalidProgramException
Creates a new exception with the given message and cause.
InvalidSemanticAnnotationException(String) - Constructor for exception org.apache.flink.api.common.operators.SemanticProperties.InvalidSemanticAnnotationException
 
InvalidSemanticAnnotationException(String, Throwable) - Constructor for exception org.apache.flink.api.common.operators.SemanticProperties.InvalidSemanticAnnotationException
 
InvalidTypesException - Exception in org.apache.flink.api.common.functions
A special case of the InvalidProgramException, indicating that the types used in an operation are invalid or inconsistent.
InvalidTypesException() - Constructor for exception org.apache.flink.api.common.functions.InvalidTypesException
Creates a new exception with no message.
InvalidTypesException(String) - Constructor for exception org.apache.flink.api.common.functions.InvalidTypesException
Creates a new exception with the given message.
InvalidTypesException(String, Throwable) - Constructor for exception org.apache.flink.api.common.functions.InvalidTypesException
 
InvalidVertexIdsValidator<K,VV,EV> - Class in org.apache.flink.graph.validation
 
InvalidVertexIdsValidator() - Constructor for class org.apache.flink.graph.validation.InvalidVertexIdsValidator
 
invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Flag whether normalized key comparisons should be inverted key should be interpreted inverted, i.e.
invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.scala.typeutils.EnumValueComparator
 
invertNormalizedKey() - Method in class org.apache.flink.api.scala.typeutils.OptionTypeComparator
 
invertNormalizedKey() - Method in class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
 
invertNormalizedKey() - Method in class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
 
invertNormalizedKey() - Method in class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
 
invertNormalizedKey() - Method in class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
 
invertNormalizedKey() - Method in class org.apache.flink.table.runtime.types.CRowComparator
 
invertNormKey - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
inView - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
inView - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
invoke() - Method in class org.apache.flink.runtime.iterative.task.IterationSynchronizationSinkTask
 
invoke() - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
Starts the execution.
invoke() - Method in class org.apache.flink.runtime.operators.BatchTask
The main work method.
invoke() - Method in class org.apache.flink.runtime.operators.DataSinkTask
 
invoke() - Method in class org.apache.flink.runtime.operators.DataSourceTask
 
invoke(T) - Method in class org.apache.flink.streaming.api.functions.sink.DiscardingSink
 
invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
 
invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
 
invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.RichSinkFunction
 
invoke(IN) - Method in interface org.apache.flink.streaming.api.functions.sink.SinkFunction
Function for standard sink behaviour.
invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.SocketClientSink
Called when new data arrives to the sink, and forwards it to Socket.
invoke(IN) - Method in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
Implementation of the invoke method of the SinkFunction class.
invoke(IN) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSinkBase
 
invoke(T) - Method in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase
 
invoke(T) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
 
invoke(T) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
Deprecated.
 
invoke(T) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
Invoke method for using the Sink as DataStream.addSink() sink.
invoke(IN) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
Called when new data arrives to the sink, and forwards it to Kafka.
invoke(T) - Method in class org.apache.flink.streaming.connectors.nifi.NiFiSink
 
invoke(IN) - Method in class org.apache.flink.streaming.connectors.rabbitmq.RMQSink
Called when new data arrives to the sink, and forwards it to RMQ.
invoke() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
invokeInteractiveModeForExecution() - Method in class org.apache.flink.client.program.PackagedProgram
This method assumes that the context environment is prepared, or the execution will be a local execution by default.
invokeRegistration(Gateway, UUID, long) - Method in class org.apache.flink.runtime.registration.RetryingRegistration
 
InvScaling(double) - Constructor for class org.apache.flink.ml.optimization.LearningRateMethod.InvScaling
 
InvScaling$() - Constructor for class org.apache.flink.ml.optimization.LearningRateMethod.InvScaling$
 
io() - Method in class org.apache.flink.table.plan.cost.DataSetCost
 
IO_NUM_BYTES_IN - Static variable in class org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_BYTES_IN_LOCAL - Static variable in class org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_BYTES_IN_LOCAL_RATE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_BYTES_IN_REMOTE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_BYTES_IN_REMOTE_RATE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_BYTES_OUT - Static variable in class org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_BYTES_OUT_RATE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_RECORDS_IN - Static variable in class org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_RECORDS_IN_RATE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_RECORDS_OUT - Static variable in class org.apache.flink.runtime.metrics.MetricNames
 
IO_NUM_RECORDS_OUT_RATE - Static variable in class org.apache.flink.runtime.metrics.MetricNames
 
ioBuffer() - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
 
ioBuffer(int) - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
 
ioBuffer(int, int) - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
 
ioExecutor() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
ioExecutor() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
ioManager() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
IOManager - Class in org.apache.flink.runtime.io.disk.iomanager
The facade for the provided I/O manager services.
IOManager(String[]) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.IOManager
Constructs a new IOManager.
ioManager - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
The I/O manager used to instantiate writers for the spilled partitions.
ioManager - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 
ioManager() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
 
ioManager() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
IOManager.IOMode - Enum in org.apache.flink.runtime.io.disk.iomanager
 
IOManagerAsync - Class in org.apache.flink.runtime.io.disk.iomanager
A version of the IOManager that uses asynchronous I/O.
IOManagerAsync() - Constructor for class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
Constructs a new asynchronous I/O manger, writing files to the system 's temp directory.
IOManagerAsync(String) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
Constructs a new asynchronous I/O manger, writing file to the given directory.
IOManagerAsync(String[]) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
Constructs a new asynchronous I/O manger, writing file round robin across the given directories.
IOMetrics - Class in org.apache.flink.runtime.executiongraph
An instance of this class represents a snapshot of the io-related metrics of a single task.
IOMetrics(Meter, Meter, Meter, Meter, Meter) - Constructor for class org.apache.flink.runtime.executiongraph.IOMetrics
 
IOMetrics(int, int, int, int, int, double, double, double, double, double) - Constructor for class org.apache.flink.runtime.executiongraph.IOMetrics
 
ioMode() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
IOReadableWritable - Interface in org.apache.flink.core.io
This interface must be implemented by every class whose objects have to be serialized to their binary representation and vice-versa.
IOReadableWritableSerializer - Class in org.apache.flink.runtime.akka.serialization
 
IOReadableWritableSerializer() - Constructor for class org.apache.flink.runtime.akka.serialization.IOReadableWritableSerializer
 
IOUtils - Class in org.apache.flink.util
An utility class for I/O related functionality.
ipAddressAndPortToUrlString(InetAddress, int) - Static method in class org.apache.flink.util.NetUtils
Encodes an IP address and port to be included in URL.
ipAddressToUrlString(InetAddress) - Static method in class org.apache.flink.util.NetUtils
Encodes an IP address properly as a URL string.
IS_A_SET - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
IS_DIFFERENT_FROM - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The internal $IS_DIFFERENT_FROM operator is the same as the user-level SqlStdOperatorTable.IS_DISTINCT_FROM in all respects except that the test for equality on character datatypes treats trailing spaces as significant.
IS_DISTINCT_FROM - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
IS DISTINCT FROM operator.
IS_FALSE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
IS_NOT_DISTINCT_FROM - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
IS NOT DISTINCT FROM operator.
IS_NOT_FALSE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
IS_NOT_NULL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
IS_NOT_TRUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
IS_NOT_UNKNOWN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
IS_NULL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
IS_TRUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
IS_UNKNOWN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
isAbsolute() - Method in class org.apache.flink.core.fs.Path
Checks if the directory of this path is absolute.
isAccRetract(RelNode) - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamRetractionRules$
Checks if a RelNode is in AccMode.AccRetract mode.
isAccRetract(RelNode) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamRetractionRules
Checks if a RelNode is in AccMode.AccRetract mode.
isActive(CommandLine, Configuration) - Method in interface org.apache.flink.client.cli.CustomCommandLine
Signals whether the custom command-line wants to execute or not
isActive(CommandLine, Configuration) - Method in class org.apache.flink.client.cli.DefaultCLI
 
isActive(JobID, AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
 
isActive() - Method in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
isActive(CommandLine, Configuration) - Method in class org.apache.flink.yarn.cli.FlinkYarnCLI
 
isActive(CommandLine, Configuration) - Method in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
 
isAdvanced(TypeInformation<?>) - Method in class org.apache.flink.table.typeutils.TypeCheckUtils$
Checks if type information is an advanced type that can be converted to a SQL type but NOT vice versa.
isAdvanced(TypeInformation<?>) - Static method in class org.apache.flink.table.typeutils.TypeCheckUtils
Checks if type information is an advanced type that can be converted to a SQL type but NOT vice versa.
isAggregator() - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
isAggregator() - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
isAggregator() - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
isAggregator() - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
isAlive() - Method in class org.apache.flink.runtime.instance.Instance
 
isAlive() - Method in class org.apache.flink.runtime.instance.Slot
Checks of the slot is still alive, i.e.
isAllocated() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
isAllocated(JobID, AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
 
isAllocated(int, JobID, AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Check whether the slot for the given index is allocated for the given job and allocation id.
isAppendOnly(RelNode) - Method in class org.apache.flink.table.api.StreamTableEnvironment
Validates that the plan produces only append changes.
isArchived() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns whether this execution graph was archived.
isArchived() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
isArchived() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
isArray(TypeInformation<?>) - Method in class org.apache.flink.table.typeutils.TypeCheckUtils$
 
isArray(TypeInformation<?>) - Static method in class org.apache.flink.table.typeutils.TypeCheckUtils
 
isAssigned() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
Checks whether the location of this constraint has been assigned.
isAssigned() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
isAssignedAndAlive() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
Checks whether the location of this constraint has been assigned (as defined in the CoLocationConstraint.isAssigned() method, and the current shared slot is alive.
isAutomaticRecovery() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig
Returns true if automatic connection recovery is enabled, false otherwise
isAutoTypeRegistrationDisabled() - Method in class org.apache.flink.api.common.ExecutionConfig
 
isBasicType() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
Checks if this type information represents a basic type.
isBasicType() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.java.typeutils.ListTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
isBasicType() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.scala.typeutils.EitherTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.scala.typeutils.EnumValueTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.scala.typeutils.OptionTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.scala.typeutils.ScalaNothingTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.scala.typeutils.TraversableTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.scala.typeutils.TryTypeInfo
 
isBasicType() - Method in class org.apache.flink.api.scala.typeutils.UnitTypeInfo
 
isBasicType() - Method in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
 
isBasicType() - Method in class org.apache.flink.table.runtime.types.CRowTypeInfo
 
isBasicType() - Method in class org.apache.flink.table.typeutils.InternalTypeInfo
 
isBasicType() - Static method in class org.apache.flink.table.typeutils.RowIntervalTypeInfo
 
isBasicType() - Static method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
 
isBasicType() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
 
isBasicValueType() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
isBlocking() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
 
isBoolean(TypeInformation<?>) - Method in class org.apache.flink.table.typeutils.TypeCheckUtils$
 
isBoolean(TypeInformation<?>) - Static method in class org.apache.flink.table.typeutils.TypeCheckUtils
 
isBotEdit() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
 
isBounded() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
Whether this partition uses a limited number of (network) buffers or not.
isBranching() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
Checks whether this node has branching output.
isBreakingPipeline() - Method in class org.apache.flink.optimizer.dag.DagConnection
Checks whether this connection is marked to break the pipeline.
isBuffer() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileSegment
 
isBuffer() - Method in class org.apache.flink.runtime.io.network.buffer.Buffer
 
isBuffer() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
isBufferConsumed() - Method in enum org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer.DeserializationResult
 
isCached() - Method in enum org.apache.flink.optimizer.dag.TempMode
 
isCallByValue() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
isCanceled() - Method in class org.apache.flink.runtime.instance.Slot
Checks of the slot has been cancelled.
isCanceled() - Method in class org.apache.flink.runtime.registration.RetryingRegistration
Checks if the registration was canceled.
isCanceled() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
isCanceledOrFailed() - Method in class org.apache.flink.runtime.taskmanager.Task
Checks whether the task has failed, is canceled, or is being canceled at the moment.
isCanceledOrStopped() - Method in class org.apache.flink.streaming.api.operators.StreamSource
Checks whether the source has been canceled or stopped.
isCancelled() - Method in class org.apache.flink.runtime.state.DoneFuture
 
isCaseClass() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
isCaseClass() - Method in class org.apache.flink.api.scala.typeutils.CaseClassTypeInfo
 
isCastableToDefinedType(String) - Method in class org.apache.flink.api.java.utils.Option
 
isChainable(StreamEdge, StreamGraph) - Static method in class org.apache.flink.streaming.api.graph.StreamingJobGraphGenerator
 
isChainEnd() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
isChainingEnabled - Variable in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
 
isChainingEnabled() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Returns whether operator chaining is enabled.
isChainingEnabled() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
isChainStart() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
isCheckpointCommitted(int, long) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraCommitter
 
isCheckpointCommitted(int, long) - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
Checked the resource whether the given checkpoint was committed completely.
isCheckpointingEnabled() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
Checks whether checkpointing is enabled.
isCheckpointingEnabled() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
isCheckpointingEnabled() - Method in class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
Returns true if checkpointing is enabled for the running job.
isClassType(Type) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils
Checks if a type can be converted to a Class.
isCleanupTime(W, long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
Returns true if the given time is the cleanup time for the given window.
isClientConnected() - Method in class org.apache.flink.runtime.client.JobClientActor
 
isClosed() - Method in class org.apache.flink.core.fs.ClosingFSDataInputStream
 
isClosed() - Method in class org.apache.flink.core.fs.ClosingFSDataOutputStream
 
isClosed() - Method in class org.apache.flink.migration.runtime.state.AbstractCloseableHandle
Deprecated.
Checks whether this handle has been closed.
isClosed() - Method in class org.apache.flink.runtime.blob.BlobClient
 
isClosed() - Method in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
 
isClosed() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
 
isClosed() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
 
isClosed() - Method in interface org.apache.flink.runtime.io.disk.iomanager.FileIOChannel
Checks whether the channel has been closed.
isClosed() - Method in class org.apache.flink.runtime.io.disk.iomanager.RequestQueue
Checks whether this request queue is closed.
isClosed() - Method in class org.apache.flink.runtime.io.disk.iomanager.SynchronousFileIOChannel
 
isClosed() - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
isClosed() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
 
isClosed() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
Checks whether the stream is closed.
isClosed() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
 
isClosed() - Method in class org.apache.flink.util.AbstractCloseableRegistry
 
isClosed() - Method in class org.apache.flink.yarn.highavailability.YarnHighAvailabilityServices
Checks whether these services have been shut down.
isClosureCleanerEnabled() - Method in class org.apache.flink.api.common.ExecutionConfig
Returns whether the ClosureCleaner is enabled.
isCollected() - Method in class org.apache.flink.table.runtime.TableFunctionCollector
Whether collect(T) has been called.
isCollectionExecution() - Method in class org.apache.flink.test.util.JavaProgramTestBase
 
isCollector() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
isCombinable() - Method in class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
Checks whether the operation is combinable.
isCombinable() - Method in class org.apache.flink.api.java.operators.GroupReduceOperator
 
isCombinableFirst() - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
isCombinableFirst() - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
 
isCombinableSecond() - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
isCombinableSecond() - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
 
isCombineable() - Method in class org.apache.flink.optimizer.dag.GroupReduceNode
Checks, whether a combiner function has been given for the function encapsulated by this reduce contract.
isCompacted() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
 
isComparable(TypeInformation<?>) - Method in class org.apache.flink.table.typeutils.TypeCheckUtils$
 
isComparable(TypeInformation<?>) - Static method in class org.apache.flink.table.typeutils.TypeCheckUtils
 
isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
 
isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
 
isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
 
isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
 
isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
 
isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
 
isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
 
isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
 
isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton
Subclasses can override this if they know that they are also compatible with identifiers of other formats.
isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.graph.types.valuearray.IntValueArraySerializer
 
isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.graph.types.valuearray.LongValueArraySerializer
 
isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.graph.types.valuearray.StringValueArraySerializer
 
isCompatibleSerializationFormatIdentifier(String) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
 
isCompatibleWith(DeweyNumber) - Method in class org.apache.flink.cep.nfa.DeweyNumber
Checks whether this dewey number is compatible to the other dewey number.
isCompleted() - Method in enum org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
Returns whether the checkpoint has completed successfully.
isComputablyPartitioned() - Method in enum org.apache.flink.optimizer.dataproperties.PartitioningProperty
Checks, if this property represents a partitioning that is computable.
isConnected() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
isConnected() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
 
isConnected() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
Checks whether the TaskManager is currently connected to the JobManager.
isConnected() - Method in class org.apache.flink.yarn.ApplicationClient
True if the ApplicationClient is connected to the YarnJobManager
isConnected() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
isConsumable() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResultPartition
 
isContainer() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
isContributors_enabled() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
isConverged(int, T) - Method in interface org.apache.flink.api.common.aggregators.ConvergenceCriterion
Decide whether the iterative algorithm has converged
isConverged(int, DoubleValue) - Method in class org.apache.flink.api.common.aggregators.DoubleZeroConvergence
Returns true, if the aggregator value is zero, false otherwise.
isConverged(int, LongValue) - Method in class org.apache.flink.api.common.aggregators.LongZeroConvergence
Returns true, if the aggregator value is zero, false otherwise.
isConverged(int, LongValue) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregationConvergence
 
isConverged(int, LongValue) - Method in class org.apache.flink.runtime.iterative.convergence.WorksetEmptyConvergenceCriterion
 
isConvertTableAccess() - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
Returns the convertTableAccess option.
isCreateValuesRel() - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
Returns the createValuesRel option.
isDataSet(int) - Method in class org.apache.flink.python.api.util.SetCache
Checks whether the cached set for the given ID is a DataSet.
isDecimal(TypeInformation<?>) - Method in class org.apache.flink.table.typeutils.TypeCheckUtils$
 
isDecimal(TypeInformation<?>) - Static method in class org.apache.flink.table.typeutils.TypeCheckUtils
 
isDecorrelationEnabled() - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
Returns the decorrelationEnabled option.
isDefault_profile() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
isDefault_profile_image() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
isDefaultOverwriteFiles() - Method in class org.apache.flink.client.LocalExecutor
 
isDestroyed() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
Checks whether this buffer pool has been destroyed.
isDestroyed() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
Returns whether the buffer provider has been destroyed.
isDestroyed() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
isDetached() - Method in class org.apache.flink.client.program.ClusterClient
A flag to indicate whether this clients submits jobs detached.
isDetached() - Method in class org.apache.flink.yarn.YarnClusterClient
 
isDetached() - Method in class org.apache.flink.yarn.YarnClusterClientV2
 
isDetachedMode() - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
 
isDeterministic() - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
isDeterministic() - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
isDeterministic() - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
isDeterministic() - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
isDir() - Method in interface org.apache.flink.core.fs.FileStatus
Checks if this object represents a directory.
isDir() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
 
isDir() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileStatus
 
isDirectBufferPooled() - Method in class org.apache.flink.runtime.io.network.netty.NettyBufferPool
 
isDiscarded() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
Returns whether the checkpoint has been discarded.
isDiscarded() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
isDispose() - Method in class org.apache.flink.client.cli.SavepointOptions
 
isDisposed() - Method in class org.apache.flink.runtime.util.AtomicDisposableReferenceCounter
Returns whether the reference count has reached the disposed state.
isDistinct() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
isDistinct() - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
isDistinct() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
isDistinct() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
isDistinct() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
isDistinct() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
isDistinct() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
isDistinct() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
isDistinct() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
isDistinct() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
isDistinct() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
isDistinct() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
isDistinct() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
isDistinct() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
isDistinct() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
isDistinct() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
isDistributedFS() - Method in class org.apache.flink.core.fs.FileSystem
Returns true if this is a distributed file system.
isDistributedFS() - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
isDistributedFS() - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
isDistributedFS() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
 
isDistributedFS() - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
 
isDone() - Method in interface org.apache.flink.runtime.concurrent.Future
Checks if the future has been completed.
isDone() - Method in class org.apache.flink.runtime.concurrent.impl.FlinkFuture
 
isDone() - Method in class org.apache.flink.runtime.state.DoneFuture
 
isDone() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
True if the stream element queue entry has been completed; otherwise false.
isDummy() - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
isDynamicFunction() - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
isDynamicFunction() - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
isDynamicFunction() - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
isDynamicFunction() - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
isDynamicStruct() - Static method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
isElementLate(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
Decide if a record is currently late, based on current watermark and allowed lateness.
isEmpty() - Method in class org.apache.flink.api.common.operators.Keys
 
isEmpty() - Method in class org.apache.flink.cep.nfa.NFA
Check if the NFA has finished processing all incoming data so far.
isEmpty() - Method in class org.apache.flink.cep.nfa.SharedBuffer
 
isEmpty() - Method in class org.apache.flink.migration.streaming.runtime.tasks.StreamTaskState
Deprecated.
Checks if this state object actually contains any state, or if all of the state fields are null.
isEmpty() - Method in class org.apache.flink.migration.streaming.runtime.tasks.StreamTaskStateList
Deprecated.
 
isEmpty() - Method in class org.apache.flink.runtime.jobmaster.SerializedInputSplit
 
isEmpty() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
Checks whether the buffer is empty.
isEmpty() - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
Checks whether the buffer is empty.
isEmpty() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
Checks whether the buffer is empty.
isEmpty() - Method in class org.apache.flink.runtime.state.ChainedStateHandle
Check if there are any states handles present.
isEmpty() - Method in class org.apache.flink.runtime.state.heap.StateTable
Returns whether this NestedMapsStateTable is empty.
isEmpty() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
 
isEmpty() - Method in class org.apache.flink.runtime.util.EvictingBoundedList
 
isEmpty() - Method in class org.apache.flink.runtime.util.IntArrayList
 
isEmpty() - Method in class org.apache.flink.runtime.util.LongArrayList
 
isEmpty() - Method in class org.apache.flink.runtime.util.LRUCache
 
isEmpty() - Method in class org.apache.flink.runtime.util.LRUCacheMap
 
isEmpty() - Method in class org.apache.flink.storm.util.StormConfig
 
isEmpty() - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
 
isEmpty() - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
True if the queue is empty; otherwise false.
isEmpty() - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
 
isEmpty() - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
Checks whether the queue is empty (has no elements).
isEmpty() - Method in class org.apache.flink.streaming.runtime.io.BarrierBuffer
 
isEmpty() - Method in class org.apache.flink.streaming.runtime.io.BarrierTracker
 
isEmpty() - Method in interface org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
Checks if the barrier handler has buffered any data internally.
isEmpty() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
Checks whether the map is empty.
isEmpty() - Method in class org.apache.flink.types.ListValue
 
isEmpty() - Method in class org.apache.flink.types.MapValue
 
isEncodeForHTML() - Method in class org.apache.flink.optimizer.plandump.PlanJSONDumpGenerator
 
isEndOfStream(T) - Method in class org.apache.flink.streaming.util.serialization.AbstractDeserializationSchema
Method to decide whether the element signals the end of the stream.
isEndOfStream(T) - Method in interface org.apache.flink.streaming.util.serialization.DeserializationSchema
Method to decide whether the element signals the end of the stream.
isEndOfStream(ObjectNode) - Method in class org.apache.flink.streaming.util.serialization.JSONDeserializationSchema
 
isEndOfStream(ObjectNode) - Method in class org.apache.flink.streaming.util.serialization.JSONKeyValueDeserializationSchema
 
isEndOfStream(Row) - Method in class org.apache.flink.streaming.util.serialization.JsonRowDeserializationSchema
 
isEndOfStream(T) - Method in interface org.apache.flink.streaming.util.serialization.KeyedDeserializationSchema
Method to decide whether the element signals the end of the stream.
isEndOfStream(T) - Method in class org.apache.flink.streaming.util.serialization.KeyedDeserializationSchemaWrapper
 
isEndOfStream(String) - Method in class org.apache.flink.streaming.util.serialization.SimpleStringSchema
 
isEndOfStream(Tuple2<K, V>) - Method in class org.apache.flink.streaming.util.serialization.TypeInformationKeyValueSerializationSchema
This schema never considers an element to signal end-of-stream, so this method returns always false.
isEndOfStream(T) - Method in class org.apache.flink.streaming.util.serialization.TypeInformationSerializationSchema
This schema never considers an element to signal end-of-stream, so this method returns always false.
isEndOfSuperstep() - Method in class org.apache.flink.runtime.iterative.task.SyncEventHandler
 
isEqualTo(Function1<R, K>, TypeInformation<K>) - Method in class org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions.OnHalfUnfinishedKeyPairOperation
Initiates a join or co-group operation, defining the second half of the where clause with an equality over the right data set items.
isEqWithEpsilon(RelOptCost) - Method in class org.apache.flink.table.plan.cost.DataSetCost
 
isEvent(Buffer, Class<?>, ClassLoader) - Static method in class org.apache.flink.runtime.io.network.api.serialization.EventSerializer
Identifies whether the given buffer encodes the given event.
isEvent() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.BaseAlignedWindowAssigner
 
isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
 
isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
 
isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
 
isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
 
isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
 
isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
 
isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
 
isEventTime() - Method in class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
Returns true if elements are assigned to windows based on event time, false otherwise.
isEventTime() - Method in class org.apache.flink.table.plan.schema.TimeIndicatorRelDataType
 
isEventTime() - Method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
 
isExactlyOnce() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
isExactlyPartitionedOnFields(FieldList) - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
 
isExactMatch(FieldList) - Method in class org.apache.flink.api.common.operators.util.FieldList
 
isExecutable - Variable in class org.apache.flink.api.common.cache.DistributedCache.DistributedCacheEntry
 
isExpand() - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
Returns the expand option.
isExplain() - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
Returns the explain option.
isExternalized() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
isExternalizedCheckpointsEnabled() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
Returns whether checkpoints should be persisted externally.
isExtremal(Comparable<R>, R) - Method in class org.apache.flink.streaming.api.functions.aggregation.Comparator
 
isFailed() - Method in enum org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
Returns whether the checkpoint has failed.
isFailure() - Static method in class org.apache.flink.table.validate.ValidationFailure
 
isFailure() - Method in interface org.apache.flink.table.validate.ValidationResult
 
isFailure() - Static method in class org.apache.flink.table.validate.ValidationSuccess
 
isFalse() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Returns true if given boolean expression is false.
IsFalse - Class in org.apache.flink.table.expressions
 
IsFalse(Expression) - Constructor for class org.apache.flink.table.expressions.IsFalse
 
IsFalse$ - Class in org.apache.flink.table.expressions
 
IsFalse$() - Constructor for class org.apache.flink.table.expressions.IsFalse$
 
isFastAccumulating() - Method in enum org.apache.flink.streaming.api.datastream.LegacyWindowOperatorType
 
isFastAggregating() - Method in enum org.apache.flink.streaming.api.datastream.LegacyWindowOperatorType
 
isFavorited() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
isFieldPrimitive(Field) - Method in class org.apache.flink.table.codegen.CodeGenUtils$
 
isFieldPrimitive(Field) - Static method in class org.apache.flink.table.codegen.CodeGenUtils
 
isFilterPushedDown() - Method in interface org.apache.flink.table.sources.FilterableTableSource
Return the flag to indicate whether filter push down has been tried.
isFinal() - Method in class org.apache.flink.cep.nfa.State
 
isFinalState() - Method in class org.apache.flink.cep.nfa.ComputationState
 
isFinished() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
isFinished() - Method in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
 
isFinished() - Method in interface org.apache.flink.runtime.io.network.api.reader.ReaderBase
Returns whether the reader has consumed the input.
isFinished() - Method in interface org.apache.flink.runtime.io.network.partition.consumer.InputGate
 
isFinished() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
isFinished() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
 
isFire() - Method in enum org.apache.flink.streaming.api.windowing.triggers.TriggerResult
 
isFlinkSupportedScheme(String) - Static method in class org.apache.flink.core.fs.FileSystem
Returns a boolean indicating whether a scheme has built-in Flink support.
isFollow_request_sent() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
isFollowing() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
isForceAvroEnabled() - Method in class org.apache.flink.api.common.ExecutionConfig
 
isForceCheckpointing() - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
Deprecated.
This will be removed once iterations properly participate in checkpointing.
isForceCheckpointing() - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Deprecated.
Forcing checkpoints will be removed in future version.
isForceKryoEnabled() - Method in class org.apache.flink.api.common.ExecutionConfig
 
isFree() - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
isFree() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
 
isFreeBSD() - Static method in enum org.apache.flink.util.OperatingSystem
Checks whether the operating system this JVM runs on is FreeBSD.
isFreed() - Method in class org.apache.flink.core.memory.MemorySegment
Checks whether the memory segment was freed.
isFull() - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
 
isFull() - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
 
isFull() - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
 
isFull() - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
 
isFull() - Method in interface org.apache.flink.graph.types.valuearray.ValueArray
An bounded array fills when the allocated capacity has been fully used.
isFullBuffer() - Method in enum org.apache.flink.runtime.io.network.api.serialization.RecordSerializer.SerializationResult
Whether the target buffer is full after the serialization process.
isFullRecord() - Method in enum org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer.DeserializationResult
 
isFullRecord() - Method in enum org.apache.flink.runtime.io.network.api.serialization.RecordSerializer.SerializationResult
Whether the full record was serialized and completely written to a target buffer.
isFullyAcknowledged() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
isFullyReplicated() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
 
isGeo_enabled() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
isGloballyTerminalState() - Method in enum org.apache.flink.runtime.jobgraph.JobStatus
Checks whether this state is globally terminal.
isGroup() - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
isGroup() - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
isGroup() - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
isGroup() - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
isGroupAuxiliary() - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
isGroupAuxiliary() - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
isGroupAuxiliary() - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
isGroupAuxiliary() - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
isGrouped() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
isGuaranteed() - Static method in class org.apache.flink.table.plan.rules.dataSet.BatchTableSourceScanRule
 
isGuaranteed() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateRule
 
isGuaranteed() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateWithNullValuesRule
 
isGuaranteed() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetCalcRule
 
isGuaranteed() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetCorrelateRule
 
isGuaranteed() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetDistinctRule
 
isGuaranteed() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetIntersectRule
 
isGuaranteed() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetJoinRule
 
isGuaranteed() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetMinusRule
 
isGuaranteed() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetScanRule
 
isGuaranteed() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetSingleRowJoinRule
 
isGuaranteed() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetSortRule
 
isGuaranteed() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetUnionRule
 
isGuaranteed() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetValuesRule
 
isGuaranteed() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetWindowAggregateRule
 
isGuaranteed() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamCalcRule
 
isGuaranteed() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamCorrelateRule
 
isGuaranteed() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupAggregateRule
 
isGuaranteed() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupWindowAggregateRule
 
isGuaranteed() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamOverAggregateRule
 
isGuaranteed() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamScanRule
 
isGuaranteed() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamUnionRule
 
isGuaranteed() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamValuesRule
 
isGuaranteed() - Static method in class org.apache.flink.table.plan.rules.datastream.StreamTableSourceScanRule
 
isHighAvailabilityModeActivated(Configuration) - Static method in enum org.apache.flink.runtime.jobmanager.HighAvailabilityMode
Returns true if the defined recovery mode supports high availability.
isHomogeneous(boolean) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
isHomogeneous(boolean) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
isHomogeneous(boolean) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
isIdle() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
isIdle() - Method in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
isIdReference() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
 
isImmediateSolutionSetUpdate() - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.TypeDeserializerAdapter
 
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
Gets whether the type is an immutable type.
isImmutableType() - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
 
isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
isImmutableType() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
 
isImmutableType() - Method in class org.apache.flink.api.scala.typeutils.EitherSerializer
 
isImmutableType() - Method in class org.apache.flink.api.scala.typeutils.EnumValueSerializer
 
isImmutableType() - Method in class org.apache.flink.api.scala.typeutils.NothingSerializer
 
isImmutableType() - Method in class org.apache.flink.api.scala.typeutils.OptionSerializer
 
isImmutableType() - Method in class org.apache.flink.api.scala.typeutils.TraversableSerializer
 
isImmutableType() - Method in class org.apache.flink.api.scala.typeutils.TrySerializer
 
isImmutableType() - Method in class org.apache.flink.api.scala.typeutils.UnitSerializer
 
isImmutableType() - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
 
isImmutableType() - Method in class org.apache.flink.cep.nfa.NFA.NFASerializer
 
isImmutableType() - Method in class org.apache.flink.cep.nfa.NFA.Serializer
 
isImmutableType() - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
 
isImmutableType() - Method in class org.apache.flink.cep.NonDuplicatingTypeSerializer
 
isImmutableType() - Method in class org.apache.flink.graph.types.valuearray.IntValueArraySerializer
 
isImmutableType() - Method in class org.apache.flink.graph.types.valuearray.LongValueArraySerializer
 
isImmutableType() - Method in class org.apache.flink.graph.types.valuearray.NullValueArraySerializer
 
isImmutableType() - Method in class org.apache.flink.graph.types.valuearray.StringValueArraySerializer
 
isImmutableType() - Method in class org.apache.flink.migration.MigrationNamespaceSerializerProxy
Deprecated.
 
isImmutableType() - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer
 
isImmutableType() - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.StreamRecordSerializer
 
isImmutableType() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
isImmutableType() - Method in class org.apache.flink.runtime.state.HashMapSerializer
 
isImmutableType() - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
 
isImmutableType() - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
 
isImmutableType() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
 
isImmutableType() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
isImmutableType() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
isImmutableType() - Method in class org.apache.flink.table.runtime.types.CRowSerializer
 
isInfinite(Double) - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator
 
isInfinite(Float) - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator
 
isInfinite(Integer) - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator
 
isInfinite(Long) - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator
 
isInfinite(T) - Method in class org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
 
isInfinite(Short) - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
 
isInfinite() - Method in class org.apache.flink.table.plan.cost.DataSetCost
 
isInitialized() - Static method in class org.apache.flink.core.memory.MemorySegmentFactory
Checks whether this memory segment factory has been initialized (with a type to produce).
isInMemory() - Method in class org.apache.flink.runtime.operators.hash.HashPartition
Checks whether this partition is in memory or spilled.
isInProgress() - Method in enum org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
Returns whether the checkpoint is in progress.
isInput() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
isInput1Iterable() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
isInput1Iterator() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
isInputAsynchronouslyMaterialized(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
isInputCached(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
isInputIterable() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
isInputIterator() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
isInputResettable(int) - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
 
isInputResettable(int) - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
 
isInputResettable(int) - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
 
isInputResettable(int) - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
 
isInputResettable(int) - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
 
isInputResettable(int) - Method in interface org.apache.flink.runtime.operators.ResettableDriver
 
isInputVertex() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
isInSSSP(Edge<Long, Double>, DataSet<Edge<Long, Double>>) - Static method in class org.apache.flink.graph.examples.IncrementalSSSP
Function that verifies whether the edge to be removed is part of the SSSP or not.
isIntConstant() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
isInteger(TypeInformation<?>) - Method in class org.apache.flink.table.typeutils.TypeCheckUtils$
 
isInteger(TypeInformation<?>) - Static method in class org.apache.flink.table.typeutils.TypeCheckUtils
 
isIs_translator() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
isIterative() - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
isIterativeInputGate(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
isIteratorTrueAssumption() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
isIteratorTrueAssumptionApplied() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
isJobExecutionResult() - Method in class org.apache.flink.api.common.JobSubmissionResult
Checks if this JobSubmissionResult is also a JobExecutionResult.
isJvmFatalError(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
Checks whether the given exception indicates a situation that may leave the JVM in a corrupted state, meaning a state where continued normal operation can only be guaranteed via clean process restart.
isJvmFatalOrOutOfMemoryError(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
Checks whether the given exception indicates a situation that may leave the JVM in a corrupted state, or an out-of-memory error.
isKey(ImmutableBitSet) - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
isKey(ImmutableBitSet) - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
isKey(ImmutableBitSet) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
isKey(ImmutableBitSet) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
isKey(ImmutableBitSet) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
isKey(ImmutableBitSet) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
isKey(ImmutableBitSet) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
isKey(ImmutableBitSet) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
isKey(ImmutableBitSet) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
isKey(ImmutableBitSet) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
isKey(ImmutableBitSet) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
isKey(ImmutableBitSet) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
isKey(ImmutableBitSet) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
isKey(ImmutableBitSet) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
isKey(ImmutableBitSet) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
isKey(ImmutableBitSet) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
isKey(ImmutableBitSet) - Method in class org.apache.flink.table.plan.stats.FlinkStatistic
 
isKeyGroupAlreadyFinished(int) - Method in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
Returns true if the key group is already completely written and immutable.
isKeyGroupAlreadyStarted(int) - Method in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
Returns true, if the key group with the given id was already started.
isKeyType() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
Checks whether this type can be used as a key.
isKeyType() - Method in class org.apache.flink.api.common.typeutils.CompositeType
 
isKeyType() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.java.typeutils.ListTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.scala.typeutils.EitherTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.scala.typeutils.EnumValueTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.scala.typeutils.OptionTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.scala.typeutils.ScalaNothingTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.scala.typeutils.TraversableTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.scala.typeutils.TryTypeInfo
 
isKeyType() - Method in class org.apache.flink.api.scala.typeutils.UnitTypeInfo
 
isKeyType() - Method in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
 
isKeyType() - Static method in class org.apache.flink.table.runtime.types.CRowTypeInfo
 
isKeyType() - Method in class org.apache.flink.table.typeutils.InternalTypeInfo
 
isKeyType() - Static method in class org.apache.flink.table.typeutils.RowIntervalTypeInfo
 
isKeyType() - Static method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
 
isKeyType() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
 
isLatencyMarker() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
Checks whether this element is a record.
isLatencyTrackingEnabled() - Method in class org.apache.flink.api.common.ExecutionConfig
Returns if latency tracking is enabled
isLe(RelOptCost) - Method in class org.apache.flink.table.plan.cost.DataSetCost
 
isLeader() - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
 
isLeft() - Method in class org.apache.flink.types.Either
 
isLenient() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
isLinux() - Static method in enum org.apache.flink.util.OperatingSystem
Checks whether the operating system this JVM runs on is Linux.
isLoaded() - Method in class org.apache.flink.client.program.ClusterClient.LazyActorSystemLoader
Indicates whether the ActorSystem has already been instantiated.
isLocal() - Method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
 
isLong(TypeInformation<?>) - Method in class org.apache.flink.table.typeutils.TypeCheckUtils$
 
isLong(TypeInformation<?>) - Static method in class org.apache.flink.table.typeutils.TypeCheckUtils
 
isLt(RelOptCost) - Method in class org.apache.flink.table.plan.cost.DataSetCost
 
isMac() - Static method in enum org.apache.flink.util.OperatingSystem
Checks whether the operating system this JVM runs on is Windows.
isMatching(ResourceProfile) - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
Check whether required resource profile can be matched
isMatchingRequirement(ResourceProfile) - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
Check whether required resource profile can be matched by this slot.
isMaterializing() - Method in enum org.apache.flink.runtime.operators.DamBehavior
Checks whether this enumeration represents some form of materialization, either with a full dam or without.
isMaterializing() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
 
isMaxParallelismConfigured() - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
isMetBy(Ordering) - Method in class org.apache.flink.api.common.operators.Ordering
 
isMetBy(GlobalProperties) - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
Checks, if this set of interesting properties, is met by the given produced properties.
isMetBy(LocalProperties) - Method in class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
Checks, if this set of properties, as interesting properties, is met by the given properties.
isMinor() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
 
isMutable() - Method in class org.apache.flink.table.catalog.ExternalCatalogSchema
 
isName(String) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
isName(String) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
isName(String) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
isName(String) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
isNan(Double) - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator
 
isNan(Float) - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator
 
isNan(Integer) - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator
 
isNan(Long) - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator
 
isNan(T) - Method in class org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
 
isNan(Short) - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
 
isNear(Vector, double) - Method in class org.apache.flink.ml.nn.QuadTree.Node
Tests if queryPoint is near a node
isNetworkStrategy() - Method in enum org.apache.flink.runtime.operators.shipping.ShipStrategyType
 
isNew() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
 
isNonStaticInnerClass(Class<?>) - Static method in class org.apache.flink.util.InstantiationUtil
Checks, whether the class is an inner class that is not statically accessible.
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.BigDecComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.BigIntComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.BooleanComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.ByteComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.CharComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.DateComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.DoubleComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.EnumComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.FloatComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.IntComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.LongComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.ShortComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Checks, whether the given number of bytes for a normalized is only a prefix to determine the order of elements of the data type for which this comparator provides the comparison methods.
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.scala.typeutils.EnumValueComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.api.scala.typeutils.OptionTypeComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
 
isNormalizedKeyPrefixOnly(int) - Method in class org.apache.flink.table.runtime.types.CRowComparator
 
isNotFalse() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Returns true if given boolean expression is not false (for null and true).
IsNotFalse - Class in org.apache.flink.table.expressions
 
IsNotFalse(Expression) - Constructor for class org.apache.flink.table.expressions.IsNotFalse
 
IsNotFalse$ - Class in org.apache.flink.table.expressions
 
IsNotFalse$() - Constructor for class org.apache.flink.table.expressions.IsNotFalse$
 
isNotifications() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
isNotNull() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Returns true if the given expression is not null.
isNotNull(RexNode) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
IsNotNull - Class in org.apache.flink.table.expressions
 
IsNotNull(Expression) - Constructor for class org.apache.flink.table.expressions.IsNotNull
 
IsNotNull$ - Class in org.apache.flink.table.expressions
 
IsNotNull$() - Constructor for class org.apache.flink.table.expressions.IsNotNull$
 
isNotTrue() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Returns true if given boolean expression is not true (for null and false).
IsNotTrue - Class in org.apache.flink.table.expressions
 
IsNotTrue(Expression) - Constructor for class org.apache.flink.table.expressions.IsNotTrue
 
IsNotTrue$ - Class in org.apache.flink.table.expressions
 
IsNotTrue$() - Constructor for class org.apache.flink.table.expressions.IsNotTrue$
 
isNull() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
isNull() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Returns true if the given expression is null.
isNull(RexNode) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
IsNull - Class in org.apache.flink.table.expressions
 
IsNull(Expression) - Constructor for class org.apache.flink.table.expressions.IsNull
 
isNull(int) - Method in class org.apache.flink.types.Record
 
IsNull$ - Class in org.apache.flink.table.expressions
 
IsNull$() - Constructor for class org.apache.flink.table.expressions.IsNull$
 
isNullable() - Method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
isNullOrEmpty(ChainedStateHandle<?>) - Static method in class org.apache.flink.runtime.state.ChainedStateHandle
 
isNullOrEmpty(Collection<?>) - Static method in class org.apache.flink.util.CollectionUtil
 
isNullOrEmpty(Map<?, ?>) - Static method in class org.apache.flink.util.CollectionUtil
 
isNullOrWhitespaceOnly(String) - Static method in class org.apache.flink.util.StringUtils
Checks if the string is null, empty, or contains only whitespace characters.
isNumeric(TypeInformation<?>) - Method in class org.apache.flink.table.typeutils.TypeCheckUtils$
 
isNumeric(TypeInformation<?>) - Static method in class org.apache.flink.table.typeutils.TypeCheckUtils
 
isObjectReuseEnabled() - Method in class org.apache.flink.api.common.ExecutionConfig
Returns whether object reuse has been enabled or disabled.
isOffHeap() - Method in class org.apache.flink.core.memory.MemorySegment
Checks whether this memory segment is backed by off-heap memory.
isOffsetDefined() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionState
 
isOldSavepointKeyedState(Collection<KeyedStateHandle>) - Static method in class org.apache.flink.migration.MigrationUtil
 
isOnDynamicPath() - Method in class org.apache.flink.optimizer.dag.AbstractPartialSolutionNode
 
isOnDynamicPath() - Method in class org.apache.flink.optimizer.dag.DagConnection
 
isOnDynamicPath() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
isOnDynamicPath() - Method in class org.apache.flink.optimizer.plan.Channel
 
isOnDynamicPath() - Method in class org.apache.flink.optimizer.plan.PlanNode
 
isOne() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
 
isOpen() - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
Checks whether the queue is currently open, meaning elements can be added and polled.
isOptDegrees() - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
Gets whether the degrees option is set.
isOptNumVertices() - Method in class org.apache.flink.graph.IterationConfiguration
Gets whether the number of vertices option is set.
isOrdered(SqlNode) - Static method in class org.apache.calcite.sql2rel.SqlToRelConverter
 
isOrdered() - Method in enum org.apache.flink.api.common.operators.Order
Checks, if this enum constant represents in fact an order.
isOrderEqualOnFirstNFields(Ordering, int) - Method in class org.apache.flink.api.common.operators.Ordering
 
isOuter() - Method in enum org.apache.flink.api.java.operators.join.JoinType
 
isOutputVertex() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
isPartitioned() - Method in enum org.apache.flink.optimizer.dataproperties.PartitioningProperty
Checks, if this property represents in fact a partitioning.
isPartitionedOnFields(FieldSet) - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
 
isPartitionedOnKey() - Method in enum org.apache.flink.optimizer.dataproperties.PartitioningProperty
Checks if this property presents a partitioning that is not random, but on a partitioning key.
isPeriodicCheckpointingConfigured() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Returns whether periodic checkpointing has been configured.
isPipelined() - Method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
 
isPossibly_sensitive() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
isPowerOf2(long) - Static method in class org.apache.flink.util.MathUtils
Checks whether the given value is a power of two.
isPreAllocated() - Method in class org.apache.flink.runtime.memory.MemoryManager
Checks whether this memory manager pre-allocates the memory.
isPreAllocateMemory() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
isPrintHelp() - Method in class org.apache.flink.client.cli.CommandLineOptions
 
isPrintingStatusDuringExecution() - Method in class org.apache.flink.api.common.PlanExecutor
Gets whether the executor prints progress results to "standard out" (System.out).
isProcessingTimeTimer(ProcessFunction<IN, OUT>.OnTimerContext) - Method in class org.apache.flink.table.runtime.aggregate.ProcessFunctionWithCleanupState
 
isProctimeAttribute(Expression) - Method in class org.apache.flink.table.expressions.ExpressionUtils$
 
isProctimeAttribute(Expression) - Static method in class org.apache.flink.table.expressions.ExpressionUtils
 
isProctimeIndicatorType(RelDataType) - Method in class org.apache.flink.table.calcite.FlinkTypeFactory$
 
isProctimeIndicatorType(TypeInformation<?>) - Method in class org.apache.flink.table.calcite.FlinkTypeFactory$
 
isProctimeIndicatorType(RelDataType) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
isProctimeIndicatorType(TypeInformation<?>) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
isProfile_background_tile() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
isProfile_use_background_image() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
isProgramSubmitEnabled() - Method in class org.apache.flink.runtime.webmonitor.WebMonitorConfig
 
isPropagateParentSchemaDown() - Method in class org.apache.flink.optimizer.postpass.GenericFlatTypePostPass
 
isProperClass(Class<?>) - Static method in class org.apache.flink.util.InstantiationUtil
Checks, whether the class is a proper class, i.e.
isProperlyShutDown() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
Utility method to check whether the IO manager has been properly shut down.
isProperlyShutDown() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
Utility method to check whether the IO manager has been properly shut down.
isProtected_tweet() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
isPruneMarkerSet() - Method in class org.apache.flink.optimizer.plan.PlanNode
Checks whether the pruning marker was set.
isPublic(Class<?>) - Static method in class org.apache.flink.util.InstantiationUtil
Checks, whether the given class is public.
isPurge() - Method in enum org.apache.flink.streaming.api.windowing.triggers.TriggerResult
 
isQuantifierAllowed() - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
isQuantifierAllowed() - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
isQuantifierAllowed() - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
isQuantifierAllowed() - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
isQueryable() - Method in class org.apache.flink.api.common.state.StateDescriptor
Returns whether the state created from this descriptor is queryable.
isQueuedSchedulingAllowed() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
isReaperThreadRunning() - Static method in class org.apache.flink.core.fs.SafetyNetCloseableRegistry
 
isRecord() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
Checks whether this element is a record.
isRecycled() - Method in class org.apache.flink.runtime.io.network.buffer.Buffer
 
isReference(GeneratedExpression) - Method in class org.apache.flink.table.codegen.CodeGenUtils$
 
isReference(TypeInformation<?>) - Method in class org.apache.flink.table.codegen.CodeGenUtils$
 
isReference(GeneratedExpression) - Static method in class org.apache.flink.table.codegen.CodeGenUtils
 
isReference(TypeInformation<?>) - Static method in class org.apache.flink.table.codegen.CodeGenUtils
 
isRegistered(InstanceID) - Method in class org.apache.flink.runtime.instance.InstanceManager
 
isRegistered(ResourceID) - Method in class org.apache.flink.runtime.instance.InstanceManager
 
isRegistered(String) - Method in class org.apache.flink.table.api.TableEnvironment
Checks if a table is registered under the given name.
isRegular() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
isReleased() - Method in class org.apache.flink.runtime.instance.Slot
Checks of the slot has been released.
isReleased() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
isReleased() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
 
isReleasing() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
 
isRemote() - Method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
 
isReplication() - Method in enum org.apache.flink.optimizer.dataproperties.PartitioningProperty
Checks, if this property represents a full replication.
isRequiresMigration() - Method in class org.apache.flink.api.common.typeutils.CompatibilityResult
 
isRestored() - Method in interface org.apache.flink.runtime.state.ManagedInitializationContext
Returns true, if state was restored from the snapshot of a previous execution.
isRestored() - Method in class org.apache.flink.runtime.state.StateInitializationContextImpl
 
isResultCollection() - Method in interface org.apache.flink.streaming.api.operators.async.queue.AsyncResult
True fi the async result is a collection of output elements; otherwise false.
isResultCollection() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
 
isRetweeted() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
isRight() - Method in class org.apache.flink.types.Either
 
isRootAndEmpty() - Method in class org.apache.flink.runtime.instance.SharedSlot
Checks whether this slot is a root slot that has not yet added any child slots.
isRowCountLiteral(Expression) - Method in class org.apache.flink.table.expressions.ExpressionUtils$
 
isRowCountLiteral(Expression) - Static method in class org.apache.flink.table.expressions.ExpressionUtils
 
isRowtimeAttribute(Expression) - Method in class org.apache.flink.table.expressions.ExpressionUtils$
 
isRowtimeAttribute(Expression) - Static method in class org.apache.flink.table.expressions.ExpressionUtils
 
isRowtimeIndicatorType(RelDataType) - Method in class org.apache.flink.table.calcite.FlinkTypeFactory$
 
isRowtimeIndicatorType(TypeInformation<?>) - Method in class org.apache.flink.table.calcite.FlinkTypeFactory$
 
isRowtimeIndicatorType(RelDataType) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
isRowtimeIndicatorType(TypeInformation<?>) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
isRunning() - Method in class org.apache.flink.api.common.PlanExecutor
Checks if this executor is currently running.
isRunning() - Method in class org.apache.flink.client.LocalExecutor
 
isRunning() - Method in class org.apache.flink.client.RemoteExecutor
 
isRunning() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
Checks if the mini cluster was started and is running.
isRunning() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
Checks whether this thread is still alive.
isRunning() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
isSameSlotSharingGroup(StreamNode) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
isSavepoint() - Method in class org.apache.flink.runtime.checkpoint.CheckpointProperties
Returns whether the checkpoint properties describe a standard savepoint.
isSemiJoinDone() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
isSerializable(Object) - Static method in class org.apache.flink.util.InstantiationUtil
 
isSerializerInitialized() - Method in class org.apache.flink.api.common.state.StateDescriptor
Checks whether the serializer has been initialized.
isShutdown() - Method in class org.apache.flink.runtime.blob.BlobServer
Tests whether the BLOB server has been requested to shut down.
isShutdown() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
isShutDown() - Method in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
 
isShutdown() - Method in class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
 
isShutdown() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
isShutdown() - Method in class org.apache.flink.runtime.memory.MemoryManager
Checks whether the MemoryManager has been shut down.
isShutdown() - Method in class org.apache.flink.runtime.metrics.MetricRegistry
Returns whether this registry has been shutdown.
isSimple(TypeInformation<?>) - Method in class org.apache.flink.table.typeutils.TypeCheckUtils$
Checks if type information is a simple type that can be converted to a SQL type and vice versa.
isSimple(TypeInformation<?>) - Static method in class org.apache.flink.table.typeutils.TypeCheckUtils
Checks if type information is a simple type that can be converted to a SQL type and vice versa.
isSkipInvalidLines() - Method in class org.apache.flink.api.java.io.TextValueInputFormat
 
isSkippingFirstLineAsHeader() - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
isSlotFree(int) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Check whether the task slot with the given index is free.
isSolaris() - Static method in enum org.apache.flink.util.OperatingSystem
Checks whether the operating system this JVM runs on is Solaris.
isSolutionSetUnManaged() - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
gets whether the solution set is in managed or unmanaged memory.
isSolutionSetUnManaged() - Method in class org.apache.flink.api.java.operators.DeltaIteration
gets whether the solution set is in managed or unmanaged memory.
isSolutionSetUnmanaged() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
isSolutionSetUnmanagedMemory() - Method in class org.apache.flink.graph.IterationConfiguration
Gets whether the solution set is kept in managed memory (Flink's internal way of keeping object in serialized form) or as a simple object map.
isSolutionSetUpdate - Variable in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
isSortedGrouping(int) - Method in class org.apache.flink.python.api.util.SetCache
Checks whether the cached set for the given ID is a SortedGrouping.
isSortKey(int, TypeInformation<?>) - Static method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
isSortKey(String, TypeInformation<?>) - Static method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
isSortKeyType() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
Checks whether this type can be used as a key for sorting.
isSortKeyType() - Method in class org.apache.flink.api.common.typeutils.CompositeType
 
isSortKeyType() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
isSortKeyType() - Static method in class org.apache.flink.table.runtime.types.CRowTypeInfo
 
isSortKeyType() - Static method in class org.apache.flink.table.typeutils.RowIntervalTypeInfo
 
isSortKeyType() - Static method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
 
isSortKeyType() - Static method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
 
isSpecial() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
 
isStart() - Method in class org.apache.flink.cep.nfa.State
 
isStarted(ResourceID) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Gets the started worker for a given resource ID, if one is available.
isStarted() - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
Checks whether the service has been started.
isStartState() - Method in class org.apache.flink.cep.nfa.ComputationState
 
isStateTimerActive() - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
isStateTimerActive() - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
isStateTimerActive() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
isStateTimerActive() - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
isStillAlive(long, long) - Method in class org.apache.flink.runtime.instance.Instance
Checks whether the last heartbeat occurred within the last n milliseconds before the given timestamp now.
isStop() - Method in class org.apache.flink.cep.nfa.State
 
isStoppable() - Method in interface org.apache.flink.runtime.executiongraph.AccessExecutionGraph
Returns whether the job for this execution graph is stoppable.
isStoppable() - Method in class org.apache.flink.runtime.executiongraph.ArchivedExecutionGraph
 
isStoppable() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
isStoppable() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
isStopped() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncIOCallable
Check if the IO operation is stopped
isStopped() - Method in interface org.apache.flink.runtime.io.async.AsyncStoppable
Check whether the operation is stopped
isStopState() - Method in class org.apache.flink.cep.nfa.ComputationState
 
isStreamStatus() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
Checks whether this element is a stream status.
isString(TypeInformation<?>) - Method in class org.apache.flink.table.typeutils.TypeCheckUtils$
 
isString(TypeInformation<?>) - Static method in class org.apache.flink.table.typeutils.TypeCheckUtils
 
isStruct() - Static method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
isSuccess() - Method in class org.apache.flink.table.validate.ValidationFailure
 
isSuccess() - Method in interface org.apache.flink.table.validate.ValidationResult
 
isSuccess() - Method in class org.apache.flink.table.validate.ValidationSuccess$
 
isSuccess() - Static method in class org.apache.flink.table.validate.ValidationSuccess
 
isSynchronous() - Method in enum org.apache.flink.runtime.io.disk.iomanager.IOManager.IOMode
 
isSysoutLoggingEnabled() - Method in class org.apache.flink.api.common.ExecutionConfig
Gets whether progress update messages should be printed to System.out
isTagged(Value) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
 
isTalk() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
 
isTemporal(TypeInformation<?>) - Method in class org.apache.flink.table.typeutils.TypeCheckUtils$
 
isTemporal(TypeInformation<?>) - Static method in class org.apache.flink.table.typeutils.TypeCheckUtils
 
isTerminal() - Method in enum org.apache.flink.runtime.execution.ExecutionState
 
isTerminalState() - Method in enum org.apache.flink.runtime.jobgraph.JobStatus
Checks whether this state is locally terminal.
isTerminated() - Method in class org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
Returns true if the service has been shut down, false otherwise.
isTerminated() - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
 
isTerminated() - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
isThis() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
isTimeAttribute(Expression) - Method in class org.apache.flink.table.expressions.ExpressionUtils$
 
isTimeAttribute(Expression) - Static method in class org.apache.flink.table.expressions.ExpressionUtils
 
isTimeIndicatorType(RelDataType) - Method in class org.apache.flink.table.calcite.FlinkTypeFactory$
 
isTimeIndicatorType(TypeInformation<?>) - Method in class org.apache.flink.table.calcite.FlinkTypeFactory$
 
isTimeIndicatorType(RelDataType) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
isTimeIndicatorType(TypeInformation<?>) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
isTimeInterval(TypeInformation<?>) - Method in class org.apache.flink.table.typeutils.TypeCheckUtils$
 
isTimeInterval(TypeInformation<?>) - Static method in class org.apache.flink.table.typeutils.TypeCheckUtils
 
isTimeIntervalLiteral(Expression) - Method in class org.apache.flink.table.expressions.ExpressionUtils$
 
isTimeIntervalLiteral(Expression) - Static method in class org.apache.flink.table.expressions.ExpressionUtils
 
isTimePoint(TypeInformation<?>) - Method in class org.apache.flink.table.typeutils.TypeCheckUtils$
 
isTimePoint(TypeInformation<?>) - Static method in class org.apache.flink.table.typeutils.TypeCheckUtils
 
isTimerActive(String) - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
isTimerActive(String) - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
isTimerActive(String) - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
isTimerActive(String) - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
isTopologyRecovery() - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig
Returns true if topology recovery is enabled, false otherwise
isTriggered() - Method in class org.apache.flink.core.testutils.OneShotLatch
Checks if the latch was triggered.
isTrimUnusedFields() - Method in interface org.apache.calcite.sql2rel.SqlToRelConverter.Config
Returns the trimUnusedFields option.
isTrimUnusedFields() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Deprecated.
isTrivial() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
Checks, if the properties in this object are trivial, i.e.
isTrivial() - Method in class org.apache.flink.optimizer.dataproperties.LocalProperties
Checks, if the properties in this object are trivial, i.e.
isTrivial() - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
Checks, if the properties in this object are trivial, i.e.
isTrivial() - Method in class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
Checks, if the properties in this object are trivial, i.e.
isTrue() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Returns true if given boolean expression is true.
IsTrue - Class in org.apache.flink.table.expressions
 
IsTrue(Expression) - Constructor for class org.apache.flink.table.expressions.IsTrue
 
IsTrue$ - Class in org.apache.flink.table.expressions
 
IsTrue$() - Constructor for class org.apache.flink.table.expressions.IsTrue$
 
isTruncated() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
isTupleType() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
Checks if this type information represents a Tuple type.
isTupleType() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.java.typeutils.ListTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
isTupleType() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.scala.typeutils.EitherTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.scala.typeutils.EnumValueTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.scala.typeutils.OptionTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.scala.typeutils.ScalaNothingTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.scala.typeutils.TraversableTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.scala.typeutils.TryTypeInfo
 
isTupleType() - Method in class org.apache.flink.api.scala.typeutils.UnitTypeInfo
 
isTupleType() - Method in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
 
isTupleType() - Method in class org.apache.flink.table.runtime.types.CRowTypeInfo
 
isTupleType() - Method in class org.apache.flink.table.typeutils.InternalTypeInfo
 
isTupleType() - Static method in class org.apache.flink.table.typeutils.RowIntervalTypeInfo
 
isTupleType() - Static method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
 
isTupleType() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
 
isTwo() - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
 
isUdfBinary() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
isUdfReduceFunction() - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
isUnknown() - Method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
 
isUnpatrolled() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
 
isUnsortedGrouping(int) - Method in class org.apache.flink.python.api.util.SetCache
Checks whether the cached set for the given ID is an UnsortedGrouping.
isUsingInteractiveMode() - Method in class org.apache.flink.client.program.PackagedProgram
 
isUsingProgramEntryPoint() - Method in class org.apache.flink.client.program.PackagedProgram
 
isValid() - Method in class org.apache.flink.api.common.operators.ResourceSpec
Check whether all the field values are valid.
isValid(UUID) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
Checks whether the given resource manager leader id is matching the current leader id and not null.
isValid(K, UUID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TimerService
Check whether the timeout for the given key and ticket is still valid (not yet unregistered and not yet overwritten).
isValid(boolean) - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
isValid(Litmus, RelNode.Context) - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
isValid(Litmus, RelNode.Context) - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
isValid(boolean) - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
isValid(boolean) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
isValid(Litmus, RelNode.Context) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
isValid(boolean) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
isValid(Litmus, RelNode.Context) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
isValid(boolean) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
isValid(Litmus, RelNode.Context) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
isValid(Litmus, RelNode.Context) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
isValid(boolean) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
isValid(boolean) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
isValid(Litmus, RelNode.Context) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
isValid(Litmus, RelNode.Context) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
isValid(boolean) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
isValid(Litmus, RelNode.Context) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
isValid(boolean) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
isValid(boolean) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
isValid(Litmus, RelNode.Context) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
isValid(Litmus, RelNode.Context) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
isValid(boolean) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
isValid(Litmus, RelNode.Context) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
isValid(boolean) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
isValid(Litmus, RelNode.Context) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
isValid(boolean) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
isValid(Litmus, RelNode.Context) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
isValid(boolean) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
isValid(Litmus, RelNode.Context) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
isValid(boolean) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
isValid(boolean) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
isValid(Litmus, RelNode.Context) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
isValidSubset(FieldSet) - Method in class org.apache.flink.api.common.operators.util.FieldList
 
isValidSubset(FieldList) - Method in class org.apache.flink.api.common.operators.util.FieldList
 
isValidSubset(FieldSet) - Method in class org.apache.flink.api.common.operators.util.FieldSet
Checks if the given set of fields is a valid subset of this set of fields.
isValidTimeout(JobID, UUID) - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
 
isValidTimeout(AllocationID, UUID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Check whether the timeout with ticket is valid for the given allocation id.
isValidUnorderedPrefix(FieldSet) - Method in class org.apache.flink.api.common.operators.util.FieldList
 
isVerified() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
isWatermark() - Method in interface org.apache.flink.streaming.api.operators.async.queue.AsyncResult
True if the async result is a Watermark; otherwise false.
isWatermark() - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
 
isWatermark() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElement
Checks whether this element is a watermark.
isWatermarkAligned - Variable in class org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve.InputChannelStatus
 
isWindowLate(W) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
Returns true if the watermark is after the end timestamp plus the allowed lateness of the given window.
isWindows() - Static method in enum org.apache.flink.util.OperatingSystem
Checks whether the operating system this JVM runs on is Windows.
isWithSavepoint() - Method in class org.apache.flink.client.cli.CancelOptions
 
isWorksetIteration - Variable in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
isWorksetUpdate - Variable in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
isWriteAheadLogEnabled - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
 
isZkSaslDisable() - Method in class org.apache.flink.runtime.security.SecurityUtils.SecurityConfiguration
 
isZooKeeperRecoveryMode(Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
Returns whether HighAvailabilityMode.ZOOKEEPER is configured.
it() - Method in class org.apache.flink.table.runtime.aggregate.SingleElementIterable
 
ITEM - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The item operator {@code [ ...
item() - Method in class org.apache.flink.ml.recommendation.ALS.Rating
 
ITEM_FACTORS_FILE() - Method in class org.apache.flink.ml.recommendation.ALS$
 
ITEM_FACTORS_FILE() - Static method in class org.apache.flink.ml.recommendation.ALS
 
itemFactors() - Method in class org.apache.flink.ml.recommendation.ALS.BlockedFactorization
 
itemFactors() - Method in class org.apache.flink.ml.recommendation.ALS.Factorization
 
IterableIterator<E> - Interface in org.apache.flink.util
An Iterator that is also Iterable (often by returning itself).
iterate(int) - Method in class org.apache.flink.api.java.DataSet
Initiates an iterative part of the program that executes multiple times and feeds back data sets.
iterate(int, Function1<DataSet<T>, DataSet<T>>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
iterate(int, Function1<DataSet<T>, DataSet<T>>) - Method in class org.apache.flink.api.scala.DataSet
Creates a new DataSet by performing bulk iterations using the given step function.
iterate() - Method in class org.apache.flink.streaming.api.datastream.DataStream
Initiates an iterative part of the program that feeds back data streams.
iterate(long) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Initiates an iterative part of the program that feeds back data streams.
iterate(Function1<DataStream<T>, Tuple2<DataStream<T>, DataStream<R>>>, long, boolean) - Method in class org.apache.flink.streaming.api.scala.DataStream
Initiates an iterative part of the program that creates a loop by feeding back data streams.
iterate(Function1<ConnectedStreams<T, F>, Tuple2<DataStream<F>, DataStream<R>>>, long, TypeInformation<F>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Initiates an iterative part of the program that creates a loop by feeding back data streams.
iterateDelta(DataSet<R>, int, int...) - Method in class org.apache.flink.api.java.DataSet
Initiates a delta iteration.
iterateDelta(DataSet<R>, int, int[], Function2<DataSet<T>, DataSet<R>, Tuple2<DataSet<T>, DataSet<R>>>, ClassTag<R>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
iterateDelta(DataSet<R>, int, int[], boolean, Function2<DataSet<T>, DataSet<R>, Tuple2<DataSet<T>, DataSet<R>>>, ClassTag<R>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
iterateDelta(DataSet<R>, int, String[], Function2<DataSet<T>, DataSet<R>, Tuple2<DataSet<T>, DataSet<R>>>, ClassTag<R>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
iterateDelta(DataSet<R>, int, String[], boolean, Function2<DataSet<T>, DataSet<R>, Tuple2<DataSet<T>, DataSet<R>>>, ClassTag<R>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
iterateDelta(DataSet<R>, int, int[], Function2<DataSet<T>, DataSet<R>, Tuple2<DataSet<T>, DataSet<R>>>, ClassTag<R>) - Method in class org.apache.flink.api.scala.DataSet
Creates a new DataSet by performing delta (or workset) iterations using the given step function.
iterateDelta(DataSet<R>, int, int[], boolean, Function2<DataSet<T>, DataSet<R>, Tuple2<DataSet<T>, DataSet<R>>>, ClassTag<R>) - Method in class org.apache.flink.api.scala.DataSet
Creates a new DataSet by performing delta (or workset) iterations using the given step function.
iterateDelta(DataSet<R>, int, String[], Function2<DataSet<T>, DataSet<R>, Tuple2<DataSet<T>, DataSet<R>>>, ClassTag<R>) - Method in class org.apache.flink.api.scala.DataSet
Creates a new DataSet by performing delta (or workset) iterations using the given step function.
iterateDelta(DataSet<R>, int, String[], boolean, Function2<DataSet<T>, DataSet<R>, Tuple2<DataSet<T>, DataSet<R>>>, ClassTag<R>) - Method in class org.apache.flink.api.scala.DataSet
Creates a new DataSet by performing delta (or workset) iterations using the given step function.
iterateEdges(Iterable<Tuple2<K, Edge<K, EV>>>, Collector<O>) - Method in interface org.apache.flink.graph.EdgesFunction
This method is called per vertex and can iterate over all of its neighboring edges with the specified direction.
iterateEdges(Vertex<K, VV>, Iterable<Edge<K, EV>>, Collector<O>) - Method in interface org.apache.flink.graph.EdgesFunctionWithVertexValue
This method is called per vertex and can iterate over all of its neighboring edges with the specified direction.
iterateEdges(Vertex<String, NullValue>, Iterable<Edge<String, Integer>>, Collector<Tuple2<String, String>>) - Method in class org.apache.flink.graph.examples.MusicProfiles.GetTopSongPerUser
 
iterateEdges(Iterable<Tuple2<K, Edge<K, EV>>>, Collector<T>) - Method in class org.apache.flink.graph.scala.EdgesFunction
 
iterateEdges(Iterable<Tuple2<K, Edge<K, EV>>>, Collector<T>) - Method in class org.apache.flink.graph.scala.EdgesFunction
 
iterateEdges(Vertex<K, VV>, Iterable<Edge<K, EV>>, Collector<T>) - Method in class org.apache.flink.graph.scala.EdgesFunctionWithVertexValue
 
iterateEdges(Vertex<K, VV>, Iterable<Edge<K, EV>>, Collector<T>) - Method in class org.apache.flink.graph.scala.EdgesFunctionWithVertexValue
 
IterateExample - Class in org.apache.flink.streaming.examples.iteration
Example illustrating iterations in Flink streaming.
IterateExample() - Constructor for class org.apache.flink.streaming.examples.iteration.IterateExample
 
IterateExample.InputMap - Class in org.apache.flink.streaming.examples.iteration
Map the inputs so that the next Fibonacci numbers can be calculated while preserving the original input tuple A counter is attached to the tuple and incremented in every iteration step
IterateExample.MySelector - Class in org.apache.flink.streaming.examples.iteration
OutputSelector testing which tuple needs to be iterated again.
IterateExample.OutputMap - Class in org.apache.flink.streaming.examples.iteration
Giving back the input pair and the counter
IterateExample.Step - Class in org.apache.flink.streaming.examples.iteration
Iteration step function that calculates the next Fibonacci number
IterateExampleData - Class in org.apache.flink.streaming.examples.iteration.util
 
iterateNeighbors(Iterable<Tuple3<K, Edge<K, EV>, Vertex<K, VV>>>, Collector<O>) - Method in interface org.apache.flink.graph.NeighborsFunction
This method is called per vertex and can iterate over all of its neighbors with the specified direction.
iterateNeighbors(Vertex<K, VV>, Iterable<Tuple2<Edge<K, EV>, Vertex<K, VV>>>, Collector<O>) - Method in interface org.apache.flink.graph.NeighborsFunctionWithVertexValue
This method is called per vertex and can iterate over all of its neighbors with the specified direction.
iterateNeighbors(Iterable<Tuple3<K, Edge<K, EV>, Vertex<K, VV>>>, Collector<T>) - Method in class org.apache.flink.graph.scala.NeighborsFunction
 
iterateNeighbors(Iterable<Tuple3<K, Edge<K, EV>, Vertex<K, VV>>>, Collector<T>) - Method in class org.apache.flink.graph.scala.NeighborsFunction
 
iterateNeighbors(Vertex<K, VV>, Iterable<Tuple2<Edge<K, EV>, Vertex<K, VV>>>, Collector<T>) - Method in class org.apache.flink.graph.scala.NeighborsFunctionWithVertexValue
 
iterateNeighbors(Vertex<K, VV>, Iterable<Tuple2<Edge<K, EV>, Vertex<K, VV>>>, Collector<T>) - Method in class org.apache.flink.graph.scala.NeighborsFunctionWithVertexValue
 
iterateWithTermination(int, Function1<DataSet<T>, Tuple2<DataSet<T>, DataSet<?>>>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
iterateWithTermination(int, Function1<DataSet<T>, Tuple2<DataSet<T>, DataSet<?>>>) - Method in class org.apache.flink.api.scala.DataSet
Creates a new DataSet by performing bulk iterations using the given step function.
IterationAggregatorBroker - Class in org.apache.flink.runtime.iterative.concurrent
 
IterationAggregatorBroker() - Constructor for class org.apache.flink.runtime.iterative.concurrent.IterationAggregatorBroker
 
IterationConfiguration - Class in org.apache.flink.graph
This is used as a base class for vertex-centric iteration or gather-sum-apply iteration configuration.
IterationConfiguration() - Constructor for class org.apache.flink.graph.IterationConfiguration
 
IterationConvergence - Class in org.apache.flink.graph.drivers.parameter
Iterative algorithms which converge can be terminated with a maximum number of iterations or a convergence threshold which stops computation when the total change in scores is below a given delta.
IterationConvergence(ParameterizedBase, int) - Constructor for class org.apache.flink.graph.drivers.parameter.IterationConvergence
Add this parameter to the list of parameters stored by owner.
IterationConvergence.Value - Class in org.apache.flink.graph.drivers.parameter
Encapsulate the number of iterations and the convergence threshold.
IterationEventWithAggregators - Class in org.apache.flink.runtime.iterative.event
 
IterationEventWithAggregators() - Constructor for class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
 
IterationEventWithAggregators(String, Value) - Constructor for class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
 
IterationEventWithAggregators(Map<String, Aggregator<?>>) - Constructor for class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
 
IterationHeadTask<X,Y,S extends Function,OT> - Class in org.apache.flink.runtime.iterative.task
The head is responsible for coordinating an iteration and can run a Driver inside.
IterationHeadTask() - Constructor for class org.apache.flink.runtime.iterative.task.IterationHeadTask
 
iterationIdCounter - Static variable in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
IterationIntermediateTask<S extends Function,OT> - Class in org.apache.flink.runtime.iterative.task
An intermediate iteration task, which runs a Driver inside.
IterationIntermediateTask() - Constructor for class org.apache.flink.runtime.iterative.task.IterationIntermediateTask
 
IterationNode - Interface in org.apache.flink.optimizer.dag
 
IterationOperator - Interface in org.apache.flink.api.common.operators
 
IterationPlanNode - Interface in org.apache.flink.optimizer.plan
 
IterationRuntimeContext - Interface in org.apache.flink.api.common.functions
 
iterations - Variable in class org.apache.flink.graph.drivers.parameter.IterationConvergence.Value
 
Iterations$() - Constructor for class org.apache.flink.ml.classification.SVM.Iterations$
 
Iterations$() - Constructor for class org.apache.flink.ml.optimization.IterativeSolver.Iterations$
 
Iterations$() - Constructor for class org.apache.flink.ml.recommendation.ALS.Iterations$
 
Iterations$() - Constructor for class org.apache.flink.ml.regression.MultipleLinearRegression.Iterations$
 
IterationSynchronizationSinkTask - Class in org.apache.flink.runtime.iterative.task
The task responsible for synchronizing all iteration heads, implemented as an output task.
IterationSynchronizationSinkTask() - Constructor for class org.apache.flink.runtime.iterative.task.IterationSynchronizationSinkTask
 
IterationTailTask<S extends Function,OT> - Class in org.apache.flink.runtime.iterative.task
An iteration tail, which runs a driver inside.
IterationTailTask() - Constructor for class org.apache.flink.runtime.iterative.task.IterationTailTask
 
iterativeBroadcastInputs - Variable in class org.apache.flink.runtime.operators.BatchTask
The indices of the iterative broadcast inputs.
IterativeCondition<T> - Class in org.apache.flink.cep.pattern.conditions
A user-defined condition that decides if an element should be accepted in the pattern or not.
IterativeCondition() - Constructor for class org.apache.flink.cep.pattern.conditions.IterativeCondition
 
IterativeCondition.Context<T> - Interface in org.apache.flink.cep.pattern.conditions
The context used when evaluating the condition.
IterativeDataSet<T> - Class in org.apache.flink.api.java.operators
The IterativeDataSet represents the start of an iteration.
IterativeDataSet(ExecutionEnvironment, TypeInformation<T>, DataSet<T>, int) - Constructor for class org.apache.flink.api.java.operators.IterativeDataSet
 
iterativeInputs - Variable in class org.apache.flink.runtime.operators.BatchTask
The indices of the iterative inputs.
IterativeSolver - Class in org.apache.flink.ml.optimization
An abstract class for iterative optimization algorithms
IterativeSolver() - Constructor for class org.apache.flink.ml.optimization.IterativeSolver
 
IterativeSolver$ - Class in org.apache.flink.ml.optimization
 
IterativeSolver$() - Constructor for class org.apache.flink.ml.optimization.IterativeSolver$
 
IterativeSolver.ConvergenceThreshold$ - Class in org.apache.flink.ml.optimization
 
IterativeSolver.Iterations$ - Class in org.apache.flink.ml.optimization
 
IterativeSolver.LearningRate$ - Class in org.apache.flink.ml.optimization
 
IterativeSolver.LearningRateMethodValue$ - Class in org.apache.flink.ml.optimization
 
IterativeStream<T> - Class in org.apache.flink.streaming.api.datastream
The iterative data stream represents the start of an iteration in a DataStream.
IterativeStream(DataStream<T>, long) - Constructor for class org.apache.flink.streaming.api.datastream.IterativeStream
 
IterativeStream.ConnectedIterativeStreams<I,F> - Class in org.apache.flink.streaming.api.datastream
The IterativeStream.ConnectedIterativeStreams represent a start of an iterative part of a streaming program, where the original input of the iteration and the feedback of the iteration are connected as in a ConnectedStreams.
iterator() - Method in class org.apache.flink.api.common.functions.util.CopyingIterator
 
iterator() - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase.SimpleListIterable
 
iterator() - Method in class org.apache.flink.api.common.operators.util.FieldSet
 
iterator() - Method in class org.apache.flink.api.common.operators.util.ListKeyGroupedIterator.ValuesIterator
 
iterator() - Method in interface org.apache.flink.api.common.state.MapState
Iterates over all the mappings in the state.
iterator() - Method in class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
 
iterator() - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
 
iterator() - Method in class org.apache.flink.contrib.streaming.state.RocksDBMapState
 
iterator() - Method in class org.apache.flink.graph.pregel.MessageIterator
 
iterator() - Method in class org.apache.flink.graph.spargel.MessageIterator
 
iterator() - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
 
iterator() - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
 
iterator() - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
 
iterator() - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
 
iterator() - Method in class org.apache.flink.runtime.jobmanager.scheduler.LifoSetQueue
 
iterator() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
iterator() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable
 
iterator() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
 
iterator - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
The iterator to be returned by the sort-merger.
iterator() - Method in class org.apache.flink.runtime.operators.util.metrics.CountingIterable
 
iterator() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
iterator() - Method in class org.apache.flink.runtime.state.heap.HeapMapState
 
iterator() - Method in class org.apache.flink.runtime.state.KeyGroupRange
 
iterator() - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
 
iterator() - Method in class org.apache.flink.runtime.taskexecutor.SlotReport
 
iterator() - Method in class org.apache.flink.runtime.util.EmptyIterator
 
iterator() - Method in class org.apache.flink.runtime.util.EvictingBoundedList
 
iterator() - Method in class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator.ValuesIterator
 
iterator() - Method in class org.apache.flink.runtime.util.NonReusingMutableToRegularIteratorWrapper
 
iterator() - Method in class org.apache.flink.runtime.util.ReusingKeyGroupedIterator.ValuesIterator
 
iterator() - Method in class org.apache.flink.runtime.util.ReusingMutableToRegularIteratorWrapper
 
iterator() - Method in class org.apache.flink.runtime.util.SingleElementIterator
 
iterator() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
Creates an iterator over the entries of this map.
iterator() - Method in class org.apache.flink.table.runtime.aggregate.SingleElementIterable
 
iterator() - Method in class org.apache.flink.types.ListValue
 
iterator() - Method in class org.apache.flink.util.UnionIterator
 
iterator1 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
iterator2 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
iteratorException - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
The exception that is set, if the iterator cannot be created.
IteratorInputFormat<T> - Class in org.apache.flink.api.java.io
An input format that returns objects from an iterator.
IteratorInputFormat(Iterator<T>) - Constructor for class org.apache.flink.api.java.io.IteratorInputFormat
 
iteratorLock - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
The monitor which guards the iterator field.

J

j(Seq<Object>) - Method in class org.apache.flink.table.codegen.IndentStringContext
 
JaasModule - Class in org.apache.flink.runtime.security.modules
Responsible for installing a process-wide JAAS configuration.
JaasModule() - Constructor for class org.apache.flink.runtime.security.modules.JaasModule
 
JaccardIndex<K extends CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.drivers
Driver for JaccardIndex.
JaccardIndex() - Constructor for class org.apache.flink.graph.drivers.JaccardIndex
 
JaccardIndex<K extends CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.similarity
The Jaccard Index measures the similarity between vertex neighborhoods and is computed as the number of shared neighbors divided by the number of distinct neighbors.
JaccardIndex() - Constructor for class org.apache.flink.graph.library.similarity.JaccardIndex
 
JaccardIndex.Result<T> - Class in org.apache.flink.graph.library.similarity
Wraps the vertex type to encapsulate results from the jaccard index algorithm.
jacksonFactory - Static variable in class org.apache.flink.runtime.webmonitor.handlers.JsonFactory
The singleton Jackson JSON factory.
JarAccessDeniedHandler - Class in org.apache.flink.runtime.webmonitor.handlers
 
JarAccessDeniedHandler() - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JarAccessDeniedHandler
 
JarActionHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Abstract handler for fetching plan for a jar or running a jar.
JarActionHandler(File) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JarActionHandler
 
JarDeleteHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Handles requests for deletion of jars.
JarDeleteHandler(File) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JarDeleteHandler
 
jarDir(File, File) - Method in class org.apache.flink.api.java.JarHelper
Jars a given directory or single file into a JarOutputStream.
JarFileCreator - Class in org.apache.flink.runtime.util
This is an auxiliary program which creates a jar file from a set of classes.
JarFileCreator(File) - Constructor for class org.apache.flink.runtime.util.JarFileCreator
Constructs a new jar file creator.
jarFiles - Variable in class org.apache.flink.api.java.RemoteEnvironment
The jar files that need to be attached to each job
jarFilesToAttach - Variable in class org.apache.flink.client.program.ContextEnvironment
 
JarHelper - Class in org.apache.flink.api.java
Provides utility services for jarring and unjarring files and directories.
JarHelper() - Constructor for class org.apache.flink.api.java.JarHelper
Instantiates a new JarHelper.
JarListHandler - Class in org.apache.flink.runtime.webmonitor.handlers
 
JarListHandler(File) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JarListHandler
 
JarPlanHandler - Class in org.apache.flink.runtime.webmonitor.handlers
This handler handles requests to fetch plan for a jar.
JarPlanHandler(File) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JarPlanHandler
 
JarRunHandler - Class in org.apache.flink.runtime.webmonitor.handlers
This handler handles requests to fetch plan for a jar.
JarRunHandler(File, FiniteDuration, Configuration) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JarRunHandler
 
JarUploadHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Handles requests for uploading of jars.
JarUploadHandler(File) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JarUploadHandler
 
JavaApiPostPass - Class in org.apache.flink.optimizer.postpass
The post-optimizer plan traversal.
JavaApiPostPass() - Constructor for class org.apache.flink.optimizer.postpass.JavaApiPostPass
 
javaAsyncCollector() - Method in class org.apache.flink.streaming.api.scala.async.JavaAsyncCollectorWrapper
 
JavaAsyncCollectorWrapper<OUT> - Class in org.apache.flink.streaming.api.scala.async
Internal wrapper class to map a Flink's Java API JavaAsyncCollector to a Scala AsyncCollector.
JavaAsyncCollectorWrapper(AsyncCollector<OUT>) - Constructor for class org.apache.flink.streaming.api.scala.async.JavaAsyncCollectorWrapper
 
javaDec2Literal(BigDecimal) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionConversions
 
JavaProgramTestBase - Class in org.apache.flink.test.util
 
JavaProgramTestBase() - Constructor for class org.apache.flink.test.util.JavaProgramTestBase
 
JavaProgramTestBase(Configuration) - Constructor for class org.apache.flink.test.util.JavaProgramTestBase
 
JavaProgramTestBase.TupleComparator<T extends Tuple> - Class in org.apache.flink.test.util
 
JavaSerializer<T> - Class in org.apache.flink.api.java.typeutils.runtime.kryo
This is a reimplementation of Kryo's JavaSerializer, that additionally makes sure the ObjectInputStream used for deserialization specifically uses Kryo's registered classloader.
JavaSerializer() - Constructor for class org.apache.flink.api.java.typeutils.runtime.kryo.JavaSerializer
 
javaSet() - Static method in class org.apache.flink.api.scala.CrossDataSet
 
javaSet() - Method in class org.apache.flink.api.scala.DataSet
Returns the underlying Java DataSet.
javaStream() - Method in class org.apache.flink.streaming.api.scala.DataStream
Gets the underlying java DataStream object.
JavaToValueConverter - Class in org.apache.flink.types
 
JavaToValueConverter() - Constructor for class org.apache.flink.types.JavaToValueConverter
 
JavaTupleDescriptor(int, scala.reflect.macros.Context.universe, Seq<TypeDescriptors<C>.UDTDescriptor>) - Constructor for class org.apache.flink.api.scala.codegen.TypeDescriptors.JavaTupleDescriptor
 
JDBCInputFormat - Class in org.apache.flink.api.java.io.jdbc
InputFormat to read data from a database and generate Rows.
JDBCInputFormat() - Constructor for class org.apache.flink.api.java.io.jdbc.JDBCInputFormat
 
JDBCInputFormat.JDBCInputFormatBuilder - Class in org.apache.flink.api.java.io.jdbc
 
JDBCInputFormatBuilder() - Constructor for class org.apache.flink.api.java.io.jdbc.JDBCInputFormat.JDBCInputFormatBuilder
 
JDBCOutputFormat - Class in org.apache.flink.api.java.io.jdbc
OutputFormat to write Rows into a JDBC database.
JDBCOutputFormat() - Constructor for class org.apache.flink.api.java.io.jdbc.JDBCOutputFormat
 
JDBCOutputFormat.JDBCOutputFormatBuilder - Class in org.apache.flink.api.java.io.jdbc
 
JDBCOutputFormatBuilder() - Constructor for class org.apache.flink.api.java.io.jdbc.JDBCOutputFormat.JDBCOutputFormatBuilder
 
JDKRandomGeneratorFactory - Class in org.apache.flink.graph.generator.random
Uses a seeded JDKRandomGenerator to generate seeds for the distributed collection of JDKRandomGenerator.
JDKRandomGeneratorFactory() - Constructor for class org.apache.flink.graph.generator.random.JDKRandomGeneratorFactory
 
JDKRandomGeneratorFactory(long) - Constructor for class org.apache.flink.graph.generator.random.JDKRandomGeneratorFactory
 
jenkinsHash(int) - Static method in class org.apache.flink.util.MathUtils
This function hashes an integer value.
JMTMRegistrationSuccess - Class in org.apache.flink.runtime.jobmaster
 
JMTMRegistrationSuccess(ResourceID, int) - Constructor for class org.apache.flink.runtime.jobmaster.JMTMRegistrationSuccess
 
JMXReporter - Class in org.apache.flink.metrics.jmx
MetricReporter that exports Metrics via JMX.
JMXReporter() - Constructor for class org.apache.flink.metrics.jmx.JMXReporter
Creates a new JMXReporter
JMXReporter.JmxCounterMBean - Interface in org.apache.flink.metrics.jmx
 
JMXReporter.JmxGaugeMBean - Interface in org.apache.flink.metrics.jmx
 
JMXReporter.JmxHistogramMBean - Interface in org.apache.flink.metrics.jmx
 
JMXReporter.JmxMeterMBean - Interface in org.apache.flink.metrics.jmx
 
JMXReporter.MetricMBean - Interface in org.apache.flink.metrics.jmx
 
job() - Method in class org.apache.flink.runtime.messages.ArchiveMessages.ArchivedJob
 
JOB_MANAGER_HEAP_MEMORY - Static variable in class org.apache.flink.configuration.JobManagerOptions
JVM heap size (in megabytes) for the JobManager
JOB_MANAGER_IPC_ADDRESS_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
JOB_MANAGER_IPC_PORT_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
JOB_MANAGER_NAME - Static variable in class org.apache.flink.runtime.jobmaster.JobMaster
Default names for Flink's distributed components
JOB_MANAGER_WEB_ARCHIVE_COUNT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
JOB_MANAGER_WEB_BACK_PRESSURE_CLEAN_UP_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
JOB_MANAGER_WEB_BACK_PRESSURE_DELAY - Static variable in class org.apache.flink.configuration.ConfigConstants
JOB_MANAGER_WEB_BACK_PRESSURE_NUM_SAMPLES - Static variable in class org.apache.flink.configuration.ConfigConstants
JOB_MANAGER_WEB_BACK_PRESSURE_REFRESH_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
JOB_MANAGER_WEB_CHECKPOINTS_DISABLE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Not possible to disable any longer. Use history size of 0.
JOB_MANAGER_WEB_CHECKPOINTS_HISTORY_SIZE - Static variable in class org.apache.flink.configuration.ConfigConstants
JOB_MANAGER_WEB_LOG_PATH_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
JOB_MANAGER_WEB_PORT_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
JOB_MANAGER_WEB_PORT_KEY - Static variable in class org.apache.flink.runtime.webmonitor.WebMonitorConfig
The port for the runtime monitor web-frontend server.
JOB_MANAGER_WEB_REFRESH_INTERVAL_KEY - Static variable in class org.apache.flink.runtime.webmonitor.WebMonitorConfig
The initial refresh interval for the web dashboard
JOB_MANAGER_WEB_SSL_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
JOB_MANAGER_WEB_SUBMIT_ENABLED_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
JOB_MANAGER_WEB_TMPDIR_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
JOB_MANAGER_WEB_UPLOAD_DIR_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
JOB_TIMEOUT - Static variable in class org.apache.flink.configuration.ResourceManagerOptions
Timeout for jobs which don't have a job manager as leader assigned.
JobAccumulatorsHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Request handler that returns the aggregated user accumulators of a job.
JobAccumulatorsHandler(ExecutionGraphHolder) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JobAccumulatorsHandler
 
JobAccumulatorsHandler.JobAccumulatorsJsonArchivist - Class in org.apache.flink.runtime.webmonitor.handlers
 
JobAccumulatorsJsonArchivist() - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JobAccumulatorsHandler.JobAccumulatorsJsonArchivist
 
JobAttachmentClientActor - Class in org.apache.flink.runtime.client
Actor which handles Job attachment process and provides Job updates until completion.
JobAttachmentClientActor(LeaderRetrievalService, FiniteDuration, boolean) - Constructor for class org.apache.flink.runtime.client.JobAttachmentClientActor
 
JobCancellationException - Exception in org.apache.flink.runtime.client
An exception which is thrown by the JobClient if a job is aborted as a result of a user cancellation.
JobCancellationException(JobID, String, Throwable) - Constructor for exception org.apache.flink.runtime.client.JobCancellationException
 
JobCancellationHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Request handler for the CANCEL request.
JobCancellationHandler() - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JobCancellationHandler
 
JobCancellationWithSavepointHandlers - Class in org.apache.flink.runtime.webmonitor.handlers
Request handler for JobManagerMessages.CancelJobWithSavepoint messages.
JobCancellationWithSavepointHandlers(ExecutionGraphHolder, ExecutionContext) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JobCancellationWithSavepointHandlers
 
JobCancellationWithSavepointHandlers(ExecutionGraphHolder, ExecutionContext, String) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JobCancellationWithSavepointHandlers
 
JobCheckpointingSettings - Class in org.apache.flink.runtime.jobgraph.tasks
The JobCheckpointingSettings are attached to a JobGraph and describe the settings for the asynchronous checkpoints of the JobGraph, such as interval, and which vertices need to participate.
JobCheckpointingSettings(List<JobVertexID>, List<JobVertexID>, List<JobVertexID>, long, long, long, int, ExternalizedCheckpointSettings, SerializedValue<StateBackend>, boolean) - Constructor for class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
JobCheckpointingSettings(List<JobVertexID>, List<JobVertexID>, List<JobVertexID>, long, long, long, int, ExternalizedCheckpointSettings, SerializedValue<StateBackend>, SerializedValue<MasterTriggerRestoreHook.Factory[]>, boolean) - Constructor for class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
JobClient - Class in org.apache.flink.runtime.client
The JobClient bridges between the JobManager's asynchronous actor messages and the synchronous method calls to trigger.
JobClient() - Constructor for class org.apache.flink.runtime.client.JobClient
 
JobClientActor - Class in org.apache.flink.runtime.client
Actor which constitutes the bridge between the non-actor code and the JobManager.
JobClientActor(LeaderRetrievalService, FiniteDuration, boolean) - Constructor for class org.apache.flink.runtime.client.JobClientActor
 
JobClientActorConnectionTimeoutException - Exception in org.apache.flink.runtime.client
Exception which is thrown when the JobClientActor wants to submit a job to the job manager but has not found one after a given timeout interval.
JobClientActorConnectionTimeoutException(String) - Constructor for exception org.apache.flink.runtime.client.JobClientActorConnectionTimeoutException
 
JobClientActorConnectionTimeoutException(String, Throwable) - Constructor for exception org.apache.flink.runtime.client.JobClientActorConnectionTimeoutException
 
JobClientActorRegistrationTimeoutException - Exception in org.apache.flink.runtime.client
Exception which is thrown by the JobClientActor if it has not heard back from the job manager after it has attempted to register for a job within a given timeout interval.
JobClientActorRegistrationTimeoutException(String) - Constructor for exception org.apache.flink.runtime.client.JobClientActorRegistrationTimeoutException
 
JobClientActorRegistrationTimeoutException(String, Throwable) - Constructor for exception org.apache.flink.runtime.client.JobClientActorRegistrationTimeoutException
 
JobClientActorSubmissionTimeoutException - Exception in org.apache.flink.runtime.client
Exception which is thrown by the JobClientActor if it has not heard back from the job manager after it has submitted a job to it within a given timeout interval.
JobClientActorSubmissionTimeoutException(String) - Constructor for exception org.apache.flink.runtime.client.JobClientActorSubmissionTimeoutException
 
JobClientActorSubmissionTimeoutException(String, Throwable) - Constructor for exception org.apache.flink.runtime.client.JobClientActorSubmissionTimeoutException
 
JobClientMessages - Class in org.apache.flink.runtime.messages
This object contains the JobClient specific messages
JobClientMessages() - Constructor for class org.apache.flink.runtime.messages.JobClientMessages
 
JobClientMessages$ - Class in org.apache.flink.runtime.messages
This object contains the JobClient specific messages
JobClientMessages$() - Constructor for class org.apache.flink.runtime.messages.JobClientMessages$
 
JobClientMessages.AttachToJobAndWait - Class in org.apache.flink.runtime.messages
This message is sent to the JobClientActor to ask it to register at the JobManager and then return once the job execution is complete.
JobClientMessages.AttachToJobAndWait$ - Class in org.apache.flink.runtime.messages
 
JobClientMessages.ConnectionTimeout - Class in org.apache.flink.runtime.messages
Message which is triggered when the connection timeout has been reached.
JobClientMessages.ConnectionTimeout$ - Class in org.apache.flink.runtime.messages
 
JobClientMessages.JobManagerActorRef - Class in org.apache.flink.runtime.messages
Notifies the JobClientActor about the ActorRef of the new leader.
JobClientMessages.JobManagerActorRef$ - Class in org.apache.flink.runtime.messages
 
JobClientMessages.JobManagerLeaderAddress - Class in org.apache.flink.runtime.messages
Notifies the JobClientActor about a new leader address and a leader session ID.
JobClientMessages.JobManagerLeaderAddress$ - Class in org.apache.flink.runtime.messages
 
JobClientMessages.RegistrationTimeout$ - Class in org.apache.flink.runtime.messages
Message which is triggered when the JobClient registration at the JobManager times out
JobClientMessages.SubmissionTimeout$ - Class in org.apache.flink.runtime.messages
Message which is triggered when the submission timeout has been reached.
JobClientMessages.SubmitJobAndWait - Class in org.apache.flink.runtime.messages
This message is sent to the JobClientActor (via ask) to submit a job and get a response when the job execution has finished.
JobClientMessages.SubmitJobAndWait$ - Class in org.apache.flink.runtime.messages
 
jobConf - Variable in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
 
JobConfigHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Request handler that returns the execution config of a job.
JobConfigHandler(ExecutionGraphHolder) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JobConfigHandler
 
JobConfigHandler.JobConfigJsonArchivist - Class in org.apache.flink.runtime.webmonitor.handlers
 
JobConfigJsonArchivist() - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JobConfigHandler.JobConfigJsonArchivist
 
JobDetails - Class in org.apache.flink.runtime.messages.webmonitor
An actor message with a detailed overview of the current status of a job.
JobDetails(JobID, String, long, long, JobStatus, long, int[], int) - Constructor for class org.apache.flink.runtime.messages.webmonitor.JobDetails
 
JobDetailsHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Request handler that returns details about a job, including: Dataflow plan id, name, and current status start time, end time, duration number of job vertices in each state (pending, running, finished, failed) info about job vertices, including runtime, status, I/O bytes and records, subtasks in each status
JobDetailsHandler(ExecutionGraphHolder, MetricFetcher) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JobDetailsHandler
 
JobDetailsHandler.JobDetailsJsonArchivist - Class in org.apache.flink.runtime.webmonitor.handlers
 
JobDetailsJsonArchivist() - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JobDetailsHandler.JobDetailsJsonArchivist
 
JobEdge - Class in org.apache.flink.runtime.jobgraph
This class represent edges (communication channels) in a job graph.
JobEdge(IntermediateDataSet, JobVertex, DistributionPattern) - Constructor for class org.apache.flink.runtime.jobgraph.JobEdge
Constructs a new job edge, that connects an intermediate result to a consumer task.
JobEdge(IntermediateDataSetID, JobVertex, DistributionPattern) - Constructor for class org.apache.flink.runtime.jobgraph.JobEdge
Constructs a new job edge that refers to an intermediate result via the Id, rather than directly through the intermediate data set structure.
JobException - Exception in org.apache.flink.runtime
 
JobException(String) - Constructor for exception org.apache.flink.runtime.JobException
 
JobException(String, Throwable) - Constructor for exception org.apache.flink.runtime.JobException
 
JobExceptionsHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Request handler that returns the configuration of a job.
JobExceptionsHandler(ExecutionGraphHolder) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JobExceptionsHandler
 
JobExceptionsHandler.JobExceptionsJsonArchivist - Class in org.apache.flink.runtime.webmonitor.handlers
 
JobExceptionsJsonArchivist() - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JobExceptionsHandler.JobExceptionsJsonArchivist
 
JobExecutionException - Exception in org.apache.flink.runtime.client
This exception is the base exception for all exceptions that denote any failure during the execution of a job.
JobExecutionException(JobID, String, Throwable) - Constructor for exception org.apache.flink.runtime.client.JobExecutionException
Constructs a new job execution exception.
JobExecutionException(JobID, String) - Constructor for exception org.apache.flink.runtime.client.JobExecutionException
 
JobExecutionException(JobID, Throwable) - Constructor for exception org.apache.flink.runtime.client.JobExecutionException
 
JobExecutionResult - Class in org.apache.flink.api.common
The result of a job execution.
JobExecutionResult(JobID, long, Map<String, Object>) - Constructor for class org.apache.flink.api.common.JobExecutionResult
Creates a new JobExecutionResult.
jobFailed(Throwable) - Method in interface org.apache.flink.runtime.jobmanager.OnCompletionActions
 
jobFailed(Throwable) - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
Job completion notification triggered by JobManager
jobFailed(Throwable) - Method in class org.apache.flink.yarn.YarnFlinkApplicationMasterRunner
Job completion notification triggered by JobManager
jobFinished(JobExecutionResult) - Method in interface org.apache.flink.runtime.jobmanager.OnCompletionActions
 
jobFinished(JobExecutionResult) - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
Job completion notification triggered by JobManager
jobFinished(JobExecutionResult) - Method in class org.apache.flink.yarn.YarnFlinkApplicationMasterRunner
Job completion notification triggered by JobManager
jobFinishedByOther() - Method in interface org.apache.flink.runtime.jobmanager.OnCompletionActions
 
jobFinishedByOther() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
Job completion notification triggered by self
jobFinishedByOther() - Method in class org.apache.flink.yarn.YarnFlinkApplicationMasterRunner
Job completion notification triggered by self
JobFound(JobID, AccessExecutionGraph) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.JobFound
 
JobFound$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.JobFound$
 
JobGraph - Class in org.apache.flink.runtime.jobgraph
The JobGraph represents a Flink dataflow program, at the low level that the JobManager accepts.
JobGraph(String) - Constructor for class org.apache.flink.runtime.jobgraph.JobGraph
Constructs a new job graph with the given name, the given ExecutionConfig, and a random job ID.
JobGraph(JobID, String) - Constructor for class org.apache.flink.runtime.jobgraph.JobGraph
Constructs a new job graph with the given job ID (or a random ID, if null is passed), the given name and the given execution configuration (see ExecutionConfig).
JobGraph(JobVertex...) - Constructor for class org.apache.flink.runtime.jobgraph.JobGraph
Constructs a new job graph with no name, a random job ID, the given ExecutionConfig, and the given job vertices.
JobGraph(String, JobVertex...) - Constructor for class org.apache.flink.runtime.jobgraph.JobGraph
Constructs a new job graph with the given name, the given ExecutionConfig, a random job ID, and the given job vertices.
JobGraph(JobID, String, JobVertex...) - Constructor for class org.apache.flink.runtime.jobgraph.JobGraph
Constructs a new job graph with the given name, the given ExecutionConfig, the given jobId or a random one if null supplied, and the given job vertices.
jobGraph() - Method in class org.apache.flink.runtime.messages.JobClientMessages.SubmitJobAndWait
 
jobGraph() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.SubmitJob
 
JobGraphGenerator - Class in org.apache.flink.optimizer.plantranslate
This component translates the optimizer's resulting OptimizedPlan to a JobGraph.
JobGraphGenerator() - Constructor for class org.apache.flink.optimizer.plantranslate.JobGraphGenerator
Creates a new job graph generator that uses the default values for its resource configuration.
JobGraphGenerator(Configuration) - Constructor for class org.apache.flink.optimizer.plantranslate.JobGraphGenerator
 
JobID - Class in org.apache.flink.api.common
Unique (at least statistically unique) identifier for a Flink Job.
JobID() - Constructor for class org.apache.flink.api.common.JobID
Creates a new (statistically) random JobID.
JobID(long, long) - Constructor for class org.apache.flink.api.common.JobID
Creates a new JobID, using the given lower and upper parts.
JobID(byte[]) - Constructor for class org.apache.flink.api.common.JobID
Creates a new JobID from the given byte sequence.
jobID - Variable in class org.apache.flink.api.java.ExecutionEnvironment
The ID of the session, defined by this execution environment.
jobID - Variable in class org.apache.flink.runtime.accumulators.AccumulatorRegistry
 
jobId() - Method in class org.apache.flink.runtime.clusterframework.messages.ShutdownClusterAfterJob
 
jobID() - Method in interface org.apache.flink.runtime.messages.accumulators.AccumulatorMessage
ID of the job that the accumulator belongs to
jobID() - Method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsErroneous
 
jobID() - Method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsFound
 
jobID() - Method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsNotFound
 
jobID() - Method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultStringsFound
 
jobID() - Method in class org.apache.flink.runtime.messages.accumulators.RequestAccumulatorResults
 
jobID() - Method in class org.apache.flink.runtime.messages.accumulators.RequestAccumulatorResultsStringified
 
jobID() - Method in class org.apache.flink.runtime.messages.ArchiveMessages.ArchiveExecutionGraph
 
jobID() - Method in class org.apache.flink.runtime.messages.ArchiveMessages.RequestArchivedJob
 
jobID() - Method in class org.apache.flink.runtime.messages.ExecutionGraphMessages.ExecutionStateChanged
 
jobID() - Method in class org.apache.flink.runtime.messages.ExecutionGraphMessages.JobStatusChanged
 
jobID() - Method in class org.apache.flink.runtime.messages.JobClientMessages.AttachToJobAndWait
 
jobID() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.CancelJob
 
jobID() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.CancelJobWithSavepoint
 
jobID() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.CancellationFailure
 
jobID() - Method in interface org.apache.flink.runtime.messages.JobManagerMessages.CancellationResponse
 
jobID() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.CancellationSuccess
 
jobID() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.CurrentJobStatus
 
jobID() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.JobFound
 
jobID() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.JobNotFound
 
jobID() - Method in interface org.apache.flink.runtime.messages.JobManagerMessages.JobResponse
 
jobID() - Method in interface org.apache.flink.runtime.messages.JobManagerMessages.JobStatusResponse
 
jobId() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.JobSubmitSuccess
 
jobId() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RecoverJob
 
jobID() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RegisterJobClient
 
jobId() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RegisterJobClientSuccess
 
jobID() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RemoveCachedJob
 
jobID() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RemoveJob
 
jobId() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RequestClassloadingProps
 
jobID() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RequestJob
 
jobID() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RequestJobStatus
 
jobID() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RequestNextInputSplit
 
jobId() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RequestPartitionProducerState
 
jobId() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.ScheduleOrUpdateConsumers
 
jobID() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.StopJob
 
jobID() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.StoppingFailure
 
jobID() - Method in interface org.apache.flink.runtime.messages.JobManagerMessages.StoppingResponse
 
jobID() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.StoppingSuccess
 
jobId() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.TriggerSavepoint
 
jobId() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.TriggerSavepointFailure
 
jobId() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.TriggerSavepointSuccess
 
jobID - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobQueryScopeInfo
 
jobID - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
 
jobID - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
 
jobId - Variable in class org.apache.flink.runtime.metrics.groups.JobMetricGroup
The ID of the job represented by this metrics group
jobId() - Method in class org.apache.flink.runtime.metrics.groups.JobMetricGroup
 
jobId - Variable in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
 
jobIdfromPath(String) - Static method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
Returns the JobID from the given path in ZooKeeper.
JobInfo - Class in org.apache.flink.runtime.jobmanager
Utility class to store job information on the JobManager.
JobInfo(ActorRef, ListeningBehaviour, long, long) - Constructor for class org.apache.flink.runtime.jobmanager.JobInfo
 
JobInfo$ - Class in org.apache.flink.runtime.jobmanager
 
JobInfo$() - Constructor for class org.apache.flink.runtime.jobmanager.JobInfo$
 
JobInformation - Class in org.apache.flink.runtime.executiongraph
Container class for job information which is stored in the ExecutionGraph.
JobInformation(JobID, String, SerializedValue<ExecutionConfig>, Configuration, Collection<BlobKey>, Collection<URL>) - Constructor for class org.apache.flink.runtime.executiongraph.JobInformation
 
JobLeaderIdActions - Interface in org.apache.flink.runtime.resourcemanager
Interface for actions called by the JobLeaderIdService.
JobLeaderIdService - Class in org.apache.flink.runtime.resourcemanager
Service which retrieves for a registered job the current job leader id (the leader id of the job manager responsible for the job).
JobLeaderIdService(HighAvailabilityServices, ScheduledExecutor, Time) - Constructor for class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
 
JobLeaderListener - Interface in org.apache.flink.runtime.taskexecutor
Listener for the JobLeaderService.
jobLeaderLostLeadership(JobID, UUID) - Method in interface org.apache.flink.runtime.resourcemanager.JobLeaderIdActions
Callback when a monitored job leader lost its leadership.
jobLeaderLostLeadership(JobID, UUID) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
JobLeaderService - Class in org.apache.flink.runtime.taskexecutor
This service has the responsibility to monitor the job leaders (the job manager which is leader for a given job) for all registered jobs.
JobLeaderService(TaskManagerLocation) - Constructor for class org.apache.flink.runtime.taskexecutor.JobLeaderService
 
JobListeningContext - Class in org.apache.flink.runtime.client
The JobListeningContext holds the state necessary to monitor a running job and receive its results.
JobListeningContext(JobID, Future<Object>, ActorRef, FiniteDuration, ClassLoader, HighAvailabilityServices) - Constructor for class org.apache.flink.runtime.client.JobListeningContext
Constructor to use when the class loader is available.
JobListeningContext(JobID, Future<Object>, ActorRef, FiniteDuration, ActorSystem, Configuration, HighAvailabilityServices) - Constructor for class org.apache.flink.runtime.client.JobListeningContext
Constructor to use when the class loader is not available.
jobManager - Variable in class org.apache.flink.runtime.client.JobClientActor
ActorRef to the current leader
jobManager() - Method in class org.apache.flink.runtime.clusterframework.messages.RegisterResourceManagerSuccessful
 
JobManager - Class in org.apache.flink.runtime.jobmanager
The job manager is responsible for receiving Flink jobs, scheduling the tasks, gathering the job status and managing the task managers.
JobManager(Configuration, ScheduledExecutorService, Executor, InstanceManager, Scheduler, BlobLibraryCacheManager, ActorRef, RestartStrategyFactory, FiniteDuration, LeaderElectionService, SubmittedJobGraphStore, CheckpointRecoveryFactory, FiniteDuration, Option<MetricRegistry>) - Constructor for class org.apache.flink.runtime.jobmanager.JobManager
 
jobManager() - Method in class org.apache.flink.runtime.messages.JobClientMessages.JobManagerActorRef
 
JobManager$ - Class in org.apache.flink.runtime.jobmanager
Job Manager companion object.
JobManager$() - Constructor for class org.apache.flink.runtime.jobmanager.JobManager$
 
JobManagerActorRef(ActorRef) - Constructor for class org.apache.flink.runtime.messages.JobClientMessages.JobManagerActorRef
 
JobManagerActorRef$() - Constructor for class org.apache.flink.runtime.messages.JobClientMessages.JobManagerActorRef$
 
jobManagerActors() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
jobManagerActorSystems() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
jobManagerAddress() - Method in class org.apache.flink.runtime.clusterframework.messages.TriggerRegistrationAtJobManager
 
jobManagerAddress() - Method in class org.apache.flink.runtime.messages.TaskManagerMessages.JobManagerLeaderAddress
 
jobManagerAkkaURL() - Method in class org.apache.flink.yarn.YarnMessages.JobManagerLeaderAddress
 
jobManagerAkkaURL() - Method in class org.apache.flink.yarn.YarnMessages.TriggerApplicationClientRegistration
 
jobManagerClass() - Method in class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
JobManagerCliOptions - Class in org.apache.flink.runtime.jobmanager
The command line parameters passed to the JobManager.
JobManagerCliOptions() - Constructor for class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
 
JobManagerConfigHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Returns the Job Manager's configuration.
JobManagerConfigHandler(Configuration) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JobManagerConfigHandler
 
JobManagerConnection - Class in org.apache.flink.runtime.taskexecutor
Container class for JobManager specific communication utils used by the TaskExecutor.
JobManagerConnection(JobID, ResourceID, JobMasterGateway, UUID, TaskManagerActions, CheckpointResponder, LibraryCacheManager, ResultPartitionConsumableNotifier, PartitionProducerStateChecker) - Constructor for class org.apache.flink.runtime.taskexecutor.JobManagerConnection
 
JobManagerException - Exception in org.apache.flink.runtime.jobmaster
Base exception thrown by the JobMaster.
JobManagerException(String) - Constructor for exception org.apache.flink.runtime.jobmaster.JobManagerException
 
JobManagerException(String, Throwable) - Constructor for exception org.apache.flink.runtime.jobmaster.JobManagerException
 
JobManagerException(Throwable) - Constructor for exception org.apache.flink.runtime.jobmaster.JobManagerException
 
jobManagerGainedLeadership(JobID, JobMasterGateway, UUID, JMTMRegistrationSuccess) - Method in interface org.apache.flink.runtime.taskexecutor.JobLeaderListener
Callback if a job manager has gained leadership for the job identified by the job id and a connection could be established to this job manager.
JobManagerJobMetricGroup - Class in org.apache.flink.runtime.metrics.groups
Special MetricGroup representing everything belonging to a specific job, running on the JobManager.
JobManagerJobMetricGroup(MetricRegistry, JobManagerMetricGroup, JobID, String) - Constructor for class org.apache.flink.runtime.metrics.groups.JobManagerJobMetricGroup
 
JobManagerJobScopeFormat - Class in org.apache.flink.runtime.metrics.scope
The scope format for the JobMetricGroup.
JobManagerJobScopeFormat(String, JobManagerScopeFormat) - Constructor for class org.apache.flink.runtime.metrics.scope.JobManagerJobScopeFormat
 
JobManagerLeaderAddress(String, UUID) - Constructor for class org.apache.flink.runtime.messages.JobClientMessages.JobManagerLeaderAddress
 
JobManagerLeaderAddress(String, UUID) - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages.JobManagerLeaderAddress
 
JobManagerLeaderAddress(String, UUID) - Constructor for class org.apache.flink.yarn.YarnMessages.JobManagerLeaderAddress
 
JobManagerLeaderAddress$() - Constructor for class org.apache.flink.runtime.messages.JobClientMessages.JobManagerLeaderAddress$
 
JobManagerLeaderAddress$() - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages.JobManagerLeaderAddress$
 
JobManagerLeaderAddress$() - Constructor for class org.apache.flink.yarn.YarnMessages.JobManagerLeaderAddress$
 
jobManagerLeaderRetrievalService() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
jobManagerLostLeadership(JobID, UUID) - Method in interface org.apache.flink.runtime.taskexecutor.JobLeaderListener
Callback if the job leader for the job with the given job id lost its leadership.
jobManagerMemory() - Method in class org.apache.flink.api.scala.FlinkShell.YarnConfig
 
JobManagerMessages - Class in org.apache.flink.runtime.messages
The job manager specific actor messages
JobManagerMessages() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages
 
JobManagerMessages$ - Class in org.apache.flink.runtime.messages
The job manager specific actor messages
JobManagerMessages$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages$
 
JobManagerMessages.CancelJob - Class in org.apache.flink.runtime.messages
Cancels a job with the given jobID at the JobManager.
JobManagerMessages.CancelJob$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.CancelJobWithSavepoint - Class in org.apache.flink.runtime.messages
Cancels the job with the given jobID at the JobManager.
JobManagerMessages.CancelJobWithSavepoint$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.CancellationFailure - Class in org.apache.flink.runtime.messages
Denotes a failed job cancellation param: jobID param: cause
JobManagerMessages.CancellationFailure$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.CancellationResponse - Interface in org.apache.flink.runtime.messages
 
JobManagerMessages.CancellationSuccess - Class in org.apache.flink.runtime.messages
Denotes a successful job cancellation param: jobID
JobManagerMessages.CancellationSuccess$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.ClassloadingProps - Class in org.apache.flink.runtime.messages
Response to JobManagerMessages.RequestClassloadingProps param: blobManagerPort The port of the blobManager param: requiredJarFiles The blob keys of the required jar files param: requiredClasspaths The urls of the required classpaths
JobManagerMessages.ClassloadingProps$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.CurrentJobStatus - Class in org.apache.flink.runtime.messages
Denotes the current JobStatus of the job with jobID.
JobManagerMessages.CurrentJobStatus$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.DisposeSavepoint - Class in org.apache.flink.runtime.messages
Disposes a savepoint.
JobManagerMessages.DisposeSavepoint$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.DisposeSavepointFailure - Class in org.apache.flink.runtime.messages
Response after a failed savepoint dispose containing the failure cause.
JobManagerMessages.DisposeSavepointFailure$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.DisposeSavepointSuccess$ - Class in org.apache.flink.runtime.messages
Response after a successful savepoint dispose.
JobManagerMessages.GrantLeadership - Class in org.apache.flink.runtime.messages
Grants leadership to the receiver.
JobManagerMessages.GrantLeadership$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.JobFound - Class in org.apache.flink.runtime.messages
Contains the executionGraph of a job with jobID.
JobManagerMessages.JobFound$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.JobManagerStatus - Interface in org.apache.flink.runtime.messages
Response to RequestJobManagerStatus
JobManagerMessages.JobManagerStatusAlive$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.JobNotFound - Class in org.apache.flink.runtime.messages
Denotes that there is no job with jobID retrievable.
JobManagerMessages.JobNotFound$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.JobResponse - Interface in org.apache.flink.runtime.messages
 
JobManagerMessages.JobResultFailure - Class in org.apache.flink.runtime.messages
Denotes an unsuccessful job execution.
JobManagerMessages.JobResultFailure$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.JobResultMessage - Interface in org.apache.flink.runtime.messages
Denotes messages which contain the result of a completed job execution
JobManagerMessages.JobResultSuccess - Class in org.apache.flink.runtime.messages
Denotes a successful job execution.
JobManagerMessages.JobResultSuccess$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.JobStatusResponse - Interface in org.apache.flink.runtime.messages
 
JobManagerMessages.JobSubmitSuccess - Class in org.apache.flink.runtime.messages
Denotes a successful job submission.
JobManagerMessages.JobSubmitSuccess$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.LeaderSessionMessage - Class in org.apache.flink.runtime.messages
Wrapper class for leader session messages.
JobManagerMessages.LeaderSessionMessage$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.NextInputSplit - Class in org.apache.flink.runtime.messages
Contains the next input split for a task.
JobManagerMessages.NextInputSplit$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.RecoverAllJobs$ - Class in org.apache.flink.runtime.messages
Triggers recovery of all available jobs.
JobManagerMessages.RecoverJob - Class in org.apache.flink.runtime.messages
Triggers the recovery of the job with the given ID.
JobManagerMessages.RecoverJob$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.RecoverSubmittedJob - Class in org.apache.flink.runtime.messages
Triggers the submission of the recovered job
JobManagerMessages.RecoverSubmittedJob$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.RegisteredTaskManagers - Class in org.apache.flink.runtime.messages
Contains the Instance objects of all registered task managers.
JobManagerMessages.RegisteredTaskManagers$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.RegisterJobClient - Class in org.apache.flink.runtime.messages
Registers the sender of the message as the client for the provided job identifier.
JobManagerMessages.RegisterJobClient$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.RegisterJobClientSuccess - Class in org.apache.flink.runtime.messages
Denotes a successful registration of a JobClientActor for a running job param: jobId The job id of the registered job
JobManagerMessages.RegisterJobClientSuccess$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.RemoveCachedJob - Class in org.apache.flink.runtime.messages
Removes the job belonging to the job identifier from the job manager and archives it.
JobManagerMessages.RemoveCachedJob$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.RemoveJob - Class in org.apache.flink.runtime.messages
Triggers the removal of the job with the given job ID
JobManagerMessages.RemoveJob$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.RequestArchive$ - Class in org.apache.flink.runtime.messages
Requests the ActorRef of the archiver
JobManagerMessages.RequestBlobManagerPort$ - Class in org.apache.flink.runtime.messages
Requests the port of the blob manager from the job manager.
JobManagerMessages.RequestClassloadingProps - Class in org.apache.flink.runtime.messages
Requests all entities necessary for reconstructing a job class loader May respond with JobManagerMessages.ClassloadingProps or JobManagerMessages.JobNotFound param: jobId The job id of the registered job
JobManagerMessages.RequestClassloadingProps$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.RequestJob - Class in org.apache.flink.runtime.messages
Requests the execution graph of a specific job identified by jobID.
JobManagerMessages.RequestJob$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.RequestJobManagerStatus$ - Class in org.apache.flink.runtime.messages
Requests the current state of the job manager
JobManagerMessages.RequestJobStatus - Class in org.apache.flink.runtime.messages
Requests the current JobStatus of the job identified by jobID.
JobManagerMessages.RequestJobStatus$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.RequestLeaderSessionID$ - Class in org.apache.flink.runtime.messages
Requests the current leader session ID of the job manager.
JobManagerMessages.RequestNextInputSplit - Class in org.apache.flink.runtime.messages
Requesting next input split for the ExecutionJobVertex of the job specified by jobID.
JobManagerMessages.RequestNextInputSplit$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.RequestNumberRegisteredTaskManager$ - Class in org.apache.flink.runtime.messages
Requests the number of currently registered task manager at the job manager.
JobManagerMessages.RequestPartitionProducerState - Class in org.apache.flink.runtime.messages
Requests the execution state of the execution producing a result partition.
JobManagerMessages.RequestPartitionProducerState$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.RequestRegisteredTaskManagers$ - Class in org.apache.flink.runtime.messages
Requests the instances of all registered task managers.
JobManagerMessages.RequestRunningJobs$ - Class in org.apache.flink.runtime.messages
Requests all currently running jobs from the job manager.
JobManagerMessages.RequestRunningJobsStatus$ - Class in org.apache.flink.runtime.messages
Requests the status of all currently running jobs from the job manager.
JobManagerMessages.RequestStackTrace - Class in org.apache.flink.runtime.messages
Requests stack trace messages of the task manager
JobManagerMessages.RequestStackTrace$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.RequestTaskManagerInstance - Class in org.apache.flink.runtime.messages
Requests the Instance object of the task manager with the given instance ID
JobManagerMessages.RequestTaskManagerInstance$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.RequestTotalNumberOfSlots$ - Class in org.apache.flink.runtime.messages
Requests the maximum number of slots available to the job manager.
JobManagerMessages.RequestWebMonitorPort$ - Class in org.apache.flink.runtime.messages
Request for the WebMonitor port.
JobManagerMessages.ResponseArchive - Class in org.apache.flink.runtime.messages
Response containing the ActorRef of the archiver
JobManagerMessages.ResponseArchive$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.ResponseLeaderSessionID - Class in org.apache.flink.runtime.messages
Response to the RequestLeaderSessionID message.
JobManagerMessages.ResponseLeaderSessionID$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.ResponseWebMonitorPort - Class in org.apache.flink.runtime.messages
Response containing the WebMonitor port.
JobManagerMessages.ResponseWebMonitorPort$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.RevokeLeadership$ - Class in org.apache.flink.runtime.messages
Revokes leadership of the receiver.
JobManagerMessages.RunningJobs - Class in org.apache.flink.runtime.messages
This message is the response to the RequestRunningJobs message.
JobManagerMessages.RunningJobs$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.RunningJobsStatus - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.RunningJobsStatus$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.ScheduleOrUpdateConsumers - Class in org.apache.flink.runtime.messages
Notifies the JobManager about available data for a produced partition.
JobManagerMessages.ScheduleOrUpdateConsumers$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.StopJob - Class in org.apache.flink.runtime.messages
Stops a (streaming) job with the given jobID at the JobManager.
JobManagerMessages.StopJob$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.StoppingFailure - Class in org.apache.flink.runtime.messages
Denotes a failed (streaming) job stopping param: jobID param: cause
JobManagerMessages.StoppingFailure$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.StoppingResponse - Interface in org.apache.flink.runtime.messages
 
JobManagerMessages.StoppingSuccess - Class in org.apache.flink.runtime.messages
Denotes a successful (streaming) job stopping param: jobID
JobManagerMessages.StoppingSuccess$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.SubmitJob - Class in org.apache.flink.runtime.messages
Submits a job to the job manager.
JobManagerMessages.SubmitJob$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.TaskManagerInstance - Class in org.apache.flink.runtime.messages
Returns the Instance object of the requested task manager.
JobManagerMessages.TaskManagerInstance$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.TriggerSavepoint - Class in org.apache.flink.runtime.messages
Triggers a savepoint for the specified job.
JobManagerMessages.TriggerSavepoint$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.TriggerSavepointFailure - Class in org.apache.flink.runtime.messages
Response after a failed savepoint trigger containing the failure cause.
JobManagerMessages.TriggerSavepointFailure$ - Class in org.apache.flink.runtime.messages
 
JobManagerMessages.TriggerSavepointSuccess - Class in org.apache.flink.runtime.messages
Response after a successful savepoint trigger containing the savepoint path.
JobManagerMessages.TriggerSavepointSuccess$ - Class in org.apache.flink.runtime.messages
 
jobManagerMetricGroup() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
JobManagerMetricGroup - Class in org.apache.flink.runtime.metrics.groups
Special MetricGroup representing a JobManager.
JobManagerMetricGroup(MetricRegistry, String) - Constructor for class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
 
JobManagerMetricsHandler - Class in org.apache.flink.runtime.webmonitor.metrics
Request handler that returns for the job manager a list of all available metrics or the values for a set of metrics.
JobManagerMetricsHandler(MetricFetcher) - Constructor for class org.apache.flink.runtime.webmonitor.metrics.JobManagerMetricsHandler
 
JobManagerMetricStore() - Constructor for class org.apache.flink.runtime.webmonitor.metrics.MetricStore.JobManagerMetricStore
 
JobManagerMode - Enum in org.apache.flink.runtime.jobmanager
The startup mode for the JobManager.
JobManagerOptions - Class in org.apache.flink.configuration
Configuration options for the JobManager.
JobManagerQueryScopeInfo() - Constructor for class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobManagerQueryScopeInfo
 
JobManagerQueryScopeInfo(String) - Constructor for class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobManagerQueryScopeInfo
 
JobManagerRegistration - Class in org.apache.flink.runtime.resourcemanager.registration
Container for JobManager related registration information, such as the leader id or the job id.
JobManagerRegistration(JobID, ResourceID, UUID, JobMasterGateway) - Constructor for class org.apache.flink.runtime.resourcemanager.registration.JobManagerRegistration
 
JobManagerRetriever - Class in org.apache.flink.runtime.webmonitor
Retrieves and stores the actor gateway to the current leading JobManager.
JobManagerRetriever(WebMonitor, ActorSystem, FiniteDuration, FiniteDuration) - Constructor for class org.apache.flink.runtime.webmonitor.JobManagerRetriever
 
JobManagerRunner - Class in org.apache.flink.runtime.jobmaster
The runner for the job manager.
JobManagerRunner(ResourceID, JobGraph, Configuration, RpcService, HighAvailabilityServices, HeartbeatServices, OnCompletionActions, FatalErrorHandler) - Constructor for class org.apache.flink.runtime.jobmaster.JobManagerRunner
 
JobManagerRunner(ResourceID, JobGraph, Configuration, RpcService, HighAvailabilityServices, HeartbeatServices, MetricRegistry, OnCompletionActions, FatalErrorHandler) - Constructor for class org.apache.flink.runtime.jobmaster.JobManagerRunner
 
JobManagerRunner(ResourceID, JobGraph, Configuration, RpcService, HighAvailabilityServices, HeartbeatServices, JobManagerServices, MetricRegistry, OnCompletionActions, FatalErrorHandler) - Constructor for class org.apache.flink.runtime.jobmaster.JobManagerRunner
Exceptions that occur while creating the JobManager or JobManagerRunner are directly thrown and not reported to the given FatalErrorHandler.
JobManagerScopeFormat - Class in org.apache.flink.runtime.metrics.scope
The scope format for the JobManagerMetricGroup.
JobManagerScopeFormat(String) - Constructor for class org.apache.flink.runtime.metrics.scope.JobManagerScopeFormat
 
JobManagerServices - Class in org.apache.flink.runtime.jobmaster
Utility class to hold all auxiliary services used by the JobMaster.
JobManagerServices(ScheduledExecutorService, BlobLibraryCacheManager, RestartStrategyFactory, Time) - Constructor for class org.apache.flink.runtime.jobmaster.JobManagerServices
 
JobManagerStatusAlive$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.JobManagerStatusAlive$
 
JobManagerTable - Class in org.apache.flink.runtime.taskexecutor
Container for multiple JobManagerConnection registered under their respective job id.
JobManagerTable() - Constructor for class org.apache.flink.runtime.taskexecutor.JobManagerTable
 
jobManagerURL() - Method in class org.apache.flink.runtime.messages.RegistrationMessages.TriggerTaskManagerRegistration
 
JobMaster - Class in org.apache.flink.runtime.jobmaster
JobMaster implementation.
JobMaster(RpcService, ResourceID, JobGraph, Configuration, HighAvailabilityServices, HeartbeatServices, ScheduledExecutorService, BlobLibraryCacheManager, RestartStrategyFactory, Time, JobManagerMetricGroup, OnCompletionActions, FatalErrorHandler, ClassLoader) - Constructor for class org.apache.flink.runtime.jobmaster.JobMaster
 
JobMasterGateway - Interface in org.apache.flink.runtime.jobmaster
JobMaster rpc gateway interface
JobMasterRegistrationSuccess - Class in org.apache.flink.runtime.jobmaster
Base class for responses from the ResourceManager to a registration attempt by a JobMaster.
JobMasterRegistrationSuccess(long, UUID, ResourceID) - Constructor for class org.apache.flink.runtime.jobmaster.JobMasterRegistrationSuccess
 
JobMetricGroup<C extends ComponentMetricGroup<C>> - Class in org.apache.flink.runtime.metrics.groups
Special abstract MetricGroup representing everything belonging to a specific job.
JobMetricGroup(MetricRegistry, C, JobID, String, String[]) - Constructor for class org.apache.flink.runtime.metrics.groups.JobMetricGroup
 
JobMetricsHandler - Class in org.apache.flink.runtime.webmonitor.metrics
Request handler that returns for a given job a list of all available metrics or the values for a set of metrics.
JobMetricsHandler(MetricFetcher) - Constructor for class org.apache.flink.runtime.webmonitor.metrics.JobMetricsHandler
 
JobMetricStore() - Constructor for class org.apache.flink.runtime.webmonitor.metrics.MetricStore.JobMetricStore
 
jobName - Variable in class org.apache.flink.api.common.Plan
The name of the job.
jobName - Variable in class org.apache.flink.runtime.metrics.groups.JobMetricGroup
The name of the job represented by this metrics group
jobName() - Method in class org.apache.flink.runtime.metrics.groups.JobMetricGroup
 
JobNotFound(JobID) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.JobNotFound
 
JobNotFound$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.JobNotFound$
 
JobPlanHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Request handler that returns the JSON program plan of a job graph.
JobPlanHandler(ExecutionGraphHolder) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JobPlanHandler
 
JobPlanHandler.JobPlanJsonArchivist - Class in org.apache.flink.runtime.webmonitor.handlers
 
JobPlanJsonArchivist() - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JobPlanHandler.JobPlanJsonArchivist
 
jobPollingInterval() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosJobManager
 
jobPollingInterval() - Method in class org.apache.flink.runtime.clusterframework.ContaineredJobManager
 
jobPollingInterval() - Method in class org.apache.flink.yarn.YarnJobManager
 
JobQueryScopeInfo(String) - Constructor for class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobQueryScopeInfo
 
JobQueryScopeInfo(String, String) - Constructor for class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.JobQueryScopeInfo
 
jobRecoveryTimeout() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
JobResultFailure(SerializedThrowable) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.JobResultFailure
 
JobResultFailure$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.JobResultFailure$
 
JobResultSuccess(SerializedJobExecutionResult) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.JobResultSuccess
 
JobResultSuccess$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.JobResultSuccess$
 
JobRetrievalException - Exception in org.apache.flink.runtime.client
Exception used to indicate that a job couldn't be retrieved from the JobManager
JobRetrievalException(JobID, String, Throwable) - Constructor for exception org.apache.flink.runtime.client.JobRetrievalException
 
JobRetrievalException(JobID, String) - Constructor for exception org.apache.flink.runtime.client.JobRetrievalException
 
JobRetrievalException(JobID, Throwable) - Constructor for exception org.apache.flink.runtime.client.JobRetrievalException
 
jobs() - Method in class org.apache.flink.runtime.messages.ArchiveMessages.ArchivedJobs
 
JobsOverview - Class in org.apache.flink.runtime.messages.webmonitor
An overview of how many jobs are in which status.
JobsOverview(int, int, int, int) - Constructor for class org.apache.flink.runtime.messages.webmonitor.JobsOverview
 
JobsOverview(JobsOverview, JobsOverview) - Constructor for class org.apache.flink.runtime.messages.webmonitor.JobsOverview
 
JobStatus - Enum in org.apache.flink.runtime.jobgraph
Possible states of a job once it has been accepted by the job manager.
JobStatusChanged(JobID, JobStatus, long, Throwable) - Constructor for class org.apache.flink.runtime.messages.ExecutionGraphMessages.JobStatusChanged
 
JobStatusChanged$() - Constructor for class org.apache.flink.runtime.messages.ExecutionGraphMessages.JobStatusChanged$
 
jobStatusChanges(JobID, JobStatus, long, Throwable) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinatorDeActivator
 
jobStatusChanges(JobID, JobStatus, long, Throwable) - Method in interface org.apache.flink.runtime.executiongraph.JobStatusListener
This method is called whenever the status of the job changes.
jobStatusChanges(JobID, JobStatus, long, Throwable) - Method in class org.apache.flink.runtime.executiongraph.StatusListenerMessenger
 
JobStatusListener - Interface in org.apache.flink.runtime.executiongraph
Interface for observers that monitor the status of a job.
JobStatusMessage - Class in org.apache.flink.runtime.client
A simple message that holds the state of a job execution.
JobStatusMessage(JobID, String, JobStatus, long) - Constructor for class org.apache.flink.runtime.client.JobStatusMessage
 
JobStoppingHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Request handler for the STOP request.
JobStoppingHandler() - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JobStoppingHandler
 
JobSubmissionClientActor - Class in org.apache.flink.runtime.client
Actor which handles Job submission process and provides Job updates until completion.
JobSubmissionClientActor(LeaderRetrievalService, FiniteDuration, boolean, Configuration) - Constructor for class org.apache.flink.runtime.client.JobSubmissionClientActor
 
JobSubmissionException - Exception in org.apache.flink.runtime.client
This exception denotes an error while submitting a job to the JobManager
JobSubmissionException(JobID, String, Throwable) - Constructor for exception org.apache.flink.runtime.client.JobSubmissionException
 
JobSubmissionException(JobID, String) - Constructor for exception org.apache.flink.runtime.client.JobSubmissionException
 
JobSubmissionResult - Class in org.apache.flink.api.common
The result of submitting a job to a JobManager.
JobSubmissionResult(JobID) - Constructor for class org.apache.flink.api.common.JobSubmissionResult
 
JobSubmitSuccess(JobID) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.JobSubmitSuccess
 
JobSubmitSuccess$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.JobSubmitSuccess$
 
JobsWithIDsOverview - Class in org.apache.flink.runtime.messages.webmonitor
An overview of how many jobs are in which status.
JobsWithIDsOverview(List<JobID>, List<JobID>, List<JobID>, List<JobID>) - Constructor for class org.apache.flink.runtime.messages.webmonitor.JobsWithIDsOverview
 
JobsWithIDsOverview(JobsWithIDsOverview, JobsWithIDsOverview) - Constructor for class org.apache.flink.runtime.messages.webmonitor.JobsWithIDsOverview
 
JobTimeoutException - Exception in org.apache.flink.runtime.client
An exception which is thrown by the JobClient if the job manager is no longer reachable.
JobTimeoutException(JobID, String, Throwable) - Constructor for exception org.apache.flink.runtime.client.JobTimeoutException
 
JobVertex - Class in org.apache.flink.runtime.jobgraph
The base class for job vertexes.
JobVertex(String) - Constructor for class org.apache.flink.runtime.jobgraph.JobVertex
Constructs a new job vertex and assigns it with the given name.
JobVertex(String, JobVertexID) - Constructor for class org.apache.flink.runtime.jobgraph.JobVertex
Constructs a new job vertex and assigns it with the given name.
JobVertex(String, JobVertexID, List<JobVertexID>, List<OperatorID>, List<OperatorID>) - Constructor for class org.apache.flink.runtime.jobgraph.JobVertex
Constructs a new job vertex and assigns it with the given name.
JobVertexAccumulatorsHandler - Class in org.apache.flink.runtime.webmonitor.handlers
 
JobVertexAccumulatorsHandler(ExecutionGraphHolder) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JobVertexAccumulatorsHandler
 
JobVertexAccumulatorsHandler.JobVertexAccumulatorsJsonArchivist - Class in org.apache.flink.runtime.webmonitor.handlers
 
JobVertexAccumulatorsJsonArchivist() - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JobVertexAccumulatorsHandler.JobVertexAccumulatorsJsonArchivist
 
JobVertexBackPressureHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Request handler that returns back pressure stats for a single job vertex and all its sub tasks.
JobVertexBackPressureHandler(ExecutionGraphHolder, BackPressureStatsTracker, int) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JobVertexBackPressureHandler
 
JobVertexDetailsHandler - Class in org.apache.flink.runtime.webmonitor.handlers
A request handler that provides the details of a job vertex, including id, name, parallelism, and the runtime and metrics of all its subtasks.
JobVertexDetailsHandler(ExecutionGraphHolder, MetricFetcher) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JobVertexDetailsHandler
 
JobVertexDetailsHandler.JobVertexDetailsJsonArchivist - Class in org.apache.flink.runtime.webmonitor.handlers
 
JobVertexDetailsJsonArchivist() - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JobVertexDetailsHandler.JobVertexDetailsJsonArchivist
 
JobVertexID - Class in org.apache.flink.runtime.jobgraph
A class for statistically unique job vertex IDs.
JobVertexID() - Constructor for class org.apache.flink.runtime.jobgraph.JobVertexID
 
JobVertexID(byte[]) - Constructor for class org.apache.flink.runtime.jobgraph.JobVertexID
 
JobVertexID(long, long) - Constructor for class org.apache.flink.runtime.jobgraph.JobVertexID
 
JobVertexMetricsHandler - Class in org.apache.flink.runtime.webmonitor.metrics
Request handler that returns for a given task a list of all available metrics or the values for a set of metrics.
JobVertexMetricsHandler(MetricFetcher) - Constructor for class org.apache.flink.runtime.webmonitor.metrics.JobVertexMetricsHandler
 
JobVertexTaskManagersHandler - Class in org.apache.flink.runtime.webmonitor.handlers
A request handler that provides the details of a job vertex, including id, name, and the runtime and metrics of all its subtasks aggregated by TaskManager.
JobVertexTaskManagersHandler(ExecutionGraphHolder, MetricFetcher) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JobVertexTaskManagersHandler
 
JobVertexTaskManagersHandler.JobVertexTaskManagersJsonArchivist - Class in org.apache.flink.runtime.webmonitor.handlers
 
JobVertexTaskManagersJsonArchivist() - Constructor for class org.apache.flink.runtime.webmonitor.handlers.JobVertexTaskManagersHandler.JobVertexTaskManagersJsonArchivist
 
JobWithJars - Class in org.apache.flink.client.program
A JobWithJars is a Flink dataflow plan, together with a bunch of JAR files that contain the classes of the functions and libraries necessary for the execution.
JobWithJars(Plan, List<URL>, List<URL>) - Constructor for class org.apache.flink.client.program.JobWithJars
 
JobWithJars(Plan, URL) - Constructor for class org.apache.flink.client.program.JobWithJars
 
join(IN1, IN2, Collector<OUT>) - Method in interface org.apache.flink.api.common.functions.FlatJoinFunction
The join method, called once per joined pair of elements.
join(IN1, IN2) - Method in interface org.apache.flink.api.common.functions.JoinFunction
The join method, called once per joined pair of elements.
join(IN1, IN2, Collector<OUT>) - Method in class org.apache.flink.api.common.functions.RichFlatJoinFunction
 
join(IN1, IN2) - Method in class org.apache.flink.api.common.functions.RichJoinFunction
 
join(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
Initiates a Join transformation.
join(DataSet<R>, JoinOperatorBase.JoinHint) - Method in class org.apache.flink.api.java.DataSet
Initiates a Join transformation.
join(T1, T2, Collector<Tuple2<T1, T2>>) - Method in class org.apache.flink.api.java.operators.JoinOperator.DefaultFlatJoinFunction
 
join(IN1, IN2, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.JoinOperator.DefaultJoin.WrappingFlatJoinFunction
 
join(T1, T2, Collector<R>) - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectFlatJoinFunction
 
join(Tuple2<K, I1>, I2, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.TupleLeftUnwrappingJoiner
 
join(I1, Tuple2<K, I2>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.TupleRightUnwrappingJoiner
 
join(Tuple2<K, I1>, Tuple2<K, I2>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingJoiner
 
join(DataSet<O>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
join(DataSet<O>, JoinOperatorBase.JoinHint) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
join(DataSet<O>) - Method in class org.apache.flink.api.scala.DataSet
Creates a new DataSet by joining this DataSet with the other DataSet.
join(DataSet<O>, JoinOperatorBase.JoinHint) - Method in class org.apache.flink.api.scala.DataSet
Special join operation for explicitly telling the system what join strategy to use.
join(Tuple2<Long, Long>, Tuple2<Long, Long>, Collector<Tuple2<Long, Long>>) - Method in class org.apache.flink.examples.java.graph.ConnectedComponents.ComponentIdFilter
 
join(Tuple2<Long, Long>, Tuple2<Long, Long>) - Method in class org.apache.flink.examples.java.graph.ConnectedComponents.NeighborWithComponentIDJoin
 
join(Edge<K, Tuple2<EV, D>>, Vertex<K, D>) - Method in class org.apache.flink.graph.asm.degree.annotate.DegreeAnnotationFunctions.JoinEdgeDegreeWithVertexDegree
 
join(Edge<K, EV>, Vertex<K, D>) - Method in class org.apache.flink.graph.asm.degree.annotate.DegreeAnnotationFunctions.JoinEdgeWithVertexDegree
 
join(Vertex<K, VV>, Vertex<K, LongValue>) - Method in class org.apache.flink.graph.asm.degree.annotate.DegreeAnnotationFunctions.JoinVertexWithVertexDegree
 
join(DataStream<T2>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Creates a join operation.
join(DataStream<T2>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Creates a join operation.
join(Table) - Method in class org.apache.flink.table.api.Table
Joins two Tables.
join(Table, String) - Method in class org.apache.flink.table.api.Table
Joins two Tables.
join(Table, Expression) - Method in class org.apache.flink.table.api.Table
Joins two Tables.
join(JoinRelType, RexNode, RexNode[]) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
join(JoinRelType, Iterable<? extends RexNode>) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
join(JoinRelType, RexNode) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
join(JoinRelType, RexNode, Set<CorrelationId>) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
join(JoinRelType, String[]) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
Join - Class in org.apache.flink.table.plan.logical
 
Join(LogicalNode, LogicalNode, JoinType, Option<Expression>, boolean) - Constructor for class org.apache.flink.table.plan.logical.Join
 
join(IN1, IN2, Collector<OUT>) - Method in class org.apache.flink.table.runtime.FlatJoinRunner
 
Join$ - Class in org.apache.flink.table.plan.logical
 
Join$() - Constructor for class org.apache.flink.table.plan.logical.Join$
 
JoinDataSet<L,R> - Class in org.apache.flink.api.scala
A specific DataSet that results from a join operation.
JoinDataSet(JoinOperator.EquiJoin<L, R, Tuple2<L, R>>, DataSet<L>, DataSet<R>, Keys<L>, Keys<R>) - Constructor for class org.apache.flink.api.scala.JoinDataSet
 
JoinDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
The join driver implements the logic of a join operator at runtime.
JoinDriver() - Constructor for class org.apache.flink.runtime.operators.JoinDriver
 
JoinEdgeDegreeWithVertexDegree() - Constructor for class org.apache.flink.graph.asm.degree.annotate.DegreeAnnotationFunctions.JoinEdgeDegreeWithVertexDegree
 
JoinEdgeWithVertexDegree() - Constructor for class org.apache.flink.graph.asm.degree.annotate.DegreeAnnotationFunctions.JoinEdgeWithVertexDegree
 
joinedPathsVector - Variable in class org.apache.flink.optimizer.dag.OptimizerNode.UnclosedBranchDescriptor
 
JoinedStreams<T1,T2> - Class in org.apache.flink.streaming.api.datastream
JoinedStreams represents two DataStreams that have been joined.
JoinedStreams(DataStream<T1>, DataStream<T2>) - Constructor for class org.apache.flink.streaming.api.datastream.JoinedStreams
Creates new JoinedStreams data streams, which are the first step towards building a streaming co-group.
JoinedStreams<T1,T2> - Class in org.apache.flink.streaming.api.scala
JoinedStreams represents two DataStreams that have been joined.
JoinedStreams(DataStream<T1>, DataStream<T2>) - Constructor for class org.apache.flink.streaming.api.scala.JoinedStreams
 
JoinedStreams.Where<KEY> - Class in org.apache.flink.streaming.api.datastream
Joined streams that have the key for one side defined.
JoinedStreams.Where<KEY> - Class in org.apache.flink.streaming.api.scala
A join operation that has a KeySelector defined for the first input.
JoinedStreams.Where.EqualTo - Class in org.apache.flink.streaming.api.datastream
A join operation that has KeySelectors defined for both inputs.
JoinedStreams.Where.EqualTo - Class in org.apache.flink.streaming.api.scala
A join operation that has a KeySelector defined for the first and the second input.
JoinedStreams.Where.EqualTo.WithWindow<W extends Window> - Class in org.apache.flink.streaming.api.scala
A join operation that has KeySelectors defined for both inputs as well as a WindowAssigner.
JoinedStreams.WithWindow<T1,T2,KEY,W extends Window> - Class in org.apache.flink.streaming.api.datastream
A join operation that has KeySelectors defined for both inputs as well as a WindowAssigner.
JoinFunction<IN1,IN2,OUT> - Interface in org.apache.flink.api.common.functions
Interface for Join functions.
JoinFunctionAssigner<I1,I2> - Interface in org.apache.flink.api.java.operators.join
A Join transformation that needs to be finished by specifying either a JoinFunction or a FlatJoinFunction before it can be used as an input to other operators.
JoinFunctionAssigner<L,R> - Interface in org.apache.flink.api.scala
 
JoinHashMap<BT> - Class in org.apache.flink.api.common.operators.util
 
JoinHashMap(TypeSerializer<BT>, TypeComparator<BT>) - Constructor for class org.apache.flink.api.common.operators.util.JoinHashMap
 
JoinHashMap.Prober<PT> - Class in org.apache.flink.api.common.operators.util
 
joinHint - Variable in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
 
joinHint() - Method in class org.apache.flink.api.scala.UnfinishedJoinOperationBase
 
JoinNode - Class in org.apache.flink.optimizer.dag
The Optimizer representation of a join operator.
JoinNode(InnerJoinOperatorBase<?, ?, ?, ?>) - Constructor for class org.apache.flink.optimizer.dag.JoinNode
Creates a new JoinNode for the given join operator.
JoinOperator<I1,I2,OUT> - Class in org.apache.flink.api.java.operators
A DataSet that is the result of a Join transformation.
JoinOperator(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, TypeInformation<OUT>, JoinOperatorBase.JoinHint, JoinType) - Constructor for class org.apache.flink.api.java.operators.JoinOperator
 
JoinOperator.DefaultFlatJoinFunction<T1,T2> - Class in org.apache.flink.api.java.operators
 
JoinOperator.DefaultJoin<I1,I2> - Class in org.apache.flink.api.java.operators
A Join transformation that wraps pairs of joining elements into Tuple2.
It also represents the DataSet that is the result of a Join transformation.
JoinOperator.DefaultJoin.WrappingFlatJoinFunction<IN1,IN2,OUT> - Class in org.apache.flink.api.java.operators
 
JoinOperator.EquiJoin<I1,I2,OUT> - Class in org.apache.flink.api.java.operators
A Join transformation that applies a JoinFunction on each pair of joining elements.
It also represents the DataSet that is the result of a Join transformation.
JoinOperator.JoinOperatorSets<I1,I2> - Class in org.apache.flink.api.java.operators
Intermediate step of a Join transformation.
JoinOperator.JoinOperatorSets.JoinOperatorSetsPredicate - Class in org.apache.flink.api.java.operators
Intermediate step of a Join transformation.
JoinOperator.JoinProjection<I1,I2> - Class in org.apache.flink.api.java.operators
 
JoinOperator.ProjectFlatJoinFunction<T1,T2,R extends Tuple> - Class in org.apache.flink.api.java.operators
 
JoinOperator.ProjectJoin<I1,I2,OUT extends Tuple> - Class in org.apache.flink.api.java.operators
A Join transformation that projects joining elements or fields of joining Tuples into result Tuples.
JoinOperatorBase<IN1,IN2,OUT,FT extends FlatJoinFunction<IN1,IN2,OUT>> - Class in org.apache.flink.api.common.operators.base
 
JoinOperatorBase(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.JoinOperatorBase
 
JoinOperatorBase(FT, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.JoinOperatorBase
 
JoinOperatorBase(Class<? extends FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String) - Constructor for class org.apache.flink.api.common.operators.base.JoinOperatorBase
 
JoinOperatorBase.JoinHint - Enum in org.apache.flink.api.common.operators.base
An enumeration of hints, optionally usable to tell the system how exactly execute the join.
JoinOperatorSets(DataSet<I1>, DataSet<I2>) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets
 
JoinOperatorSets(DataSet<I1>, DataSet<I2>, JoinOperatorBase.JoinHint) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets
 
JoinOperatorSetsBase<I1,I2> - Class in org.apache.flink.api.java.operators.join
Intermediate step of an Outer Join transformation.
JoinOperatorSetsBase(DataSet<I1>, DataSet<I2>) - Constructor for class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
 
JoinOperatorSetsBase(DataSet<I1>, DataSet<I2>, JoinOperatorBase.JoinHint) - Constructor for class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
 
JoinOperatorSetsBase(DataSet<I1>, DataSet<I2>, JoinOperatorBase.JoinHint, JoinType) - Constructor for class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
 
JoinOperatorSetsBase.JoinOperatorSetsPredicateBase - Class in org.apache.flink.api.java.operators.join
Intermediate step of a Join transformation.
JoinOperatorSetsPredicateBase(Keys<I1>) - Constructor for class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
 
JoinProjection(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, JoinOperatorBase.JoinHint, int[], int[]) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
 
joinStreams(DataStream<WindowJoin.Grade>, DataStream<WindowJoin.Salary>, long) - Method in class org.apache.flink.streaming.scala.examples.join.WindowJoin$
 
joinStreams(DataStream<WindowJoin.Grade>, DataStream<WindowJoin.Salary>, long) - Static method in class org.apache.flink.streaming.scala.examples.join.WindowJoin
 
JoinTaskIterator<V1,V2,O> - Interface in org.apache.flink.runtime.operators.util
Interface of an iterator that performs the logic of a match task.
joinType - Variable in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
 
JoinType - Enum in org.apache.flink.api.java.operators.join
 
joinType - Variable in class org.apache.flink.api.java.operators.JoinOperator
 
joinType() - Method in class org.apache.flink.api.scala.UnfinishedJoinOperationBase
 
joinType() - Method in class org.apache.flink.table.plan.logical.Join
 
JoinVertexWithEdgesMatch() - Constructor for class org.apache.flink.examples.java.graph.PageRank.JoinVertexWithEdgesMatch
 
JoinVertexWithVertexDegree() - Constructor for class org.apache.flink.graph.asm.degree.annotate.DegreeAnnotationFunctions.JoinVertexWithVertexDegree
 
joinWithEdges(DataSet<Tuple3<K, K, T>>, EdgeJoinFunction<EV, T>) - Method in class org.apache.flink.graph.Graph
Joins the edge DataSet with an input DataSet on the composite key of both source and target IDs and applies a user-defined transformation on the values of the matched records.
joinWithEdges(DataSet<Tuple3<K, K, T>>, EdgeJoinFunction<EV, T>, TypeInformation<T>) - Method in class org.apache.flink.graph.scala.Graph
Joins the edge DataSet with an input DataSet on the composite key of both source and target IDs and applies a user-defined transformation on the values of the matched records.
joinWithEdges(DataSet<Tuple3<K, K, T>>, Function2<EV, T, EV>, TypeInformation<T>) - Method in class org.apache.flink.graph.scala.Graph
Joins the edge DataSet with an input DataSet on the composite key of both source and target IDs and applies a user-defined transformation on the values of the matched records.
joinWithEdgesOnSource(DataSet<Tuple2<K, T>>, EdgeJoinFunction<EV, T>) - Method in class org.apache.flink.graph.Graph
Joins the edge DataSet with an input Tuple2 DataSet and applies a user-defined transformation on the values of the matched records.
joinWithEdgesOnSource(DataSet<Tuple2<K, T>>, EdgeJoinFunction<EV, T>, TypeInformation<T>) - Method in class org.apache.flink.graph.scala.Graph
Joins the edge DataSet with an input Tuple2 DataSet and applies a user-defined transformation on the values of the matched records.
joinWithEdgesOnSource(DataSet<Tuple2<K, T>>, Function2<EV, T, EV>, TypeInformation<T>) - Method in class org.apache.flink.graph.scala.Graph
Joins the edge DataSet with an input Tuple2 DataSet and applies a user-defined transformation on the values of the matched records.
joinWithEdgesOnTarget(DataSet<Tuple2<K, T>>, EdgeJoinFunction<EV, T>) - Method in class org.apache.flink.graph.Graph
Joins the edge DataSet with an input Tuple2 DataSet and applies a user-defined transformation on the values of the matched records.
joinWithEdgesOnTarget(DataSet<Tuple2<K, T>>, EdgeJoinFunction<EV, T>, TypeInformation<T>) - Method in class org.apache.flink.graph.scala.Graph
Joins the edge DataSet with an input Tuple2 DataSet and applies a user-defined transformation on the values of the matched records.
joinWithEdgesOnTarget(DataSet<Tuple2<K, T>>, Function2<EV, T, EV>, TypeInformation<T>) - Method in class org.apache.flink.graph.scala.Graph
Joins the edge DataSet with an input Tuple2 DataSet and applies a user-defined transformation on the values of the matched records.
joinWithHuge(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
Initiates a Join transformation.
A Join transformation joins the elements of two DataSets on key equality and provides multiple ways to combine joining elements into one DataSet.
This method also gives the hint to the optimizer that the second DataSet to join is much larger than the first one.
This method returns a JoinOperator.JoinOperatorSets on which one of the where methods can be called to define the join key of the first joining (i.e., this) DataSet.
joinWithHuge(DataSet<O>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
joinWithHuge(DataSet<O>) - Method in class org.apache.flink.api.scala.DataSet
Special join operation for explicitly telling the system that the left side is assumed to be a lot smaller than the right side of the join.
JoinWithSolutionSetFirstDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
 
JoinWithSolutionSetFirstDriver() - Constructor for class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
 
JoinWithSolutionSetSecondDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
 
JoinWithSolutionSetSecondDriver() - Constructor for class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
 
joinWithTiny(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
Initiates a Join transformation.
joinWithTiny(DataSet<O>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
joinWithTiny(DataSet<O>) - Method in class org.apache.flink.api.scala.DataSet
Special join operation for explicitly telling the system that the right side is assumed to be a lot smaller than the left side of the join.
joinWithVertices(DataSet<Tuple2<K, T>>, VertexJoinFunction<VV, T>) - Method in class org.apache.flink.graph.Graph
Joins the vertex DataSet of this graph with an input Tuple2 DataSet and applies a user-defined transformation on the values of the matched records.
joinWithVertices(DataSet<Tuple2<K, T>>, VertexJoinFunction<VV, T>, TypeInformation<T>) - Method in class org.apache.flink.graph.scala.Graph
Joins the vertex DataSet of this graph with an input Tuple2 DataSet and applies a user-defined transformation on the values of the matched records.
joinWithVertices(DataSet<Tuple2<K, T>>, Function2<VV, T, VV>, TypeInformation<T>) - Method in class org.apache.flink.graph.scala.Graph
Joins the vertex DataSet of this graph with an input Tuple2 DataSet and applies a user-defined transformation on the values of the matched records.
JsonArchivist - Interface in org.apache.flink.runtime.webmonitor.history
Interface for all classes that want to participate in the archiving of job-related json responses.
JSONDeserializationSchema - Class in org.apache.flink.streaming.util.serialization
DeserializationSchema that deserializes a JSON String into an ObjectNode.
JSONDeserializationSchema() - Constructor for class org.apache.flink.streaming.util.serialization.JSONDeserializationSchema
 
JsonFactory - Class in org.apache.flink.runtime.webmonitor.handlers
A holder for the singleton Jackson JSON factory.
JSONGenerator - Class in org.apache.flink.streaming.api.graph
Helper class for generating a JSON representation from a StreamGraph.
JSONGenerator(StreamGraph) - Constructor for class org.apache.flink.streaming.api.graph.JSONGenerator
 
JSONKeyValueDeserializationSchema - Class in org.apache.flink.streaming.util.serialization
DeserializationSchema that deserializes a JSON String into an ObjectNode.
JSONKeyValueDeserializationSchema(boolean) - Constructor for class org.apache.flink.streaming.util.serialization.JSONKeyValueDeserializationSchema
 
JsonMapper - Class in org.apache.flink.optimizer.plantranslate
 
JsonMapper() - Constructor for class org.apache.flink.optimizer.plantranslate.JsonMapper
 
JsonPlanGenerator - Class in org.apache.flink.runtime.jobgraph.jsonplan
 
JsonPlanGenerator() - Constructor for class org.apache.flink.runtime.jobgraph.jsonplan.JsonPlanGenerator
 
JsonRowDeserializationSchema - Class in org.apache.flink.streaming.util.serialization
Deserialization schema from JSON to Row.
JsonRowDeserializationSchema(TypeInformation<Row>) - Constructor for class org.apache.flink.streaming.util.serialization.JsonRowDeserializationSchema
Creates a JSON deserialization schema for the given fields and types.
JsonRowSerializationSchema - Class in org.apache.flink.streaming.util.serialization
Serialization schema that serializes an object into a JSON bytes.
JsonRowSerializationSchema(String[]) - Constructor for class org.apache.flink.streaming.util.serialization.JsonRowSerializationSchema
Creates a JSON serialization schema for the given fields and types.
JvmShutdownSafeguard - Class in org.apache.flink.runtime.util
A utility that guards against blocking shutdown hooks that block JVM shutdown.

K

K$() - Constructor for class org.apache.flink.ml.nn.KNN.K$
 
Kafka010AvroTableSource - Class in org.apache.flink.streaming.connectors.kafka
Kafka StreamTableSource for Kafka 0.10.
Kafka010AvroTableSource(String, Properties, Class<? extends SpecificRecordBase>) - Constructor for class org.apache.flink.streaming.connectors.kafka.Kafka010AvroTableSource
Creates a Kafka 0.10 Avro StreamTableSource using a given SpecificRecord.
Kafka010Fetcher<T> - Class in org.apache.flink.streaming.connectors.kafka.internal
A fetcher that fetches data from Kafka brokers via the Kafka 0.10 consumer API.
Kafka010Fetcher(SourceFunction.SourceContext<T>, Map<KafkaTopicPartition, Long>, SerializedValue<AssignerWithPeriodicWatermarks<T>>, SerializedValue<AssignerWithPunctuatedWatermarks<T>>, ProcessingTimeService, long, ClassLoader, String, MetricGroup, KeyedDeserializationSchema<T>, Properties, long, boolean) - Constructor for class org.apache.flink.streaming.connectors.kafka.internal.Kafka010Fetcher
 
Kafka010JsonTableSource - Class in org.apache.flink.streaming.connectors.kafka
Kafka StreamTableSource for Kafka 0.10.
Kafka010JsonTableSource(String, Properties, TypeInformation<Row>) - Constructor for class org.apache.flink.streaming.connectors.kafka.Kafka010JsonTableSource
Creates a Kafka 0.10 JSON StreamTableSource.
Kafka010TableSource - Class in org.apache.flink.streaming.connectors.kafka
Kafka StreamTableSource for Kafka 0.10.
Kafka010TableSource(String, Properties, DeserializationSchema<Row>, TypeInformation<Row>) - Constructor for class org.apache.flink.streaming.connectors.kafka.Kafka010TableSource
Creates a Kafka 0.10 StreamTableSource.
Kafka08AvroTableSource - Class in org.apache.flink.streaming.connectors.kafka
Kafka StreamTableSource for Kafka 0.8.
Kafka08AvroTableSource(String, Properties, Class<? extends SpecificRecordBase>) - Constructor for class org.apache.flink.streaming.connectors.kafka.Kafka08AvroTableSource
Creates a Kafka 0.8 Avro StreamTableSource using a given SpecificRecord.
Kafka08Fetcher<T> - Class in org.apache.flink.streaming.connectors.kafka.internals
A fetcher that fetches data from Kafka brokers via the Kafka 0.8 low-level consumer API.
Kafka08Fetcher(SourceFunction.SourceContext<T>, Map<KafkaTopicPartition, Long>, SerializedValue<AssignerWithPeriodicWatermarks<T>>, SerializedValue<AssignerWithPunctuatedWatermarks<T>>, StreamingRuntimeContext, KeyedDeserializationSchema<T>, Properties, long, boolean) - Constructor for class org.apache.flink.streaming.connectors.kafka.internals.Kafka08Fetcher
 
Kafka08JsonTableSink - Class in org.apache.flink.streaming.connectors.kafka
Kafka 0.8 KafkaTableSink that serializes data in JSON format.
Kafka08JsonTableSink(String, Properties, FlinkKafkaPartitioner<Row>) - Constructor for class org.apache.flink.streaming.connectors.kafka.Kafka08JsonTableSink
Creates KafkaTableSink for Kafka 0.8
Kafka08JsonTableSink(String, Properties, KafkaPartitioner<Row>) - Constructor for class org.apache.flink.streaming.connectors.kafka.Kafka08JsonTableSink
Deprecated.
This is a deprecated constructor that does not correctly handle partitioning when producing to multiple topics. Use Kafka08JsonTableSink.Kafka08JsonTableSink(String, Properties, FlinkKafkaPartitioner) instead.
Kafka08JsonTableSource - Class in org.apache.flink.streaming.connectors.kafka
Kafka StreamTableSource for Kafka 0.8.
Kafka08JsonTableSource(String, Properties, TypeInformation<Row>) - Constructor for class org.apache.flink.streaming.connectors.kafka.Kafka08JsonTableSource
Creates a Kafka 0.8 JSON StreamTableSource.
Kafka08TableSource - Class in org.apache.flink.streaming.connectors.kafka
Kafka StreamTableSource for Kafka 0.8.
Kafka08TableSource(String, Properties, DeserializationSchema<Row>, TypeInformation<Row>) - Constructor for class org.apache.flink.streaming.connectors.kafka.Kafka08TableSource
Creates a Kafka 0.8 StreamTableSource.
Kafka09AvroTableSource - Class in org.apache.flink.streaming.connectors.kafka
Kafka StreamTableSource for Kafka 0.9.
Kafka09AvroTableSource(String, Properties, Class<? extends SpecificRecordBase>) - Constructor for class org.apache.flink.streaming.connectors.kafka.Kafka09AvroTableSource
Creates a Kafka 0.9 Avro StreamTableSource using a given SpecificRecord.
Kafka09Fetcher<T> - Class in org.apache.flink.streaming.connectors.kafka.internal
A fetcher that fetches data from Kafka brokers via the Kafka 0.9 consumer API.
Kafka09Fetcher(SourceFunction.SourceContext<T>, Map<KafkaTopicPartition, Long>, SerializedValue<AssignerWithPeriodicWatermarks<T>>, SerializedValue<AssignerWithPunctuatedWatermarks<T>>, ProcessingTimeService, long, ClassLoader, String, MetricGroup, KeyedDeserializationSchema<T>, Properties, long, boolean) - Constructor for class org.apache.flink.streaming.connectors.kafka.internal.Kafka09Fetcher
 
Kafka09JsonTableSink - Class in org.apache.flink.streaming.connectors.kafka
Kafka 0.9 KafkaTableSink that serializes data in JSON format.
Kafka09JsonTableSink(String, Properties, FlinkKafkaPartitioner<Row>) - Constructor for class org.apache.flink.streaming.connectors.kafka.Kafka09JsonTableSink
Creates KafkaTableSink for Kafka 0.9
Kafka09JsonTableSink(String, Properties, KafkaPartitioner<Row>) - Constructor for class org.apache.flink.streaming.connectors.kafka.Kafka09JsonTableSink
Deprecated.
This is a deprecated constructor that does not correctly handle partitioning when producing to multiple topics. Use Kafka09JsonTableSink.Kafka09JsonTableSink(String, Properties, FlinkKafkaPartitioner) instead.
Kafka09JsonTableSource - Class in org.apache.flink.streaming.connectors.kafka
Kafka StreamTableSource for Kafka 0.9.
Kafka09JsonTableSource(String, Properties, TypeInformation<Row>) - Constructor for class org.apache.flink.streaming.connectors.kafka.Kafka09JsonTableSource
Creates a Kafka 0.9 JSON StreamTableSource.
Kafka09TableSource - Class in org.apache.flink.streaming.connectors.kafka
Kafka StreamTableSource for Kafka 0.9.
Kafka09TableSource(String, Properties, DeserializationSchema<Row>, TypeInformation<Row>) - Constructor for class org.apache.flink.streaming.connectors.kafka.Kafka09TableSource
Creates a Kafka 0.9 StreamTableSource.
KafkaAvroTableSource - Class in org.apache.flink.streaming.connectors.kafka
A version-agnostic Kafka Avro StreamTableSource.
KafkaCommitCallback - Interface in org.apache.flink.streaming.connectors.kafka.internals
A callback interface that the source operator can implement to trigger custom actions when a commit request completes, which should normally be triggered from checkpoint complete event.
KafkaConsumerCallBridge - Class in org.apache.flink.streaming.connectors.kafka.internal
The ConsumerCallBridge simply calls methods on the KafkaConsumer.
KafkaConsumerCallBridge() - Constructor for class org.apache.flink.streaming.connectors.kafka.internal.KafkaConsumerCallBridge
 
KafkaConsumerCallBridge010 - Class in org.apache.flink.streaming.connectors.kafka.internal
The ConsumerCallBridge simply calls the KafkaConsumer#assign(java.util.Collection) method.
KafkaConsumerCallBridge010() - Constructor for class org.apache.flink.streaming.connectors.kafka.internal.KafkaConsumerCallBridge010
 
KafkaConsumerThread - Class in org.apache.flink.streaming.connectors.kafka.internal
The thread the runs the KafkaConsumer, connecting to the brokers and polling records.
KafkaConsumerThread(Logger, Handover, Properties, KafkaTopicPartitionState<TopicPartition>[], MetricGroup, KafkaConsumerCallBridge, String, long, boolean) - Constructor for class org.apache.flink.streaming.connectors.kafka.internal.KafkaConsumerThread
 
KafkaJsonTableSink - Class in org.apache.flink.streaming.connectors.kafka
Base class for KafkaTableSink that serializes data in JSON format
KafkaJsonTableSink(String, Properties, FlinkKafkaPartitioner<Row>) - Constructor for class org.apache.flink.streaming.connectors.kafka.KafkaJsonTableSink
Creates KafkaJsonTableSink
KafkaJsonTableSource - Class in org.apache.flink.streaming.connectors.kafka
A version-agnostic Kafka JSON StreamTableSource.
KafkaMetricWrapper - Class in org.apache.flink.streaming.connectors.kafka.internals.metrics
Gauge for getting the current value of a Kafka metric.
KafkaMetricWrapper(Metric) - Constructor for class org.apache.flink.streaming.connectors.kafka.internals.metrics.KafkaMetricWrapper
 
KafkaPartitioner<T> - Class in org.apache.flink.streaming.connectors.kafka.partitioner
Deprecated.
This partitioner does not handle partitioning properly in the case of multiple topics, and has been deprecated. Please use FlinkKafkaPartitioner instead.
KafkaPartitioner() - Constructor for class org.apache.flink.streaming.connectors.kafka.partitioner.KafkaPartitioner
Deprecated.
 
KafkaTableSink - Class in org.apache.flink.streaming.connectors.kafka
A version-agnostic Kafka AppendStreamTableSink.
KafkaTableSink(String, Properties, FlinkKafkaPartitioner<Row>) - Constructor for class org.apache.flink.streaming.connectors.kafka.KafkaTableSink
Creates KafkaTableSink
KafkaTableSource - Class in org.apache.flink.streaming.connectors.kafka
A version-agnostic Kafka StreamTableSource.
KafkaTopicPartition - Class in org.apache.flink.streaming.connectors.kafka.internals
Flink's description of a partition in a Kafka topic.
KafkaTopicPartition(String, int) - Constructor for class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartition
 
KafkaTopicPartitionAssigner - Class in org.apache.flink.streaming.connectors.kafka.internals
Utility for assigning Kafka partitions to consumer subtasks.
KafkaTopicPartitionAssigner() - Constructor for class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionAssigner
 
KafkaTopicPartitionLeader - Class in org.apache.flink.streaming.connectors.kafka.internals
Serializable Topic Partition info with leader Node information.
KafkaTopicPartitionLeader(KafkaTopicPartition, Node) - Constructor for class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionLeader
 
KafkaTopicPartitionState<KPH> - Class in org.apache.flink.streaming.connectors.kafka.internals
The state that the Flink Kafka Consumer holds for each Kafka partition.
KafkaTopicPartitionState(KafkaTopicPartition, KPH) - Constructor for class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionState
 
KafkaTopicPartitionStateSentinel - Class in org.apache.flink.streaming.connectors.kafka.internals
Magic values used to represent special offset states before partitions are actually read.
KafkaTopicPartitionStateSentinel() - Constructor for class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionStateSentinel
 
KafkaTopicPartitionStateWithPeriodicWatermarks<T,KPH> - Class in org.apache.flink.streaming.connectors.kafka.internals
A special version of the per-kafka-partition-state that additionally holds a periodic watermark generator (and timestamp extractor) per partition.
KafkaTopicPartitionStateWithPeriodicWatermarks(KafkaTopicPartition, KPH, AssignerWithPeriodicWatermarks<T>) - Constructor for class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionStateWithPeriodicWatermarks
 
KafkaTopicPartitionStateWithPunctuatedWatermarks<T,KPH> - Class in org.apache.flink.streaming.connectors.kafka.internals
A special version of the per-kafka-partition-state that additionally holds a periodic watermark generator (and timestamp extractor) per partition.
KafkaTopicPartitionStateWithPunctuatedWatermarks(KafkaTopicPartition, KPH, AssignerWithPunctuatedWatermarks<T>) - Constructor for class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionStateWithPunctuatedWatermarks
 
keepBuildSidePartitions - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
If true, build side partitions are kept for multiple probe steps.
KERBEROS_LOGIN_CONTEXTS - Static variable in class org.apache.flink.configuration.SecurityOptions
 
KERBEROS_LOGIN_KEYTAB - Static variable in class org.apache.flink.configuration.SecurityOptions
 
KERBEROS_LOGIN_PRINCIPAL - Static variable in class org.apache.flink.configuration.SecurityOptions
 
KERBEROS_LOGIN_USETICKETCACHE - Static variable in class org.apache.flink.configuration.SecurityOptions
 
KerberosUtils - Class in org.apache.flink.runtime.security
Provides vendor-specific Kerberos AppConfigurationEntry instances.
KerberosUtils() - Constructor for class org.apache.flink.runtime.security.KerberosUtils
 
key - Variable in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
key() - Method in class org.apache.flink.configuration.ConfigOption
Gets the configuration key.
key(String) - Static method in class org.apache.flink.configuration.ConfigOptions
Starts building a new ConfigOption.
key - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
key - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
 
key() - Method in class org.apache.flink.table.expressions.ExpressionParser.Keyword
 
key() - Method in class org.apache.flink.table.expressions.GetCompositeField
 
Key<T> - Interface in org.apache.flink.types
Deprecated.
The Key type is a relict of a deprecated and removed API and will be removed in future (2.0) versions as well.
KEY_DISABLE_METRICS - Static variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
Boolean configuration key to disable metrics tracking
KEY_DISABLE_METRICS - Static variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
Configuration key for disabling the metrics reporting.
KEY_FIELD - Static variable in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter.AvroKeyValue
The name of the generic record field containing the key.
KEY_POLL_TIMEOUT - Static variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
Configuration key to change the polling timeout
KEY_VALUE_PAIR_RECORD_NAME - Static variable in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter.AvroKeyValue
The name of the key value pair generic record.
KEY_VALUE_PAIR_RECORD_NAMESPACE - Static variable in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter.AvroKeyValue
The namespace of the key value pair generic record.
keyBy(int, int) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
KeyBy operation for connected data stream.
keyBy(int[], int[]) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
KeyBy operation for connected data stream.
keyBy(String, String) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
KeyBy operation for connected data stream using key expressions.
keyBy(String[], String[]) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
KeyBy operation for connected data stream using key expressions.
keyBy(KeySelector<IN1, ?>, KeySelector<IN2, ?>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
KeyBy operation for connected data stream.
keyBy(KeySelector<T, K>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
It creates a new KeyedStream that uses the provided key for partitioning its operator states.
keyBy(int...) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Partitions the operator state of a DataStream by the given key positions.
keyBy(String...) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Partitions the operator state of a DataStream using field expressions.
keyBy(int[], int[]) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream.ConnectedIterativeStreams
 
keyBy(String, String) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream.ConnectedIterativeStreams
 
keyBy(String[], String[]) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream.ConnectedIterativeStreams
 
keyBy(KeySelector<I, ?>, KeySelector<F, ?>) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream.ConnectedIterativeStreams
 
keyBy(int, int) - Method in class org.apache.flink.streaming.api.scala.ConnectedStreams
Keys the two connected streams together.
keyBy(int[], int[]) - Method in class org.apache.flink.streaming.api.scala.ConnectedStreams
Keys the two connected streams together.
keyBy(String, String) - Method in class org.apache.flink.streaming.api.scala.ConnectedStreams
Keys the two connected streams together.
keyBy(String[], String[]) - Method in class org.apache.flink.streaming.api.scala.ConnectedStreams
Keys the two connected streams together.
keyBy(Function1<IN1, K1>, Function1<IN2, K2>, TypeInformation<K1>, TypeInformation<K2>) - Method in class org.apache.flink.streaming.api.scala.ConnectedStreams
Keys the two connected streams together.
keyBy(Seq<Object>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Groups the elements of a DataStream by the given key positions (for tuple/array types) to be used with grouped operators like grouped reduce or grouped aggregations.
keyBy(String, Seq<String>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Groups the elements of a DataStream by the given field expressions to be used with grouped operators like grouped reduce or grouped aggregations.
keyBy(Function1<T, K>, TypeInformation<K>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Groups the elements of a DataStream by the given K key to be used with grouped operators like grouped reduce or grouped aggregations.
keyClass - Variable in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
keyClass - Variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
keyContext - Variable in class org.apache.flink.runtime.state.heap.StateTable
The key context view on the backend.
KeyContext - Interface in org.apache.flink.streaming.api.operators
Inteface for setting and querying the current key of keyed operations.
KeyDiscarder<T> - Class in org.apache.flink.python.api.functions.util
 
KeyDiscarder() - Constructor for class org.apache.flink.python.api.functions.util.KeyDiscarder
 
keyDone() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.KeyMap.TraversalEvaluator
Called when the traversal for the current key is complete.
KeyedBackendSerializationProxy<K> - Class in org.apache.flink.runtime.state
Serialization proxy for all meta data in keyed state backends.
KeyedBackendSerializationProxy(ClassLoader) - Constructor for class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
 
KeyedBackendSerializationProxy(TypeSerializer<K>, List<RegisteredKeyedBackendStateMetaInfo.Snapshot<?, ?>>) - Constructor for class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
 
KeyedBackendStateMetaInfoSnapshotReaderWriters - Class in org.apache.flink.runtime.state
Readers and writers for different versions of the RegisteredKeyedBackendStateMetaInfo.Snapshot.
KeyedBackendStateMetaInfoSnapshotReaderWriters() - Constructor for class org.apache.flink.runtime.state.KeyedBackendStateMetaInfoSnapshotReaderWriters
 
KeyedBackendStateMetaInfoSnapshotReaderWriters.KeyedBackendStateMetaInfoReader<N,S> - Interface in org.apache.flink.runtime.state
 
KeyedBackendStateMetaInfoSnapshotReaderWriters.KeyedBackendStateMetaInfoWriter - Interface in org.apache.flink.runtime.state
 
KeyedCEPPatternOperator<IN,KEY> - Class in org.apache.flink.cep.operator
CEP pattern operator which only returns fully matched event patterns stored in a Map.
KeyedCEPPatternOperator(TypeSerializer<IN>, boolean, TypeSerializer<KEY>, NFACompiler.NFAFactory<IN>, boolean) - Constructor for class org.apache.flink.cep.operator.KeyedCEPPatternOperator
 
KeyedCoProcessOperator<K,IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.operators.co
A StreamOperator for executing keyed CoProcessFunctions.
KeyedCoProcessOperator(CoProcessFunction<IN1, IN2, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
 
KeyedDeserializationSchema<T> - Interface in org.apache.flink.streaming.util.serialization
The deserialization schema describes how to turn the byte key / value messages delivered by certain data sources (for example Apache Kafka) into data types (Java/Scala objects) that are processed by Flink.
KeyedDeserializationSchemaWrapper<T> - Class in org.apache.flink.streaming.util.serialization
A simple wrapper for using the DeserializationSchema with the KeyedDeserializationSchema interface
KeyedDeserializationSchemaWrapper(DeserializationSchema<T>) - Constructor for class org.apache.flink.streaming.util.serialization.KeyedDeserializationSchemaWrapper
 
KeyedProcessOperator<K,IN,OUT> - Class in org.apache.flink.streaming.api.operators
A StreamOperator for executing keyed ProcessFunctions.
KeyedProcessOperator(ProcessFunction<IN, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.KeyedProcessOperator
 
KeyedSerializationSchema<T> - Interface in org.apache.flink.streaming.util.serialization
The serialization schema describes how to turn a data object into a different serialized representation.
KeyedSerializationSchemaWrapper<T> - Class in org.apache.flink.streaming.util.serialization
A simple wrapper for using the SerializationSchema with the KeyedDeserializationSchema interface
KeyedSerializationSchemaWrapper(SerializationSchema<T>) - Constructor for class org.apache.flink.streaming.util.serialization.KeyedSerializationSchemaWrapper
 
KeyedStateBackend<K> - Interface in org.apache.flink.runtime.state
A keyed state backend provides methods for managing keyed state.
KeyedStateCheckpointOutputStream - Class in org.apache.flink.runtime.state
Checkpoint output stream that allows to write raw keyed state in a partitioned way, split into key-groups.
KeyedStateCheckpointOutputStream(CheckpointStreamFactory.CheckpointStateOutputStream, KeyGroupRange) - Constructor for class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
 
KeyedStateHandle - Interface in org.apache.flink.runtime.state
Base for the handles of the checkpointed states in keyed streams.
KeyedStateStore - Interface in org.apache.flink.api.common.state
This interface contains methods for registering keyed state with a managed store.
KeyedStream<T,KEY> - Class in org.apache.flink.streaming.api.datastream
A KeyedStream represents a DataStream on which operator state is partitioned by key using a provided KeySelector.
KeyedStream(DataStream<T>, KeySelector<T, KEY>) - Constructor for class org.apache.flink.streaming.api.datastream.KeyedStream
Creates a new KeyedStream using the given KeySelector to partition operator state by key.
KeyedStream(DataStream<T>, KeySelector<T, KEY>, TypeInformation<KEY>) - Constructor for class org.apache.flink.streaming.api.datastream.KeyedStream
Creates a new KeyedStream using the given KeySelector to partition operator state by key.
KeyedStream<T,K> - Class in org.apache.flink.streaming.api.scala
 
KeyedStream(KeyedStream<T, K>) - Constructor for class org.apache.flink.streaming.api.scala.KeyedStream
 
KeyExtractingMapper<T,K> - Class in org.apache.flink.api.java.operators.translation
 
KeyExtractingMapper(KeySelector<T, K>) - Constructor for class org.apache.flink.api.java.operators.translation.KeyExtractingMapper
 
KeyFieldOutOfBoundsException - Exception in org.apache.flink.types
An exception specifying that a required key field was not set in a record, i.e.
KeyFieldOutOfBoundsException() - Constructor for exception org.apache.flink.types.KeyFieldOutOfBoundsException
Constructs an KeyFieldOutOfBoundsException with null as its error detail message.
KeyFieldOutOfBoundsException(String) - Constructor for exception org.apache.flink.types.KeyFieldOutOfBoundsException
Constructs an KeyFieldOutOfBoundsException with the specified detail message.
KeyFieldOutOfBoundsException(int) - Constructor for exception org.apache.flink.types.KeyFieldOutOfBoundsException
Constructs an KeyFieldOutOfBoundsException with a default message, referring to given field number as the null key field.
KeyFieldOutOfBoundsException(int, Throwable) - Constructor for exception org.apache.flink.types.KeyFieldOutOfBoundsException
 
KeyFunctions - Class in org.apache.flink.api.java.operators
This class holds static utilities to append functions that extract and prune keys.
KeyFunctions() - Constructor for class org.apache.flink.api.java.operators.KeyFunctions
 
KeyGroupedIterator<E> - Interface in org.apache.flink.runtime.util
 
keyGroupRange - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
Range of key-groups for which this backend is responsible
KeyGroupRange - Class in org.apache.flink.runtime.state
This class defines a range of key-group indexes.
KeyGroupRange(int, int) - Constructor for class org.apache.flink.runtime.state.KeyGroupRange
Defines the range [startKeyGroup, endKeyGroup]
KeyGroupRangeAssignment - Class in org.apache.flink.runtime.state
 
KeyGroupRangeOffsets - Class in org.apache.flink.runtime.state
This class combines a key-group range with offsets that correspond to the key-groups in the range.
KeyGroupRangeOffsets(KeyGroupRange, long[]) - Constructor for class org.apache.flink.runtime.state.KeyGroupRangeOffsets
Creates key-group range with offsets from the given key-group range.
KeyGroupRangeOffsets(int, int, long[]) - Constructor for class org.apache.flink.runtime.state.KeyGroupRangeOffsets
Creates key-group range with offsets from the given start key-group to end key-group.
KeyGroupRangeOffsets(int, int) - Constructor for class org.apache.flink.runtime.state.KeyGroupRangeOffsets
Creates key-group range with offsets from the given start key-group to end key-group.
KeyGroupRangeOffsets(KeyGroupRange) - Constructor for class org.apache.flink.runtime.state.KeyGroupRangeOffsets
Creates key-group range with offsets for the given key-group range, where all offsets are initially zero.
KeyGroupsList - Interface in org.apache.flink.runtime.state
This interface offers ordered random read access to multiple key group ids.
KeyGroupsStateHandle - Class in org.apache.flink.runtime.state
A handle to the partitioned stream operator state after it has been checkpointed.
KeyGroupsStateHandle(KeyGroupRangeOffsets, StreamStateHandle) - Constructor for class org.apache.flink.runtime.state.KeyGroupsStateHandle
 
KeyGroupState - Class in org.apache.flink.migration.runtime.checkpoint
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
KeyGroupState(SerializedValue<StateHandle<?>>, long, long) - Constructor for class org.apache.flink.migration.runtime.checkpoint.KeyGroupState
Deprecated.
 
KeyGroupStatePartitionStreamProvider - Class in org.apache.flink.runtime.state
This class provides access to an input stream that contains state data for one key group and the key group id.
KeyGroupStatePartitionStreamProvider(IOException, int) - Constructor for class org.apache.flink.runtime.state.KeyGroupStatePartitionStreamProvider
 
KeyGroupStatePartitionStreamProvider(InputStream, int) - Constructor for class org.apache.flink.runtime.state.KeyGroupStatePartitionStreamProvider
 
KeyGroupStreamPartitioner<T,K> - Class in org.apache.flink.streaming.runtime.partitioner
Partitioner selects the target channel based on the key group index.
KeyGroupStreamPartitioner(KeySelector<T, K>, int) - Constructor for class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
 
keyingBy(Function1<IN1, K1>, Function1<IN2, K2>, TypeInformation<K1>, TypeInformation<K2>) - Method in class org.apache.flink.streaming.api.scala.extensions.impl.acceptPartialFunctions.OnConnectedStream
Keys the two connected streams together.
keyingBy(Function1<T, K>, TypeInformation<K>) - Method in class org.apache.flink.streaming.api.scala.extensions.impl.acceptPartialFunctions.OnDataStream
Keys the items according to a keying function fun
keyList - Variable in class org.apache.flink.optimizer.operators.OperatorDescriptorSingle
 
KeyMap<K,V> - Class in org.apache.flink.streaming.runtime.operators.windowing
A special Hash Map implementation that can be traversed efficiently in sync with other hash maps.
KeyMap() - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
Creates a new hash table with the default initial capacity.
KeyMap(int) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
Creates a new table with a capacity tailored to the given expected number of elements.
KeyMap.Entry<K,V> - Class in org.apache.flink.streaming.runtime.operators.windowing
An entry in the hash table.
KeyMap.LazyFactory<V> - Interface in org.apache.flink.streaming.runtime.operators.windowing
A factory for lazy/on-demand instantiation of values.
KeyMap.TraversalEvaluator<K,V> - Interface in org.apache.flink.streaming.runtime.operators.windowing
A visitor for a traversal over the union of multiple hash maps.
keyPositions - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
key positions describe which fields are keys in what order
KeyRemovingMapper<T,K> - Class in org.apache.flink.api.java.operators.translation
 
KeyRemovingMapper() - Constructor for class org.apache.flink.api.java.operators.translation.KeyRemovingMapper
 
Keys<T> - Class in org.apache.flink.api.common.operators
 
Keys() - Constructor for class org.apache.flink.api.common.operators.Keys
 
keys() - Method in interface org.apache.flink.api.common.state.MapState
Returns all the keys in the state
keys - Variable in class org.apache.flink.api.java.operators.Grouping
 
keys() - Method in class org.apache.flink.contrib.streaming.state.RocksDBMapState
 
keys - Variable in class org.apache.flink.optimizer.dag.SingleInputNode
 
keys - Variable in class org.apache.flink.optimizer.operators.OperatorDescriptorSingle
 
keys - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
keys() - Method in class org.apache.flink.runtime.state.heap.HeapMapState
 
Keys.ExpressionKeys<T> - Class in org.apache.flink.api.common.operators
Represents (nested) field access through string and integer-based keys
Keys.IncompatibleKeysException - Exception in org.apache.flink.api.common.operators
 
Keys.SelectorFunctionKeys<T,K> - Class in org.apache.flink.api.common.operators
 
keys1 - Variable in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase.JoinOperatorSetsPredicateBase
 
keys1 - Variable in class org.apache.flink.api.java.operators.JoinOperator
 
keys1 - Variable in class org.apache.flink.optimizer.dag.TwoInputNode
 
keys1 - Variable in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
 
keys1 - Variable in class org.apache.flink.optimizer.plan.DualInputPlanNode
 
keys1 - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
keys2 - Variable in class org.apache.flink.api.java.operators.JoinOperator
 
keys2 - Variable in class org.apache.flink.optimizer.dag.TwoInputNode
 
keys2 - Variable in class org.apache.flink.optimizer.operators.OperatorDescriptorDual
 
keys2 - Variable in class org.apache.flink.optimizer.plan.DualInputPlanNode
 
keys2 - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
KeySelector<IN,KEY> - Interface in org.apache.flink.api.java.functions
The KeySelector allows to use deterministic objects for operations such as reduce, reduceGroup, join, coGoup, etc.
KeySelectorUtil - Class in org.apache.flink.streaming.util.keys
Utility class that contains helper methods to manipulating KeySelector for streaming.
KeySelectorUtil.ArrayKeySelector<IN> - Class in org.apache.flink.streaming.util.keys
A key selector for selecting individual array fields as keys and returns them as a Tuple.
KeySelectorUtil.ComparableKeySelector<IN> - Class in org.apache.flink.streaming.util.keys
A key selector for selecting key fields via a TypeComparator.
KeySelectorUtil.OneKeySelector<IN,K> - Class in org.apache.flink.streaming.util.keys
Key extractor that extracts a single field via a generic comparator.
KeySelectorWithType<IN,K> - Class in org.apache.flink.streaming.api.scala
 
KeySelectorWithType(Function1<IN, K>, TypeInformation<K>) - Constructor for class org.apache.flink.streaming.api.scala.KeySelectorWithType
 
keySerializationDataOutputView - Variable in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
 
keySerializationStream - Variable in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
 
keySerializer - Variable in class org.apache.flink.migration.runtime.state.filesystem.AbstractFsStateSnapshot
Deprecated.
Key Serializer
keySerializer - Variable in class org.apache.flink.migration.runtime.state.memory.AbstractMemStateSnapshot
Deprecated.
Key Serializer
keySerializer - Variable in class org.apache.flink.migration.runtime.state.memory.AbstractMigrationRestoreStrategy
Deprecated.
Key Serializer
keySerializer - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
TypeSerializer for our key.
keySerializer - Variable in class org.apache.flink.runtime.state.heap.AbstractHeapState
 
keySerializer - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
For serializing the key in checkpoints.
keySet() - Method in class org.apache.flink.configuration.Configuration
Returns the keys of all key/value pairs stored inside this configuration object.
keySet() - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
keySet() - Method in class org.apache.flink.storm.util.StormConfig
 
keySet() - Method in class org.apache.flink.types.MapValue
 
KEYTAB_FILE_NAME - Static variable in class org.apache.flink.yarn.Utils
Keytab file name populated in YARN container
KEYTAB_PATH - Static variable in class org.apache.flink.yarn.YarnConfigKeys
 
KEYTAB_PRINCIPAL - Static variable in class org.apache.flink.yarn.YarnConfigKeys
 
keytabEntry(String, String) - Static method in class org.apache.flink.runtime.security.KerberosUtils
 
KeytabOverlay - Class in org.apache.flink.runtime.clusterframework.overlays
Overlays cluster-level Kerberos credentials (i.e.
KeytabOverlay(File) - Constructor for class org.apache.flink.runtime.clusterframework.overlays.KeytabOverlay
 
KeytabOverlay(Path) - Constructor for class org.apache.flink.runtime.clusterframework.overlays.KeytabOverlay
 
KeytabOverlay.Builder - Class in org.apache.flink.runtime.clusterframework.overlays
A builder for the KeytabOverlay.
keyType(Class<K>) - Method in class org.apache.flink.graph.GraphCsvReader
Creates a Graph from CSV input without vertex values or edge values.
keyType() - Method in class org.apache.flink.table.plan.schema.MapRelDataType
 
keyValueStatesByName - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
So that we can give out state when the user uses the same key.
Keyword(String) - Constructor for class org.apache.flink.table.expressions.ExpressionParser.Keyword
 
Keyword$() - Constructor for class org.apache.flink.table.expressions.ExpressionParser.Keyword$
 
keyword2Parser(ExpressionParser.Keyword) - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
keyword2Parser(ExpressionParser.Keyword) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
kFoldSplit(DataSet<T>, int, long, TypeInformation<T>, ClassTag<T>) - Method in class org.apache.flink.ml.preprocessing.Splitter$
Split a DataSet into an array of TrainTest DataSets
kFoldSplit(DataSet<T>, int, long, TypeInformation<T>, ClassTag<T>) - Static method in class org.apache.flink.ml.preprocessing.Splitter
Split a DataSet into an array of TrainTest DataSets
KILL_ON_OUT_OF_MEMORY - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Whether to kill the TaskManager when the task thread throws an OutOfMemoryError
Killing$() - Constructor for class org.apache.flink.mesos.scheduler.TaskMonitor.Killing$
 
killTopology(String) - Method in class org.apache.flink.storm.api.FlinkClient
 
killTopology(String) - Method in class org.apache.flink.storm.api.FlinkLocalCluster
 
killTopologyWithOpts(String, KillOptions) - Method in class org.apache.flink.storm.api.FlinkClient
 
killTopologyWithOpts(String, KillOptions) - Method in class org.apache.flink.storm.api.FlinkLocalCluster
 
KMeans - Class in org.apache.flink.examples.java.clustering
This example implements a basic K-Means clustering algorithm.
KMeans() - Constructor for class org.apache.flink.examples.java.clustering.KMeans
 
KMeans - Class in org.apache.flink.examples.scala.clustering
This example implements a basic K-Means clustering algorithm.
KMeans() - Constructor for class org.apache.flink.examples.scala.clustering.KMeans
 
KMeans$ - Class in org.apache.flink.examples.scala.clustering
This example implements a basic K-Means clustering algorithm.
KMeans$() - Constructor for class org.apache.flink.examples.scala.clustering.KMeans$
 
KMeans.Centroid - Class in org.apache.flink.examples.java.clustering
A simple two-dimensional centroid, basically a point with an ID.
KMeans.Centroid - Class in org.apache.flink.examples.scala.clustering
A simple two-dimensional centroid, basically a point with an ID.
KMeans.Centroid$ - Class in org.apache.flink.examples.scala.clustering
 
KMeans.CentroidAccumulator - Class in org.apache.flink.examples.java.clustering
Sums and counts point coordinates.
KMeans.CentroidAverager - Class in org.apache.flink.examples.java.clustering
Computes new centroid from coordinate sum and count of points.
KMeans.Coordinate - Interface in org.apache.flink.examples.scala.clustering
Common trait for operations supported by both points and centroids Note: case class inheritance is not allowed in Scala
KMeans.CountAppender - Class in org.apache.flink.examples.java.clustering
Appends a count variable to the tuple.
KMeans.Point - Class in org.apache.flink.examples.java.clustering
A simple two-dimensional point.
KMeans.Point - Class in org.apache.flink.examples.scala.clustering
A simple two-dimensional point.
KMeans.Point$ - Class in org.apache.flink.examples.scala.clustering
 
KMeans.SelectNearestCenter - Class in org.apache.flink.examples.java.clustering
Determines the closest cluster center for a data point.
KMeans.SelectNearestCenter - Class in org.apache.flink.examples.scala.clustering
Determines the closest cluster center for a data point.
KMeansData - Class in org.apache.flink.examples.java.clustering.util
Provides the default data sets used for the K-Means example program.
KMeansData() - Constructor for class org.apache.flink.examples.java.clustering.util.KMeansData
 
KMeansData - Class in org.apache.flink.test.testdata
 
KMeansDataGenerator - Class in org.apache.flink.examples.java.clustering.util
Generates data for the KMeans example program.
KMeansDataGenerator() - Constructor for class org.apache.flink.examples.java.clustering.util.KMeansDataGenerator
 
KNN - Class in org.apache.flink.ml.nn
Implements a k-nearest neighbor join.
KNN() - Constructor for class org.apache.flink.ml.nn.KNN
 
KNN$ - Class in org.apache.flink.ml.nn
 
KNN$() - Constructor for class org.apache.flink.ml.nn.KNN$
 
KNN.Blocks$ - Class in org.apache.flink.ml.nn
 
KNN.DistanceMetric$ - Class in org.apache.flink.ml.nn
 
KNN.K$ - Class in org.apache.flink.ml.nn
 
KNN.SizeHint$ - Class in org.apache.flink.ml.nn
 
KNN.UseQuadTree$ - Class in org.apache.flink.ml.nn
 
KRB5_FILE_NAME - Static variable in class org.apache.flink.yarn.Utils
KRB5 file name populated in YARN container for secure IT run
Krb5ConfOverlay - Class in org.apache.flink.runtime.clusterframework.overlays
Overlays a Kerberos configuration file into a container.
Krb5ConfOverlay(File) - Constructor for class org.apache.flink.runtime.clusterframework.overlays.Krb5ConfOverlay
 
Krb5ConfOverlay(Path) - Constructor for class org.apache.flink.runtime.clusterframework.overlays.Krb5ConfOverlay
 
Krb5ConfOverlay.Builder - Class in org.apache.flink.runtime.clusterframework.overlays
A builder for the Krb5ConfOverlay.
KryoRegistration - Class in org.apache.flink.api.java.typeutils.runtime
A KryoRegistration resembles a registered class and its serializer in Kryo.
KryoRegistration(Class<?>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
KryoRegistration(Class<?>, Class<? extends Serializer<?>>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
KryoRegistration(Class<?>, ExecutionConfig.SerializableSerializer<? extends Serializer<?>>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.KryoRegistration
 
KryoRegistration.SerializerDefinitionType - Enum in org.apache.flink.api.java.typeutils.runtime
IMPORTANT: the order of the enumerations must not change, since their ordinals are used for serialization.
KryoRegistrationSerializerConfigSnapshot<T> - Class in org.apache.flink.api.java.typeutils.runtime
Configuration snapshot base class for serializers that use Kryo for serialization.
KryoRegistrationSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
KryoRegistrationSerializerConfigSnapshot(Class<T>, LinkedHashMap<String, KryoRegistration>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot
 
KryoRegistrationSerializerConfigSnapshot.DummyKryoSerializerClass<RC> - Class in org.apache.flink.api.java.typeutils.runtime
Placeholder dummmy for a previously registered Kryo serializer that is no longer valid or in classpath on restore.
KryoRegistrationSerializerConfigSnapshot.DummyRegisteredClass - Class in org.apache.flink.api.java.typeutils.runtime
Placeholder dummy for a previously registered class that can no longer be found in classpath on restore.
KryoSerializer<T> - Class in org.apache.flink.api.java.typeutils.runtime.kryo
A type serializer that serializes its type using the Kryo serialization framework (https://github.com/EsotericSoftware/kryo).
KryoSerializer(Class<T>, ExecutionConfig) - Constructor for class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
KryoSerializer(KryoSerializer<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
Copy-constructor that does not copy transient fields.
KryoSerializer.KryoSerializerConfigSnapshot<T> - Class in org.apache.flink.api.java.typeutils.runtime.kryo
 
KryoSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer.KryoSerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
KryoSerializerConfigSnapshot(Class<T>, LinkedHashMap<String, KryoRegistration>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer.KryoSerializerConfigSnapshot
 
KryoUtils - Class in org.apache.flink.api.java.typeutils.runtime
Convenience methods for Kryo
KryoUtils() - Constructor for class org.apache.flink.api.java.typeutils.runtime.KryoUtils
 
KvStateClient - Class in org.apache.flink.runtime.query.netty
Netty-based client querying KvStateServer instances.
KvStateClient(int, KvStateRequestStats) - Constructor for class org.apache.flink.runtime.query.netty.KvStateClient
Creates a client with the specified number of event loop threads.
KvStateID - Class in org.apache.flink.runtime.query
Identifier for InternalKvState instances.
KvStateID() - Constructor for class org.apache.flink.runtime.query.KvStateID
 
KvStateID(long, long) - Constructor for class org.apache.flink.runtime.query.KvStateID
 
KvStateLocation - Class in org.apache.flink.runtime.query
Location information for all key groups of a InternalKvState instance.
KvStateLocation(JobID, JobVertexID, int, String) - Constructor for class org.apache.flink.runtime.query.KvStateLocation
Creates the location information
KvStateLocationLookupService - Interface in org.apache.flink.runtime.query
KvStateLocation lookup service.
KvStateLocationRegistry - Class in org.apache.flink.runtime.query
Simple registry, which maps InternalKvState registration notifications to KvStateLocation instances.
KvStateLocationRegistry(JobID, Map<JobVertexID, ExecutionJobVertex>) - Constructor for class org.apache.flink.runtime.query.KvStateLocationRegistry
Creates the registry for the job.
KvStateMessage - Interface in org.apache.flink.runtime.query
Actor messages for InternalKvState lookup and registration.
KvStateMessage.LookupKvStateLocation - Class in org.apache.flink.runtime.query
 
KvStateMessage.NotifyKvStateRegistered - Class in org.apache.flink.runtime.query
 
KvStateMessage.NotifyKvStateUnregistered - Class in org.apache.flink.runtime.query
 
KvStateRegistry - Class in org.apache.flink.runtime.query
A registry for InternalKvState instances per task manager.
KvStateRegistry() - Constructor for class org.apache.flink.runtime.query.KvStateRegistry
 
kvStateRegistry - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
KvStateRegistry helper for this task
KvStateRegistryGateway - Interface in org.apache.flink.runtime.query
 
KvStateRegistryListener - Interface in org.apache.flink.runtime.query
A listener for a KvStateRegistry.
KvStateRequest - Class in org.apache.flink.runtime.query.netty.message
A InternalKvState instance request for a specific key and namespace.
KvStateRequestFailure - Class in org.apache.flink.runtime.query.netty.message
A failure response to a KvStateRequest.
KvStateRequestResult - Class in org.apache.flink.runtime.query.netty.message
A successful response to a KvStateRequest containing the serialized result for the requested key and namespace.
KvStateRequestSerializer - Class in org.apache.flink.runtime.query.netty.message
Serialization and deserialization of messages exchanged between KvStateClient and KvStateServer.
KvStateRequestSerializer() - Constructor for class org.apache.flink.runtime.query.netty.message.KvStateRequestSerializer
 
KvStateRequestStats - Interface in org.apache.flink.runtime.query.netty
Simple statistics for KvStateServer monitoring.
KvStateRequestType - Enum in org.apache.flink.runtime.query.netty.message
Expected message types when communicating with the KvStateServer.
KvStateServer - Class in org.apache.flink.runtime.query.netty
Netty-based server answering KvStateRequest messages.
KvStateServer(InetAddress, int, int, int, KvStateRegistry, KvStateRequestStats) - Constructor for class org.apache.flink.runtime.query.netty.KvStateServer
Creates the KvStateServer.
KvStateServerAddress - Class in org.apache.flink.runtime.query
The (host, port)-address of a KvStateServer.
KvStateServerAddress(InetAddress, int) - Constructor for class org.apache.flink.runtime.query.KvStateServerAddress
Creates a KvStateServerAddress for the given KvStateServer host address and port.
KvStateSnapshot<K,N,S extends State,SD extends StateDescriptor<S,?>> - Interface in org.apache.flink.migration.runtime.state
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.

L

L1Regularization - Class in org.apache.flink.ml.optimization
L_1 regularization penalty.
L1Regularization() - Constructor for class org.apache.flink.ml.optimization.L1Regularization
 
L1Regularization$ - Class in org.apache.flink.ml.optimization
L_1 regularization penalty.
L1Regularization$() - Constructor for class org.apache.flink.ml.optimization.L1Regularization$
 
L2Regularization - Class in org.apache.flink.ml.optimization
L_2 regularization penalty.
L2Regularization() - Constructor for class org.apache.flink.ml.optimization.L2Regularization
 
L2Regularization$ - Class in org.apache.flink.ml.optimization
L_2 regularization penalty.
L2Regularization$() - Constructor for class org.apache.flink.ml.optimization.L2Regularization$
 
label() - Method in class org.apache.flink.ml.common.LabeledVector
 
LabeledVector - Class in org.apache.flink.ml.common
This class represents a vector with an associated label as it is required for many supervised learning tasks.
LabeledVector(double, Vector) - Constructor for class org.apache.flink.ml.common.LabeledVector
 
LabeledVector$ - Class in org.apache.flink.ml.common
 
LabeledVector$() - Constructor for class org.apache.flink.ml.common.LabeledVector$
 
LabelMessenger() - Constructor for class org.apache.flink.graph.library.CommunityDetection.LabelMessenger
 
LabelPropagation<K,VV extends Comparable<VV>,EV> - Class in org.apache.flink.graph.library
An implementation of the label propagation algorithm.
LabelPropagation(int) - Constructor for class org.apache.flink.graph.library.LabelPropagation
Creates a new Label Propagation algorithm instance.
LabelPropagation.SendNewLabelToNeighbors<K,VV extends Comparable<VV>> - Class in org.apache.flink.graph.library
Sends the vertex label to all out-neighbors
LabelPropagation.UpdateVertexLabel<K,VV extends Comparable<VV>> - Class in org.apache.flink.graph.library
Function that updates the value of a vertex by adopting the most frequent label among its in-neighbors
LabelPropagationData - Class in org.apache.flink.graph.examples.data
Provides the default data set used for the Label Propagation test program.
LABELS_AFTER_1_ITERATION - Static variable in class org.apache.flink.graph.examples.data.LabelPropagationData
 
LABELS_WITH_TIE - Static variable in class org.apache.flink.graph.examples.data.LabelPropagationData
 
LAG - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
LAG aggregate function.
Lambda$() - Constructor for class org.apache.flink.ml.recommendation.ALS.Lambda$
 
LambdaExecutable(Constructor<?>) - Constructor for class org.apache.flink.api.java.typeutils.TypeExtractionUtils.LambdaExecutable
 
LambdaExecutable(Method) - Constructor for class org.apache.flink.api.java.typeutils.TypeExtractionUtils.LambdaExecutable
 
LargeRecordHandler<T> - Class in org.apache.flink.runtime.operators.sort
 
LargeRecordHandler(TypeSerializer<T>, TypeComparator<T>, IOManager, MemoryManager, List<MemorySegment>, AbstractInvokable, int) - Constructor for class org.apache.flink.runtime.operators.sort.LargeRecordHandler
 
LAST - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
LAST function to be used within MATCH_RECOGNIZE.
LAST_VALUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
LAST_VALUE aggregate function.
lastAccessTime() - Method in class org.apache.flink.table.catalog.ExternalCatalogTable
 
lastActive() - Method in class org.apache.flink.runtime.jobmanager.JobInfo
 
lastIndexOf(Object) - Method in class org.apache.flink.types.ListValue
 
lastJobExecutionResult - Variable in class org.apache.flink.api.java.ExecutionEnvironment
Result from the latest execution, to make it retrievable when using eager execution methods
lastNoSuccess() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
lastNoSuccess_$eq(Parsers.NoSuccess) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
lateDataOutputTag - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
OutputTag to use for late arriving events.
LATENCY_HISTORY_SIZE - Static variable in class org.apache.flink.configuration.MetricOptions
The number of measured latencies to maintain at each operator
latencyGauge - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
LatencyMarker - Class in org.apache.flink.streaming.runtime.streamrecord
Special record type carrying a timestamp of its creation time at a source operator and the vertexId and subtask index of the operator.
LatencyMarker(long, int, int) - Constructor for class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
Creates a latency mark with the given timestamp.
LATERAL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The LATERAL operator.
LATEST_OFFSET - Static variable in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionStateSentinel
Magic number that defines the partition should start from the latest offset.
latestPane - Variable in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
The latest time pane.
launch(Protos.SlaveID, TaskAssignmentResult) - Method in class org.apache.flink.mesos.runtime.clusterframework.LaunchableMesosWorker
Construct the TaskInfo needed to launch the worker.
launch(Protos.SlaveID, TaskAssignmentResult) - Method in interface org.apache.flink.mesos.scheduler.LaunchableTask
Prepare to launch the task by producing a Mesos TaskInfo record.
Launch(List<LaunchableTask>) - Constructor for class org.apache.flink.mesos.scheduler.LaunchCoordinator.Launch
 
Launch$() - Constructor for class org.apache.flink.mesos.scheduler.LaunchCoordinator.Launch$
 
LAUNCH_TIMEOUT() - Method in class org.apache.flink.mesos.scheduler.TaskMonitor$
 
LAUNCH_TIMEOUT() - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
LaunchableMesosWorker - Class in org.apache.flink.mesos.runtime.clusterframework
Implements the launch of a Mesos worker.
LaunchableMesosWorker(MesosArtifactResolver, MesosTaskManagerParameters, ContainerSpecification, Protos.TaskID, MesosConfiguration) - Constructor for class org.apache.flink.mesos.runtime.clusterframework.LaunchableMesosWorker
Construct a launchable Mesos worker.
LaunchableTask - Interface in org.apache.flink.mesos.scheduler
Specifies the task requirements and produces a Mesos TaskInfo description.
LaunchCoordinator - Class in org.apache.flink.mesos.scheduler
The launch coordinator handles offer processing, including matching offers to tasks and making reservations.
LaunchCoordinator(ActorRef, Configuration, SchedulerDriver, TaskSchedulerBuilder) - Constructor for class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
LaunchCoordinator$ - Class in org.apache.flink.mesos.scheduler
Default handling of events.
LaunchCoordinator$() - Constructor for class org.apache.flink.mesos.scheduler.LaunchCoordinator$
 
LaunchCoordinator.Assign - Class in org.apache.flink.mesos.scheduler
Informs the launch coordinator that some task(s) are assigned to a host (for planning purposes).
LaunchCoordinator.Assign$ - Class in org.apache.flink.mesos.scheduler
 
LaunchCoordinator.GatherData - Class in org.apache.flink.mesos.scheduler
FSM state data.
LaunchCoordinator.GatherData$ - Class in org.apache.flink.mesos.scheduler
 
LaunchCoordinator.GatheringOffers$ - Class in org.apache.flink.mesos.scheduler
 
LaunchCoordinator.Idle$ - Class in org.apache.flink.mesos.scheduler
 
LaunchCoordinator.Launch - Class in org.apache.flink.mesos.scheduler
Instructs the launch coordinator to launch some new task.
LaunchCoordinator.Launch$ - Class in org.apache.flink.mesos.scheduler
 
LaunchCoordinator.Suspended$ - Class in org.apache.flink.mesos.scheduler
 
LaunchCoordinator.TaskState - Interface in org.apache.flink.mesos.scheduler
An FSM state of the launch coordinator.
LaunchCoordinator.Unassign - Class in org.apache.flink.mesos.scheduler
Informs the launch coordinator that some task is no longer assigned to a host (for planning purposes).
LaunchCoordinator.Unassign$ - Class in org.apache.flink.mesos.scheduler
 
Launched(Protos.TaskID, Protos.SlaveID) - Constructor for class org.apache.flink.mesos.scheduler.TaskMonitor.Launched
 
Launched$() - Constructor for class org.apache.flink.mesos.scheduler.TaskMonitor.Launched$
 
launchWorker(Protos.SlaveID, String) - Method in class org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore.Worker
Transition the worker to a launched state.
lazyDestroy() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
Destroys this buffer pool.
LEAD - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
LEAD aggregate function.
leaderAddress() - Method in class org.apache.flink.runtime.clusterframework.messages.NewLeaderAvailable
 
leaderAddress() - Method in class org.apache.flink.runtime.leaderelection.LeaderAddressAndId
 
LeaderAddressAndId - Class in org.apache.flink.runtime.leaderelection
A combination of a leader address and leader id.
LeaderAddressAndId(String, UUID) - Constructor for class org.apache.flink.runtime.leaderelection.LeaderAddressAndId
 
LeaderConnectingAddressListener() - Constructor for class org.apache.flink.runtime.net.ConnectionUtils.LeaderConnectingAddressListener
 
LeaderConnectionInfo - Class in org.apache.flink.runtime.util
Wrapper class for a pair of connection address and leader session ID.
LeaderConnectionInfo(String, UUID) - Constructor for class org.apache.flink.runtime.util.LeaderConnectionInfo
 
LeaderConnectionInfoListener() - Constructor for class org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderConnectionInfoListener
 
LeaderContender - Interface in org.apache.flink.runtime.leaderelection
Interface which has to be implemented to take part in the leader election process of the LeaderElectionService.
leaderElectionService() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
LeaderElectionService - Interface in org.apache.flink.runtime.leaderelection
Interface for a service which allows to elect a leader among a group of contenders.
leaderGateway() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
Future to the ActorGateway of the current leader
LeaderGatewayListener(ActorSystem, FiniteDuration) - Constructor for class org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderGatewayListener
 
leaderId() - Method in class org.apache.flink.runtime.leaderelection.LeaderAddressAndId
 
leaderId() - Method in class org.apache.flink.runtime.messages.TaskManagerMessages.RegisteredAtJobManager
 
LeaderIdMismatchException - Exception in org.apache.flink.runtime.highavailability
An exception thrown when the leader session id attached to a message does not match the leader session id that the receiver expects.
LeaderIdMismatchException(UUID, UUID) - Constructor for exception org.apache.flink.runtime.highavailability.LeaderIdMismatchException
 
leaderIndex() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
Future to the index of the current leader
LeaderRetrievalException - Exception in org.apache.flink.runtime.leaderretrieval
This exception is thrown by the LeaderRetrievalUtils when the method retrieveLeaderGateway fails to retrieve the current leader's gateway.
LeaderRetrievalException(String) - Constructor for exception org.apache.flink.runtime.leaderretrieval.LeaderRetrievalException
 
LeaderRetrievalException(Throwable) - Constructor for exception org.apache.flink.runtime.leaderretrieval.LeaderRetrievalException
 
LeaderRetrievalException(String, Throwable) - Constructor for exception org.apache.flink.runtime.leaderretrieval.LeaderRetrievalException
 
LeaderRetrievalListener - Interface in org.apache.flink.runtime.leaderretrieval
Classes which want to be notified about a changing leader by the LeaderRetrievalService have to implement this interface.
leaderRetrievalService() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
LeaderRetrievalService - Interface in org.apache.flink.runtime.leaderretrieval
This interface has to be implemented by a service which retrieves the current leader and notifies a listener about it.
leaderRetrievalService() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
 
leaderRetrievalService() - Method in class org.apache.flink.yarn.ApplicationClient
 
leaderRetrievalService() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
LeaderRetrievalUtils - Class in org.apache.flink.runtime.util
Utility class to work with LeaderRetrievalService class.
LeaderRetrievalUtils.LeaderConnectionInfoListener - Class in org.apache.flink.runtime.util
Helper class which is used by the retrieveLeaderConnectionInfo method to retrieve the leader's akka URL and the current leader session ID.
LeaderRetrievalUtils.LeaderGatewayListener - Class in org.apache.flink.runtime.util
Helper class which is used by the retrieveLeaderGateway method as the LeaderRetrievalListener.
leaderSessionID() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
leaderSessionID - Variable in class org.apache.flink.runtime.client.JobClientActor
leader session ID of the JobManager when this actor was created
leaderSessionId() - Method in class org.apache.flink.runtime.clusterframework.messages.NewLeaderAvailable
 
leaderSessionID() - Method in interface org.apache.flink.runtime.instance.ActorGateway
Returns the leaderSessionID associated with the remote actor or null.
leaderSessionID() - Method in class org.apache.flink.runtime.instance.AkkaActorGateway
 
leaderSessionID() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
leaderSessionID() - Method in interface org.apache.flink.runtime.LeaderSessionMessageFilter
 
leaderSessionID() - Method in class org.apache.flink.runtime.messages.JobClientMessages.JobManagerLeaderAddress
 
leaderSessionID() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.GrantLeadership
 
leaderSessionID() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.LeaderSessionMessage
 
leaderSessionID() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.ResponseLeaderSessionID
 
leaderSessionID() - Method in class org.apache.flink.runtime.messages.TaskManagerMessages.JobManagerLeaderAddress
 
leaderSessionID() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
 
leaderSessionID() - Method in class org.apache.flink.yarn.ApplicationClient
 
leaderSessionID() - Method in class org.apache.flink.yarn.YarnMessages.JobManagerLeaderAddress
 
leaderSessionID() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
leaderSessionID_$eq(Option<UUID>) - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
leaderSessionID_$eq(Option<UUID>) - Static method in class org.apache.flink.yarn.YarnTaskManager
 
LeaderSessionIDException - Exception in org.apache.flink.runtime.rpc.exceptions
An exception specifying that the received leader session ID is not the same as expected.
LeaderSessionIDException(UUID, UUID) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.LeaderSessionIDException
 
LeaderSessionMessage(UUID, Object) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.LeaderSessionMessage
 
LeaderSessionMessage$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.LeaderSessionMessage$
 
LeaderSessionMessageDecorator - Class in org.apache.flink.runtime.messages
Message decorator which wraps message which implement RequiresLeaderSessionID into a JobManagerMessages.LeaderSessionMessage.
LeaderSessionMessageDecorator(UUID) - Constructor for class org.apache.flink.runtime.messages.LeaderSessionMessageDecorator
Sets the leader session ID with which the messages will be decorated.
LeaderSessionMessageFilter - Interface in org.apache.flink.runtime
Mixin to filter out LeaderSessionMessage which contain an invalid leader session id.
LEADING() - Method in class org.apache.flink.table.expressions.TrimMode$
 
LEADING() - Static method in class org.apache.flink.table.expressions.TrimMode
 
LeafExpression - Class in org.apache.flink.table.expressions
 
LeafExpression() - Constructor for class org.apache.flink.table.expressions.LeafExpression
 
LeafNode - Class in org.apache.flink.table.plan.logical
 
LeafNode() - Constructor for class org.apache.flink.table.plan.logical.LeafNode
 
LearningRate$() - Constructor for class org.apache.flink.ml.optimization.IterativeSolver.LearningRate$
 
LearningRateMethod - Class in org.apache.flink.ml.optimization
 
LearningRateMethod() - Constructor for class org.apache.flink.ml.optimization.LearningRateMethod
 
LearningRateMethod$ - Class in org.apache.flink.ml.optimization
 
LearningRateMethod$() - Constructor for class org.apache.flink.ml.optimization.LearningRateMethod$
 
LearningRateMethod.Bottou - Class in org.apache.flink.ml.optimization
 
LearningRateMethod.Bottou$ - Class in org.apache.flink.ml.optimization
 
LearningRateMethod.Constant$ - Class in org.apache.flink.ml.optimization
 
LearningRateMethod.Default$ - Class in org.apache.flink.ml.optimization
 
LearningRateMethod.InvScaling - Class in org.apache.flink.ml.optimization
 
LearningRateMethod.InvScaling$ - Class in org.apache.flink.ml.optimization
 
LearningRateMethod.LearningRateMethodTrait - Interface in org.apache.flink.ml.optimization
 
LearningRateMethod.Xu - Class in org.apache.flink.ml.optimization
 
LearningRateMethod.Xu$ - Class in org.apache.flink.ml.optimization
 
LearningRateMethodValue$() - Constructor for class org.apache.flink.ml.optimization.IterativeSolver.LearningRateMethodValue$
 
LearningRateMethodValue$() - Constructor for class org.apache.flink.ml.regression.MultipleLinearRegression.LearningRateMethodValue$
 
leastRestrictive(List<RelDataType>) - Method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
leastRestrictiveStructuredType(List<RelDataType>) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
leaves - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
 
left() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.EitherDescriptor
 
left() - Method in class org.apache.flink.ml.pipeline.ChainedTransformer
 
left() - Method in class org.apache.flink.table.expressions.And
 
left() - Method in class org.apache.flink.table.expressions.BinaryExpression
 
left() - Method in class org.apache.flink.table.expressions.Div
 
left() - Method in class org.apache.flink.table.expressions.EqualTo
 
left() - Method in class org.apache.flink.table.expressions.GreaterThan
 
left() - Method in class org.apache.flink.table.expressions.GreaterThanOrEqual
 
left() - Method in class org.apache.flink.table.expressions.LessThan
 
left() - Method in class org.apache.flink.table.expressions.LessThanOrEqual
 
left() - Method in class org.apache.flink.table.expressions.Like
 
left() - Method in class org.apache.flink.table.expressions.Minus
 
left() - Method in class org.apache.flink.table.expressions.Mod
 
left() - Method in class org.apache.flink.table.expressions.Mul
 
left() - Method in class org.apache.flink.table.expressions.NotEqualTo
 
left() - Method in class org.apache.flink.table.expressions.Or
 
left() - Method in class org.apache.flink.table.expressions.Plus
 
left() - Method in class org.apache.flink.table.expressions.Power
 
left() - Method in class org.apache.flink.table.expressions.Round
 
left() - Method in class org.apache.flink.table.expressions.Similar
 
left() - Method in class org.apache.flink.table.plan.logical.BinaryNode
 
left() - Method in class org.apache.flink.table.plan.logical.Intersect
 
left() - Method in class org.apache.flink.table.plan.logical.Join
 
left() - Method in class org.apache.flink.table.plan.logical.Minus
 
left() - Method in class org.apache.flink.table.plan.logical.Union
 
Left(L) - Static method in class org.apache.flink.types.Either
Create a Left value of Either
left() - Method in class org.apache.flink.types.Either
Retrieve the Left value of Either.
Left(L) - Constructor for class org.apache.flink.types.Either.Left
 
left() - Method in class org.apache.flink.types.Either.Left
 
left() - Method in class org.apache.flink.types.Either.Right
 
leftInput() - Method in class org.apache.flink.api.scala.UnfinishedKeyPairOperation
 
leftOuterJoin(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
Initiates a Left Outer Join transformation.
An Outer Join transformation joins two elements of two DataSets on key equality and provides multiple ways to combine joining elements into one DataSet.
Elements of the left DataSet (i.e.
leftOuterJoin(DataSet<R>, JoinOperatorBase.JoinHint) - Method in class org.apache.flink.api.java.DataSet
Initiates a Left Outer Join transformation.
An Outer Join transformation joins two elements of two DataSets on key equality and provides multiple ways to combine joining elements into one DataSet.
Elements of the left DataSet (i.e.
leftOuterJoin(DataSet<O>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
leftOuterJoin(DataSet<O>, JoinOperatorBase.JoinHint) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
leftOuterJoin(DataSet<O>) - Method in class org.apache.flink.api.scala.DataSet
An outer join on the left side.
leftOuterJoin(DataSet<O>, JoinOperatorBase.JoinHint) - Method in class org.apache.flink.api.scala.DataSet
An outer join on the left side.
leftOuterJoin(Table) - Method in class org.apache.flink.table.api.Table
Joins this Table with an user-defined TableFunction.
leftOuterJoin(Table, String) - Method in class org.apache.flink.table.api.Table
Joins two Tables.
leftOuterJoin(Table, Expression) - Method in class org.apache.flink.table.api.Table
Joins two Tables.
LeftOuterJoinDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
The left outer join driver implements the logic of an outer join operator at runtime.
LeftOuterJoinDriver() - Constructor for class org.apache.flink.runtime.operators.LeftOuterJoinDriver
 
leftOverElement - Variable in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
leftSerializer() - Method in class org.apache.flink.api.scala.typeutils.EitherSerializer
 
leftTemporal() - Method in class org.apache.flink.table.expressions.TemporalOverlaps
 
leftTimePoint() - Method in class org.apache.flink.table.expressions.TemporalOverlaps
 
leftTypeInfo() - Method in class org.apache.flink.api.scala.typeutils.EitherTypeInfo
 
LegacyWindowOperatorType - Enum in org.apache.flink.streaming.api.datastream
For specifying what type of window operator was used to create the state that a WindowOperator is restoring from.
length() - Method in class org.apache.flink.api.avro.FSDataInputStreamWrapper
 
length() - Method in class org.apache.flink.cep.nfa.DeweyNumber
 
length() - Method in class org.apache.flink.runtime.util.DataOutputSerializer
 
length() - Method in class org.apache.flink.table.expressions.Substring
 
length() - Method in class org.apache.flink.types.StringValue
 
LESS_THAN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Logical less-than operator, '<'.
LESS_THAN_OR_EQUAL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Logical less-than-or-equal operator, '<='.
lessThan() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
lessThan() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
LessThan - Class in org.apache.flink.table.expressions
 
LessThan(Expression, Expression) - Constructor for class org.apache.flink.table.expressions.LessThan
 
LessThan$ - Class in org.apache.flink.table.expressions
 
LessThan$() - Constructor for class org.apache.flink.table.expressions.LessThan$
 
lessThanOrEqual(ResourceSpec) - Method in class org.apache.flink.api.common.operators.ResourceSpec
Checks the current resource less than or equal with the other resource by comparing all the fields in the resource.
lessThanOrEqual() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
lessThanOrEqual() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
LessThanOrEqual - Class in org.apache.flink.table.expressions
 
LessThanOrEqual(Expression, Expression) - Constructor for class org.apache.flink.table.expressions.LessThanOrEqual
 
LessThanOrEqual$ - Class in org.apache.flink.table.expressions
 
LessThanOrEqual$() - Constructor for class org.apache.flink.table.expressions.LessThanOrEqual$
 
LIBRARY_CACHE_MANAGER_CLEANUP_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
The config parameter defining the cleanup interval of the library cache manager.
LibraryCacheManager - Interface in org.apache.flink.runtime.execution.librarycache
 
libraryCacheManager() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
libraryCacheManager - Variable in class org.apache.flink.runtime.jobmaster.JobManagerServices
 
LifoSetQueue<E> - Class in org.apache.flink.runtime.jobmanager.scheduler
A queue that returns elements in LIFO order and simultaneously maintains set characteristics, i.e., elements that are already in the queue may not be added another time.
LifoSetQueue() - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.LifoSetQueue
 
LIKE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
like(Expression) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Returns true, if a string matches the specified LIKE pattern.
Like - Class in org.apache.flink.table.expressions
Returns true if str matches pattern.
Like(Expression, Expression) - Constructor for class org.apache.flink.table.expressions.Like
 
Like$ - Class in org.apache.flink.table.expressions
 
Like$() - Constructor for class org.apache.flink.table.expressions.Like$
 
LIKE_WITH_ESCAPE() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
LIKE_WITH_ESCAPE() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
limit(int) - Method in class org.apache.flink.table.api.Table
Limits a sorted result from an offset position.
limit(int, int) - Method in class org.apache.flink.table.api.Table
Limits a sorted result to a specified number of records from an offset position.
limit(int, int) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
Limit - Class in org.apache.flink.table.plan.logical
 
Limit(int, int, LogicalNode) - Constructor for class org.apache.flink.table.plan.logical.Limit
 
Limit$ - Class in org.apache.flink.table.plan.logical
 
Limit$() - Constructor for class org.apache.flink.table.plan.logical.Limit$
 
LimitFilterFunction<T> - Class in org.apache.flink.table.runtime
 
LimitFilterFunction(long, long, String) - Constructor for class org.apache.flink.table.runtime.LimitFilterFunction
 
LINE_WIDTH() - Method in class org.apache.flink.ml.math.DenseMatrix$
 
LINE_WIDTH() - Static method in class org.apache.flink.ml.math.DenseMatrix
 
LinearPrediction - Class in org.apache.flink.ml.optimization
A linear prediction function
LinearPrediction() - Constructor for class org.apache.flink.ml.optimization.LinearPrediction
 
LinearPrediction$ - Class in org.apache.flink.ml.optimization
A linear prediction function
LinearPrediction$() - Constructor for class org.apache.flink.ml.optimization.LinearPrediction$
 
LinearRegression - Class in org.apache.flink.examples.java.ml
This example implements a basic Linear Regression to solve the y = theta0 + theta1*x problem using batch gradient descent algorithm.
LinearRegression() - Constructor for class org.apache.flink.examples.java.ml.LinearRegression
 
LinearRegression - Class in org.apache.flink.examples.scala.ml
This example implements a basic Linear Regression to solve the y = theta0 + theta1*x problem using batch gradient descent algorithm.
LinearRegression() - Constructor for class org.apache.flink.examples.scala.ml.LinearRegression
 
LinearRegression$ - Class in org.apache.flink.examples.scala.ml
This example implements a basic Linear Regression to solve the y = theta0 + theta1*x problem using batch gradient descent algorithm.
LinearRegression$() - Constructor for class org.apache.flink.examples.scala.ml.LinearRegression$
 
LinearRegression.Data - Class in org.apache.flink.examples.java.ml
A simple data sample, x means the input, and y means the target.
LinearRegression.Data - Class in org.apache.flink.examples.scala.ml
 
LinearRegression.Data$ - Class in org.apache.flink.examples.scala.ml
 
LinearRegression.Params - Class in org.apache.flink.examples.java.ml
A set of parameters -- theta0, theta1.
LinearRegression.Params - Class in org.apache.flink.examples.scala.ml
 
LinearRegression.Params$ - Class in org.apache.flink.examples.scala.ml
 
LinearRegression.SubUpdate - Class in org.apache.flink.examples.java.ml
Compute a single BGD type update for every parameters.
LinearRegression.SubUpdate - Class in org.apache.flink.examples.scala.ml
 
LinearRegression.Update - Class in org.apache.flink.examples.java.ml
Compute the final update by average them.
LinearRegression.UpdateAccumulator - Class in org.apache.flink.examples.java.ml
Accumulator all the update.
LinearRegressionData - Class in org.apache.flink.examples.java.ml.util
Provides the default data sets used for the Linear Regression example program.
LinearRegressionData() - Constructor for class org.apache.flink.examples.java.ml.util.LinearRegressionData
 
LinearRegressionDataGenerator - Class in org.apache.flink.examples.java.ml.util
Generates data for the LinearRegression example program.
LinearRegressionDataGenerator() - Constructor for class org.apache.flink.examples.java.ml.util.LinearRegressionDataGenerator
 
LinearTimestamp() - Constructor for class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.LinearTimestamp
 
lineDelimiter - Variable in class org.apache.flink.api.java.io.CsvReader
 
lineDelimiter(String) - Method in class org.apache.flink.api.java.io.CsvReader
Configures the delimiter that separates the lines/rows.
lineDelimiter - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
lineDelimiter(String) - Method in class org.apache.flink.table.sources.CsvTableSource.Builder
Sets the line delimiter, "\n" by default.
lineDelimiterEdges(String) - Method in class org.apache.flink.graph.GraphCsvReader
Configures the Delimiter that separates rows for the CSV reader used to read the edges ('\n') is used by default.
lineDelimiterIsLinebreak - Variable in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
lineDelimiterVertices(String) - Method in class org.apache.flink.graph.GraphCsvReader
Configures the Delimiter that separates rows for the CSV reader used to read the vertices ('\n') is used by default.
Lineitem() - Constructor for class org.apache.flink.examples.java.relational.TPCHQuery3.Lineitem
 
Lineitem(long, double, double, String) - Constructor for class org.apache.flink.examples.scala.relational.TPCHQuery3.Lineitem
 
Lineitem(long, double, double, String) - Constructor for class org.apache.flink.table.examples.scala.TPCHQuery3Table.Lineitem
 
Lineitem$() - Constructor for class org.apache.flink.examples.scala.relational.TPCHQuery3.Lineitem$
 
Lineitem$() - Constructor for class org.apache.flink.table.examples.scala.TPCHQuery3Table.Lineitem$
 
Link(long, long) - Constructor for class org.apache.flink.examples.scala.graph.PageRankBasic.Link
 
Link$() - Constructor for class org.apache.flink.examples.scala.graph.PageRankBasic.Link$
 
links() - Method in class org.apache.flink.ml.recommendation.ALS.OutLinks
 
list(String[]) - Method in class org.apache.flink.client.CliFrontend
Executes the list action.
ListAccumulator<T> - Class in org.apache.flink.api.common.accumulators
This accumulator stores a collection of objects.
ListAccumulator() - Constructor for class org.apache.flink.api.common.accumulators.ListAccumulator
 
ListCheckpointed<T extends Serializable> - Interface in org.apache.flink.streaming.api.checkpoint
This interface can be implemented by functions that want to store state in checkpoints.
ListCollector<T> - Class in org.apache.flink.api.common.functions.util
A Collector that puts the collected elements into a given list.
ListCollector(List<T>) - Constructor for class org.apache.flink.api.common.functions.util.ListCollector
 
listenerManagement() - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
listenerManagement() - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
listenerManagement() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
listenerManagement() - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
listeners() - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
listeners() - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
listeners() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
listeners() - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
ListeningBehaviour - Enum in org.apache.flink.runtime.akka
Defines the listening behaviour of the JobClientActor and thus the messages which are sent from the JobManger to the JobClientActor.
listeningBehaviour() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RegisterJobClient
 
listeningBehaviour() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.SubmitJob
 
listIterator() - Method in class org.apache.flink.types.ListValue
 
listIterator(int) - Method in class org.apache.flink.types.ListValue
 
ListKeyGroupedIterator<E> - Class in org.apache.flink.api.common.operators.util
The KeyValueIterator returns a key and all values that belong to the key (share the same key).
ListKeyGroupedIterator(List<E>, TypeSerializer<E>, TypeComparator<E>) - Constructor for class org.apache.flink.api.common.operators.util.ListKeyGroupedIterator
Initializes the ListKeyGroupedIterator..
ListKeyGroupedIterator.ValuesIterator - Class in org.apache.flink.api.common.operators.util
 
ListMemorySegmentSource - Class in org.apache.flink.runtime.memory
Simple memory segment source that draws segments from a list.
ListMemorySegmentSource(List<MemorySegment>) - Constructor for class org.apache.flink.runtime.memory.ListMemorySegmentSource
 
ListOptions - Class in org.apache.flink.client.cli
Command line options for the LIST command
ListOptions(CommandLine) - Constructor for class org.apache.flink.client.cli.ListOptions
 
ListSerializer<T> - Class in org.apache.flink.api.common.typeutils.base
A serializer for Lists.
ListSerializer(TypeSerializer<T>) - Constructor for class org.apache.flink.api.common.typeutils.base.ListSerializer
Creates a list serializer that uses the given serializer to serialize the list's elements.
ListState<T> - Interface in org.apache.flink.api.common.state
State interface for partitioned list state in Operations.
ListStateDescriptor<T> - Class in org.apache.flink.api.common.state
ListStateDescriptor(String, Class<T>) - Constructor for class org.apache.flink.api.common.state.ListStateDescriptor
Creates a new ListStateDescriptor with the given name and list element type.
ListStateDescriptor(String, TypeInformation<T>) - Constructor for class org.apache.flink.api.common.state.ListStateDescriptor
Creates a new ListStateDescriptor with the given name and list element type.
ListStateDescriptor(String, TypeSerializer<T>) - Constructor for class org.apache.flink.api.common.state.ListStateDescriptor
Creates a new ListStateDescriptor with the given name and list element type.
ListStateDescriptor<T> - Class in org.apache.flink.migration.api.common.state
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
ListStateDescriptor(String, Class<T>) - Constructor for class org.apache.flink.migration.api.common.state.ListStateDescriptor
Deprecated.
Creates a new ListStateDescriptor with the given name and list element type.
ListStateDescriptor(String, TypeInformation<T>) - Constructor for class org.apache.flink.migration.api.common.state.ListStateDescriptor
Deprecated.
Creates a new ListStateDescriptor with the given name and list element type.
ListStateDescriptor(String, TypeSerializer<T>) - Constructor for class org.apache.flink.migration.api.common.state.ListStateDescriptor
Deprecated.
Creates a new ListStateDescriptor with the given name and list element type.
listStatus(Path) - Method in class org.apache.flink.core.fs.FileSystem
List the statuses of the files/directories in the given path if the path is a directory.
listStatus(Path) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
listStatus(Path) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
listStatus(Path) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
 
listStatus(Path) - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
 
listSubCatalogs() - Method in interface org.apache.flink.table.catalog.ExternalCatalog
Gets the names of all sub catalogs registered in this catalog.
listSubCatalogs() - Method in class org.apache.flink.table.catalog.InMemoryExternalCatalog
 
listTables() - Method in interface org.apache.flink.table.catalog.ExternalCatalog
Gets the names of all tables registered in this catalog.
listTables() - Method in class org.apache.flink.table.catalog.InMemoryExternalCatalog
 
ListTypeInfo<T> - Class in org.apache.flink.api.java.typeutils
A TypeInformation for the list types of the Java API.
ListTypeInfo(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.ListTypeInfo
 
ListTypeInfo(TypeInformation<T>) - Constructor for class org.apache.flink.api.java.typeutils.ListTypeInfo
 
ListValue<V extends Value> - Class in org.apache.flink.types
Generic list base type for PACT programs that implements the Value and List interfaces.
ListValue() - Constructor for class org.apache.flink.types.ListValue
Initializes the encapsulated list with an empty ArrayList.
ListValue(Collection<V>) - Constructor for class org.apache.flink.types.ListValue
Initializes the encapsulated list with an ArrayList filled with all object contained in the specified Collection object.
literal(Object) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
literal(String) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
Literal - Class in org.apache.flink.table.expressions
 
Literal(Object, TypeInformation<?>) - Constructor for class org.apache.flink.table.expressions.Literal
 
Literal$ - Class in org.apache.flink.table.expressions
 
Literal$() - Constructor for class org.apache.flink.table.expressions.Literal$
 
LITERAL_CHAIN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
LiteralBooleanExpression(boolean) - Constructor for class org.apache.flink.table.api.scala.ImplicitExpressionConversions.LiteralBooleanExpression
 
LiteralByteExpression(byte) - Constructor for class org.apache.flink.table.api.scala.ImplicitExpressionConversions.LiteralByteExpression
 
LiteralDoubleExpression(double) - Constructor for class org.apache.flink.table.api.scala.ImplicitExpressionConversions.LiteralDoubleExpression
 
literalExpr() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
literalExpr() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
LiteralFloatExpression(float) - Constructor for class org.apache.flink.table.api.scala.ImplicitExpressionConversions.LiteralFloatExpression
 
LiteralIntExpression(int) - Constructor for class org.apache.flink.table.api.scala.ImplicitExpressionConversions.LiteralIntExpression
 
LiteralJavaDecimalExpression(BigDecimal) - Constructor for class org.apache.flink.table.api.scala.ImplicitExpressionConversions.LiteralJavaDecimalExpression
 
LiteralLongExpression(long) - Constructor for class org.apache.flink.table.api.scala.ImplicitExpressionConversions.LiteralLongExpression
 
LiteralScalaDecimalExpression(BigDecimal) - Constructor for class org.apache.flink.table.api.scala.ImplicitExpressionConversions.LiteralScalaDecimalExpression
 
LiteralShortExpression(short) - Constructor for class org.apache.flink.table.api.scala.ImplicitExpressionConversions.LiteralShortExpression
 
LiteralSqlDateExpression(Date) - Constructor for class org.apache.flink.table.api.scala.ImplicitExpressionConversions.LiteralSqlDateExpression
 
LiteralSqlTimeExpression(Time) - Constructor for class org.apache.flink.table.api.scala.ImplicitExpressionConversions.LiteralSqlTimeExpression
 
LiteralSqlTimestampExpression(Timestamp) - Constructor for class org.apache.flink.table.api.scala.ImplicitExpressionConversions.LiteralSqlTimestampExpression
 
LiteralStringExpression(String) - Constructor for class org.apache.flink.table.api.scala.ImplicitExpressionConversions.LiteralStringExpression
 
LN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
ln() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Calculates the natural logarithm of given value.
LN() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
LN() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
Ln - Class in org.apache.flink.table.expressions
 
Ln(Expression) - Constructor for class org.apache.flink.table.expressions.Ln
 
Ln$ - Class in org.apache.flink.table.expressions
 
Ln$() - Constructor for class org.apache.flink.table.expressions.Ln$
 
loadAndValidateSavepoint(JobID, Map<JobVertexID, ExecutionJobVertex>, String, ClassLoader, boolean) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointLoader
Loads a savepoint back as a CompletedCheckpoint.
loadConfigParameters(Configuration) - Static method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
loadConfiguration() - Static method in class org.apache.flink.configuration.GlobalConfiguration
Loads the global configuration from the environment.
loadConfiguration(String) - Static method in class org.apache.flink.configuration.GlobalConfiguration
Loads the configuration files from the specified directory.
loadFailoverStrategy(Configuration, Logger) - Static method in class org.apache.flink.runtime.executiongraph.failover.FailoverStrategyLoader
Loads a FailoverStrategy Factory from the given configuration.
loadGlobalConfigParams() - Static method in class org.apache.flink.api.common.io.DelimitedInputFormat
Deprecated.
Please use loadConfigParameters(Configuration config
loadSavepoint(String, ClassLoader) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointStore
Loads the savepoint at the specified path.
loadSavepointWithHandle(String, ClassLoader) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointStore
Loads the savepoint at the specified path.
loadStateBackendFromConfig(Configuration, ClassLoader, Logger) - Static method in class org.apache.flink.runtime.state.AbstractStateBackend
Loads the state backend from the configuration, from the parameter 'state.backend', as defined in CoreOptions.STATE_BACKEND.
loadStateBackendFromConfigOrCreateDefault(Configuration, ClassLoader, Logger) - Static method in class org.apache.flink.runtime.state.AbstractStateBackend
Loads the state backend from the configuration, from the parameter 'state.backend', as defined in CoreOptions.STATE_BACKEND.
LOCAL() - Method in class org.apache.flink.api.scala.FlinkShell.ExecutionMode$
 
LOCAL_NUMBER_JOB_MANAGER - Static variable in class org.apache.flink.configuration.ConfigConstants
 
LOCAL_NUMBER_RESOURCE_MANAGER - Static variable in class org.apache.flink.configuration.ConfigConstants
 
LOCAL_NUMBER_TASK_MANAGER - Static variable in class org.apache.flink.configuration.ConfigConstants
Sets the number of local task managers
LOCAL_START_WEBSERVER - Static variable in class org.apache.flink.configuration.ConfigConstants
 
LocalBlockLocation - Class in org.apache.flink.core.fs.local
Implementation of the BlockLocation interface for a local file system.
LocalBlockLocation(String, long) - Constructor for class org.apache.flink.core.fs.local.LocalBlockLocation
 
LocalClusteringCoefficient<K extends Comparable<K> & CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.clustering.directed
The local clustering coefficient measures the connectedness of each vertex's neighborhood.
LocalClusteringCoefficient() - Constructor for class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient
 
LocalClusteringCoefficient<K extends Comparable<K> & CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.clustering.undirected
The local clustering coefficient measures the connectedness of each vertex's neighborhood.
LocalClusteringCoefficient() - Constructor for class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient
 
LocalClusteringCoefficient.Result<T> - Class in org.apache.flink.graph.library.clustering.directed
Wraps Tuple3 to encapsulate results from the Local Clustering Coefficient algorithm.
LocalClusteringCoefficient.Result<T> - Class in org.apache.flink.graph.library.clustering.undirected
Wraps Tuple3 to encapsulate results from the Local Clustering Coefficient algorithm.
LocalCollectionOutputFormat<T> - Class in org.apache.flink.api.java.io
An output format that writes record into collection
LocalCollectionOutputFormat(Collection<T>) - Constructor for class org.apache.flink.api.java.io.LocalCollectionOutputFormat
 
LocalConnectionManager - Class in org.apache.flink.runtime.io.network
A connection manager implementation to bypass setup overhead for task managers running in local execution mode.
LocalConnectionManager() - Constructor for class org.apache.flink.runtime.io.network.LocalConnectionManager
 
LocalDataInputStream - Class in org.apache.flink.core.fs.local
The LocalDataInputStream class is a wrapper class for a data input stream to the local file system.
LocalDataInputStream(File) - Constructor for class org.apache.flink.core.fs.local.LocalDataInputStream
Constructs a new LocalDataInputStream object from a given File object.
LocalDataOutputStream - Class in org.apache.flink.core.fs.local
The LocalDataOutputStream class is a wrapper class for a data output stream to the local file system.
LocalDataOutputStream(File) - Constructor for class org.apache.flink.core.fs.local.LocalDataOutputStream
Constructs a new LocalDataOutputStream object from a given File object.
LocalEnvironment - Class in org.apache.flink.api.java
An ExecutionEnvironment that runs the program locally, multi-threaded, in the JVM where the environment is instantiated.
LocalEnvironment() - Constructor for class org.apache.flink.api.java.LocalEnvironment
Creates a new local environment.
LocalEnvironment(Configuration) - Constructor for class org.apache.flink.api.java.LocalEnvironment
Creates a new local environment that configures its local executor with the given configuration.
LocalExecutor - Class in org.apache.flink.client
A PlanExecutor that runs Flink programs on a local embedded Flink runtime instance.
LocalExecutor() - Constructor for class org.apache.flink.client.LocalExecutor
 
LocalExecutor(Configuration) - Constructor for class org.apache.flink.client.LocalExecutor
 
LocalFileStatus - Class in org.apache.flink.core.fs.local
The class LocalFileStatus provides an implementation of the FileStatus interface for the local file system.
LocalFileStatus(File, FileSystem) - Constructor for class org.apache.flink.core.fs.local.LocalFileStatus
Creates a LocalFileStatus object from a given File object.
LocalFileSystem - Class in org.apache.flink.core.fs.local
The class LocalFileSystem is an implementation of the FileSystem interface for the local file system of the machine where the JVM runs.
LocalFileSystem() - Constructor for class org.apache.flink.core.fs.local.LocalFileSystem
Constructs a new LocalFileSystem object.
LocalFlinkMiniCluster - Class in org.apache.flink.runtime.minicluster
Local Flink mini cluster which executes all TaskManagers and the JobManager in the same JVM.
LocalFlinkMiniCluster(Configuration, HighAvailabilityServices, boolean) - Constructor for class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
LocalFlinkMiniCluster(Configuration, boolean) - Constructor for class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
LocalFlinkMiniCluster(Configuration) - Constructor for class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
LocalGetYarnMessage$() - Constructor for class org.apache.flink.yarn.YarnMessages.LocalGetYarnMessage$
 
LocalInputChannel - Class in org.apache.flink.runtime.io.network.partition.consumer
An input channel, which requests a local subpartition.
LocalInputChannel(SingleInputGate, int, ResultPartitionID, ResultPartitionManager, TaskEventDispatcher, TaskIOMetricGroup) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel
 
LocalInputChannel(SingleInputGate, int, ResultPartitionID, ResultPartitionManager, TaskEventDispatcher, int, int, TaskIOMetricGroup) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel
 
LocalIterations$() - Constructor for class org.apache.flink.ml.classification.SVM.LocalIterations$
 
Locality - Enum in org.apache.flink.runtime.jobmanager.scheduler
 
locality() - Method in class org.apache.flink.runtime.jobmanager.slots.SlotAndLocality
 
localJobManagerAddress - Variable in class org.apache.flink.runtime.webmonitor.RuntimeMonitorHandlerBase
 
localJobManagerAddressFuture - Variable in class org.apache.flink.runtime.webmonitor.RuntimeMonitorHandlerBase
 
LocalProperties - Class in org.apache.flink.optimizer.dataproperties
This class represents local properties of the data.
LocalProperties() - Constructor for class org.apache.flink.optimizer.dataproperties.LocalProperties
Default constructor for trivial local properties.
LocalPropertiesPair(RequestedLocalProperties, RequestedLocalProperties) - Constructor for class org.apache.flink.optimizer.operators.OperatorDescriptorDual.LocalPropertiesPair
 
localProps - Variable in class org.apache.flink.optimizer.plan.PlanNode
 
LocalRpcInvocation - Class in org.apache.flink.runtime.rpc.akka.messages
Local rpc invocation message containing the remote procedure name, its parameter types and the corresponding call arguments.
LocalRpcInvocation(String, Class<?>[], Object[]) - Constructor for class org.apache.flink.runtime.rpc.akka.messages.LocalRpcInvocation
 
LocalStopYarnSession(ApplicationStatus, String) - Constructor for class org.apache.flink.yarn.YarnMessages.LocalStopYarnSession
 
LocalStopYarnSession$() - Constructor for class org.apache.flink.yarn.YarnMessages.LocalStopYarnSession$
 
localStrategies - Variable in class org.apache.flink.runtime.operators.BatchTask
The local strategies that are applied on the inputs.
LocalStrategy - Enum in org.apache.flink.runtime.operators.util
Enumeration of all available local processing strategies tasks.
LocalStreamEnvironment - Class in org.apache.flink.streaming.api.environment
The LocalStreamEnvironment is a StreamExecutionEnvironment that runs the program locally, multi-threaded, in the JVM where the environment is instantiated.
LocalStreamEnvironment() - Constructor for class org.apache.flink.streaming.api.environment.LocalStreamEnvironment
Creates a new local stream environment that uses the default configuration.
LocalStreamEnvironment(Configuration) - Constructor for class org.apache.flink.streaming.api.environment.LocalStreamEnvironment
Creates a new local stream environment that configures its local executor with the given configuration.
LOCALTIME - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The LOCALTIME [(precision)] function.
localTime - Class in org.apache.flink.table.api.scala
Returns the current SQL time in local time zone.
localTime() - Constructor for class org.apache.flink.table.api.scala.localTime
 
LocalTime - Class in org.apache.flink.table.expressions
 
LocalTime() - Constructor for class org.apache.flink.table.expressions.LocalTime
 
localTime$ - Class in org.apache.flink.table.api.scala
Returns the current SQL time in local time zone.
localTime$() - Constructor for class org.apache.flink.table.api.scala.localTime$
 
LocalTime$ - Class in org.apache.flink.table.expressions
 
LocalTime$() - Constructor for class org.apache.flink.table.expressions.LocalTime$
 
LOCALTIMESTAMP - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The LOCALTIMESTAMP [(precision)] function.
localTimestamp - Class in org.apache.flink.table.api.scala
Returns the current SQL timestamp in local time zone.
localTimestamp() - Constructor for class org.apache.flink.table.api.scala.localTimestamp
 
LocalTimestamp - Class in org.apache.flink.table.expressions
 
LocalTimestamp() - Constructor for class org.apache.flink.table.expressions.LocalTimestamp
 
localTimestamp$ - Class in org.apache.flink.table.api.scala
Returns the current SQL timestamp in local time zone.
localTimestamp$() - Constructor for class org.apache.flink.table.api.scala.localTimestamp$
 
LocalTimestamp$ - Class in org.apache.flink.table.expressions
 
LocalTimestamp$() - Constructor for class org.apache.flink.table.expressions.LocalTimestamp$
 
LocalTransportException - Exception in org.apache.flink.runtime.io.network.netty.exception
 
LocalTransportException(String, SocketAddress) - Constructor for exception org.apache.flink.runtime.io.network.netty.exception.LocalTransportException
 
LocalTransportException(String, SocketAddress, Throwable) - Constructor for exception org.apache.flink.runtime.io.network.netty.exception.LocalTransportException
 
LocatableInputSplit - Class in org.apache.flink.core.io
A locatable input split is an input split referring to input data which is located on one or more hosts.
LocatableInputSplit(int, String[]) - Constructor for class org.apache.flink.core.io.LocatableInputSplit
Creates a new locatable input split that refers to a multiple host as its data location.
LocatableInputSplit(int, String) - Constructor for class org.apache.flink.core.io.LocatableInputSplit
Creates a new locatable input split that refers to a single host as its data location.
LocatableInputSplitAssigner - Class in org.apache.flink.api.common.io
The locatable input split assigner assigns to each host splits that are local, before assigning splits that are not local.
LocatableInputSplitAssigner(Collection<LocatableInputSplit>) - Constructor for class org.apache.flink.api.common.io.LocatableInputSplitAssigner
 
LocatableInputSplitAssigner(LocatableInputSplit[]) - Constructor for class org.apache.flink.api.common.io.LocatableInputSplitAssigner
 
location() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
location() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
 
location() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
lock(K, V, long, int) - Method in class org.apache.flink.cep.nfa.SharedBuffer
Increases the reference counter for the given value, key, timestamp entry so that it is not accidentally removed.
lock - Variable in class org.apache.flink.runtime.highavailability.nonha.AbstractNonHaServices
 
lockLocation() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
Locks the location of this slot.
LOG - Static variable in class org.apache.flink.addons.hbase.AbstractTableInputFormat
 
LOG - Static variable in class org.apache.flink.api.java.ExecutionEnvironment
The logger used by the environment and its subclasses
LOG() - Method in class org.apache.flink.api.scala.ClosureCleaner$
 
LOG() - Static method in class org.apache.flink.api.scala.ClosureCleaner
 
LOG - Static variable in class org.apache.flink.contrib.streaming.state.RocksDBStateBackendFactory
 
log - Variable in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
 
LOG - Static variable in class org.apache.flink.mesos.runtime.clusterframework.LaunchableMesosWorker
 
LOG - Static variable in class org.apache.flink.mesos.runtime.clusterframework.MesosApplicationMasterRunner
Logger
log() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
log() - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
LOG() - Method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
log() - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
LOG() - Method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
log() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
LOG() - Method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
log() - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
LOG() - Method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
log - Variable in class org.apache.flink.metrics.reporter.AbstractReporter
 
LOG - Static variable in class org.apache.flink.optimizer.dataproperties.GlobalProperties
 
LOG - Static variable in class org.apache.flink.optimizer.dataproperties.LocalProperties
 
LOG - Static variable in class org.apache.flink.optimizer.Optimizer
The log handle that is used by the compiler to log messages.
LOG - Static variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
LOG - Static variable in class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
 
LOG - Static variable in class org.apache.flink.runtime.accumulators.AccumulatorRegistry
 
LOG() - Method in class org.apache.flink.runtime.akka.AkkaUtils$
 
LOG() - Static method in class org.apache.flink.runtime.akka.AkkaUtils
 
LOG - Variable in class org.apache.flink.runtime.akka.FlinkUntypedActor
 
log() - Method in interface org.apache.flink.runtime.FlinkActor
 
log - Variable in class org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
 
LOG - Static variable in class org.apache.flink.runtime.io.disk.iomanager.AbstractFileIOChannel
Logger object for channel and its subclasses
LOG - Static variable in class org.apache.flink.runtime.io.disk.iomanager.IOManager
Logging
LOG() - Method in class org.apache.flink.runtime.jobmanager.JobManager$
 
LOG() - Static method in class org.apache.flink.runtime.jobmanager.JobManager
 
log() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
log() - Method in class org.apache.flink.runtime.jobmanager.MemoryArchivist
 
LOG - Static variable in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
shared logger
LOG() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
LOG - Static variable in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
LOG - Static variable in class org.apache.flink.runtime.operators.BatchTask
 
LOG - Static variable in class org.apache.flink.runtime.operators.JoinDriver
 
LOG - Static variable in class org.apache.flink.runtime.operators.resettable.BlockResettableMutableObjectIterator
 
LOG - Static variable in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
LOG - Static variable in class org.apache.flink.runtime.operators.resettable.ReusingBlockResettableIterator
 
log - Variable in class org.apache.flink.runtime.registration.RegisteredRpcConnection
the logger for all log messages of this class
log - Variable in class org.apache.flink.runtime.rpc.RpcEndpoint
 
LOG - Static variable in class org.apache.flink.runtime.security.DynamicConfiguration
 
LOG() - Method in class org.apache.flink.runtime.taskmanager.TaskManager$
TaskManager logger for synchronous logging (not through the logging actor)
LOG() - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
TaskManager logger for synchronous logging (not through the logging actor)
log() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
 
LOG - Static variable in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
 
LOG - Static variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
The logger used by the operator class and its subclasses.
LOG - Static variable in class org.apache.flink.streaming.connectors.cassandra.CassandraSinkBase
 
LOG - Static variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
 
LOG - Static variable in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
 
LOG - Static variable in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
 
LOG - Static variable in class org.apache.flink.streaming.util.StreamingMultipleProgramsTestBase
 
LOG() - Static method in class org.apache.flink.table.catalog.ExternalCatalogSchema
 
LOG() - Static method in class org.apache.flink.table.catalog.ExternalTableSourceUtil
 
log(Function0<Parsers.Parser<T>>, String) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
LOG() - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
LOG() - Method in interface org.apache.flink.table.util.Logging
 
LOG - Static variable in class org.apache.flink.test.util.SecureTestEnvironment
 
LOG - Static variable in class org.apache.flink.testutils.junit.RetryRule
 
log - Variable in class org.apache.flink.util.TestLogger
 
LOG - Static variable in class org.apache.flink.yarn.AbstractYarnFlinkApplicationMasterRunner
Logger
log() - Method in class org.apache.flink.yarn.ApplicationClient
 
LOG - Static variable in class org.apache.flink.yarn.highavailability.YarnHighAvailabilityServices
Logger for these services, shared with subclasses
LOG - Static variable in class org.apache.flink.yarn.YarnApplicationMasterRunner
Logger
LOG - Static variable in class org.apache.flink.yarn.YarnFlinkApplicationMasterRunner
Logger
LOG - Variable in class org.apache.flink.yarn.YarnResourceManager
 
LOG - Static variable in class org.apache.flink.yarn.YarnTaskExecutorRunner
Logger
log() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
LOG10 - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
log10() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Calculates the base 10 logarithm of given value.
LOG10() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
LOG10() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
Log10 - Class in org.apache.flink.table.expressions
 
Log10(Expression) - Constructor for class org.apache.flink.table.expressions.Log10
 
Log10$ - Class in org.apache.flink.table.expressions
 
Log10$() - Constructor for class org.apache.flink.table.expressions.Log10$
 
log2floor(int) - Static method in class org.apache.flink.util.MathUtils
Computes the logarithm of the given value to the base of 2, rounded down.
log2strict(int) - Static method in class org.apache.flink.util.MathUtils
Computes the logarithm of the given value to the base of 2.
logAndPrintMessage(String) - Method in class org.apache.flink.runtime.client.JobClientActor
 
logAndSysout(String) - Method in class org.apache.flink.client.program.ClusterClient
Logs and prints to sysout if printing to stdout is enabled.
logAndThrowException(Exception, AbstractInvokable) - Static method in class org.apache.flink.runtime.operators.BatchTask
Prints an error message and throws the given exception.
logDir - Static variable in class org.apache.flink.test.util.TestBaseUtils
 
logEnvironmentInfo(Logger, String, String[]) - Static method in class org.apache.flink.runtime.util.EnvironmentInformation
Logs a information about the environment, like code revision, current user, java version, and JVM parameters.
logFailuresOnly - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
Flag indicating whether to accept failures (and log them), or to fail on failures.
logFile - Variable in class org.apache.flink.runtime.webmonitor.WebMonitorUtils.LogFileLocation
 
LogFileRequest$() - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages.LogFileRequest$
 
logger - Static variable in class org.apache.flink.storm.api.FlinkSubmitter
 
Logging - Interface in org.apache.flink.table.util
Helper class to ensure the logger is never serialized.
LoggingHandler() - Constructor for class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor.LoggingHandler
 
logic() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
logic() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
LOGICAL() - Method in class org.apache.flink.table.plan.nodes.FlinkConventions$
 
LOGICAL() - Static method in class org.apache.flink.table.plan.nodes.FlinkConventions
 
LOGICAL_OPT_RULES() - Method in class org.apache.flink.table.plan.rules.FlinkRuleSets$
 
LOGICAL_OPT_RULES() - Static method in class org.apache.flink.table.plan.rules.FlinkRuleSets
 
logicalArity() - Method in class org.apache.flink.table.plan.schema.RowSchema
Returns the arity of the logical record.
logicalFieldNames() - Method in class org.apache.flink.table.plan.schema.RowSchema
Returns the logical fields names including logical fields (i.e.
LogicalNode - Class in org.apache.flink.table.plan.logical
LogicalNode is created and validated as we construct query plan using Table API.
LogicalNode() - Constructor for class org.apache.flink.table.plan.logical.LogicalNode
 
logicalPlan() - Method in class org.apache.flink.table.api.Table
 
LogicalRelNode - Class in org.apache.flink.table.plan.logical
Wrapper for valid logical plans generated from SQL String.
LogicalRelNode(RelNode) - Constructor for class org.apache.flink.table.plan.logical.LogicalRelNode
 
LogicalRelNode$ - Class in org.apache.flink.table.plan.logical
 
LogicalRelNode$() - Constructor for class org.apache.flink.table.plan.logical.LogicalRelNode$
 
LogicalTableFunctionCall - Class in org.apache.flink.table.plan.logical
LogicalNode for calling a user-defined table functions.
LogicalTableFunctionCall(String, TableFunction<?>, Seq<Expression>, TypeInformation<?>, String[], LogicalNode) - Constructor for class org.apache.flink.table.plan.logical.LogicalTableFunctionCall
 
LogicalTableFunctionCall$ - Class in org.apache.flink.table.plan.logical
 
LogicalTableFunctionCall$() - Constructor for class org.apache.flink.table.plan.logical.LogicalTableFunctionCall$
 
logicalType() - Method in class org.apache.flink.table.plan.schema.RowSchema
Returns a logical RelDataType including logical fields (i.e.
LogicalUnnestRule - Class in org.apache.flink.table.plan.rules.logical
 
LogicalUnnestRule(RelOptRuleOperand, String) - Constructor for class org.apache.flink.table.plan.rules.logical.LogicalUnnestRule
 
LogicalUnnestRule$ - Class in org.apache.flink.table.plan.rules.logical
 
LogicalUnnestRule$() - Constructor for class org.apache.flink.table.plan.rules.logical.LogicalUnnestRule$
 
LogicalWindow - Class in org.apache.flink.table.plan.logical
Logical super class for group windows.
LogicalWindow(Expression, Expression) - Constructor for class org.apache.flink.table.plan.logical.LogicalWindow
 
LogicalWindowAggregate - Class in org.apache.flink.table.plan.logical.rel
 
LogicalWindowAggregate(LogicalWindow, Seq<FlinkRelBuilder.NamedWindowProperty>, RelOptCluster, RelTraitSet, RelNode, boolean, ImmutableBitSet, List<ImmutableBitSet>, List<AggregateCall>) - Constructor for class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
LogicalWindowAggregate$ - Class in org.apache.flink.table.plan.logical.rel
 
LogicalWindowAggregate$() - Constructor for class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate$
 
LogicalWindowAggregateRule - Class in org.apache.flink.table.plan.rules.common
 
LogicalWindowAggregateRule(String) - Constructor for class org.apache.flink.table.plan.rules.common.LogicalWindowAggregateRule
 
LogisticLoss - Class in org.apache.flink.ml.optimization
Logistic loss function which can be used with the GenericLossFunction
LogisticLoss() - Constructor for class org.apache.flink.ml.optimization.LogisticLoss
 
LogisticLoss$ - Class in org.apache.flink.ml.optimization
Logistic loss function which can be used with the GenericLossFunction
LogisticLoss$() - Constructor for class org.apache.flink.ml.optimization.LogisticLoss$
 
logMesosConfig(Logger, MesosConfiguration) - Static method in class org.apache.flink.mesos.util.MesosConfiguration
A utility method to log relevant Mesos connection info
LogMessages - Interface in org.apache.flink.runtime
Mixin to add message logging if the debug log level is activated
logPartitionInfo(Logger, List<KafkaTopicPartition>) - Static method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
Logs the partition information in INFO level.
logTermination(FSM.Reason) - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
logTermination(FSM.Reason) - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
logTermination(FSM.Reason) - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
logTermination(FSM.Reason) - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
LONG - Static variable in class org.apache.flink.api.common.typeinfo.Types
 
LONG() - Method in class org.apache.flink.table.api.Types$
 
LONG() - Static method in class org.apache.flink.table.api.Types
 
LONG() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
LONG() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
long2Literal(long) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionConversions
 
LONG_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
LONG_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
LONG_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
LONG_VALUE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
 
LONG_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
LongArrayList - Class in org.apache.flink.runtime.util
Minimal implementation of an array-backed list of longs
LongArrayList(int) - Constructor for class org.apache.flink.runtime.util.LongArrayList
 
LongAvgAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Long Avg aggregate function
LongAvgAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.LongAvgAggFunction
 
LongComparator - Class in org.apache.flink.api.common.typeutils.base
 
LongComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.LongComparator
 
LongCounter - Class in org.apache.flink.api.common.accumulators
An accumulator that sums up long values.
LongCounter() - Constructor for class org.apache.flink.api.common.accumulators.LongCounter
 
LongCounter(long) - Constructor for class org.apache.flink.api.common.accumulators.LongCounter
 
LongExplodeTableFunc - Class in org.apache.flink.table.plan.util
 
LongExplodeTableFunc() - Constructor for class org.apache.flink.table.plan.util.LongExplodeTableFunc
 
LongMaxAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Long Max aggregate function
LongMaxAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.LongMaxAggFunction
 
LongMaximum - Class in org.apache.flink.api.common.accumulators
An accumulator that finds the maximum long value.
LongMaximum() - Constructor for class org.apache.flink.api.common.accumulators.LongMaximum
 
LongMaximum(long) - Constructor for class org.apache.flink.api.common.accumulators.LongMaximum
 
LongMaxWithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Long Max with retraction aggregate function
LongMaxWithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.LongMaxWithRetractAggFunction
 
LongMinAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Long Min aggregate function
LongMinAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.LongMinAggFunction
 
LongMinimum - Class in org.apache.flink.api.common.accumulators
An accumulator that finds the minimum long value.
LongMinimum() - Constructor for class org.apache.flink.api.common.accumulators.LongMinimum
 
LongMinimum(long) - Constructor for class org.apache.flink.api.common.accumulators.LongMinimum
 
LongMinWithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Long Min with retraction aggregate function
LongMinWithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.LongMinWithRetractAggFunction
 
LongParameter - Class in org.apache.flink.graph.drivers.parameter
A Parameter storing a Long.
LongParameter(ParameterizedBase, String) - Constructor for class org.apache.flink.graph.drivers.parameter.LongParameter
Set the parameter name and add this parameter to the list of parameters stored by owner.
LongParser - Class in org.apache.flink.types.parser
Parses a decimal text field into a LongValue.
LongParser() - Constructor for class org.apache.flink.types.parser.LongParser
 
LongPrimitiveArrayComparator - Class in org.apache.flink.api.common.typeutils.base.array
 
LongPrimitiveArrayComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArrayComparator
 
LongPrimitiveArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
A serializer for long arrays.
LongPrimitiveArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
LongSerializer - Class in org.apache.flink.api.common.typeutils.base
 
LongSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.LongSerializer
 
LongSerializer() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.LongSerializer
 
LongSum0AggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Long Sum0 aggregate function
LongSum0AggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.LongSum0AggFunction
 
LongSum0WithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Long Sum0 with retract aggregate function
LongSum0WithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.LongSum0WithRetractAggFunction
 
LongSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.LongSumAgg
 
LongSumAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Long Sum aggregate function
LongSumAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.LongSumAggFunction
 
LongSumAggregator - Class in org.apache.flink.api.common.aggregators
An Aggregator that sums up long values.
LongSumAggregator() - Constructor for class org.apache.flink.api.common.aggregators.LongSumAggregator
 
LongSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
Aggregator that can handle Long types
LongSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator
 
LongSummaryAggregator.MaxLongAggregator - Class in org.apache.flink.api.java.summarize.aggregation
 
LongSummaryAggregator.MinLongAggregator - Class in org.apache.flink.api.java.summarize.aggregation
 
LongSummaryAggregator.SumLongAggregator - Class in org.apache.flink.api.java.summarize.aggregation
 
LongSumWithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Long Sum with retract aggregate function
LongSumWithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.LongSumWithRetractAggFunction
 
longToIntWithBitMixing(long) - Static method in class org.apache.flink.util.MathUtils
Pseudo-randomly maps a long (64-bit) to an integer (32-bit) using some bit-mixing for better distribution.
LongToLongValue - Class in org.apache.flink.graph.asm.translate.translators
Translate Long to LongValue.
LongToLongValue() - Constructor for class org.apache.flink.graph.asm.translate.translators.LongToLongValue
 
LongValue - Class in org.apache.flink.types
Boxed serializable and comparable long integer type, representing the primitive type long.
LongValue() - Constructor for class org.apache.flink.types.LongValue
Initializes the encapsulated long with 0.
LongValue(long) - Constructor for class org.apache.flink.types.LongValue
Initializes the encapsulated long with the specified value.
LongValueAddOffset - Class in org.apache.flink.graph.asm.translate.translators
Translate LongValue by adding a constant offset value.
LongValueAddOffset(long) - Constructor for class org.apache.flink.graph.asm.translate.translators.LongValueAddOffset
Translate LongValue by adding a constant offset value.
LongValueArray - Class in org.apache.flink.graph.types.valuearray
An array of LongValue.
LongValueArray() - Constructor for class org.apache.flink.graph.types.valuearray.LongValueArray
Initializes an expandable array with default capacity.
LongValueArray(int) - Constructor for class org.apache.flink.graph.types.valuearray.LongValueArray
Initializes a fixed-size array with the provided number of bytes.
LongValueArrayComparator - Class in org.apache.flink.graph.types.valuearray
Specialized comparator for LongValueArray based on CopyableValueComparator.
LongValueArrayComparator(boolean) - Constructor for class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
 
LongValueArraySerializer - Class in org.apache.flink.graph.types.valuearray
Specialized serializer for LongValueArray.
LongValueArraySerializer() - Constructor for class org.apache.flink.graph.types.valuearray.LongValueArraySerializer
 
LongValueComparator - Class in org.apache.flink.api.common.typeutils.base
Specialized comparator for LongValue based on CopyableValueComparator.
LongValueComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
LongValueParser - Class in org.apache.flink.types.parser
Parses a decimal text field into a LongValue.
LongValueParser() - Constructor for class org.apache.flink.types.parser.LongValueParser
 
LongValueSequenceIterator - Class in org.apache.flink.util
The LongValueSequenceIterator is an iterator that returns a sequence of numbers (as LongValue)s.
LongValueSequenceIterator(long, long) - Constructor for class org.apache.flink.util.LongValueSequenceIterator
Creates a new splittable iterator, returning the range [from, to].
LongValueSerializer - Class in org.apache.flink.api.common.typeutils.base
 
LongValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
LongValueSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.LongValueSumAgg
 
LongValueSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.LongValueSummaryAggregator
 
LongValueToSignedIntValue - Class in org.apache.flink.graph.asm.translate.translators
Translate LongValue to IntValue.
LongValueToSignedIntValue() - Constructor for class org.apache.flink.graph.asm.translate.translators.LongValueToSignedIntValue
 
LongValueToStringValue - Class in org.apache.flink.graph.asm.translate.translators
Translate LongValue to StringValue.
LongValueToStringValue() - Constructor for class org.apache.flink.graph.asm.translate.translators.LongValueToStringValue
 
LongValueToUnsignedIntValue - Class in org.apache.flink.graph.asm.translate.translators
Translate LongValue to IntValue.
LongValueToUnsignedIntValue() - Constructor for class org.apache.flink.graph.asm.translate.translators.LongValueToUnsignedIntValue
 
LongZeroConvergence - Class in org.apache.flink.api.common.aggregators
A ConvergenceCriterion over an Aggregator that defines convergence as reached once the aggregator holds the value zero.
LongZeroConvergence() - Constructor for class org.apache.flink.api.common.aggregators.LongZeroConvergence
 
lookup() - Static method in class org.apache.flink.runtime.akka.RemoteAddressExtension
 
lookupAggregates(SqlCall) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
 
lookupFunction(String, Seq<Expression>) - Method in class org.apache.flink.table.validate.FunctionCatalog
Lookup and create an expression if we find a match.
lookupGroupExpr(SqlNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
If an expression is structurally identical to one of the group-by expressions, returns a reference to the expression, otherwise returns null.
lookupKvStateLocation(String) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
lookupKvStateLocation(String) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
Requests a KvStateLocation for the specified InternalKvState registration name.
LookupKvStateLocation(JobID, String) - Constructor for class org.apache.flink.runtime.query.KvStateMessage.LookupKvStateLocation
Requests a KvStateLocation for the specified JobID and InternalKvState registration name.
lookupMatch(PT) - Method in class org.apache.flink.api.common.operators.util.JoinHashMap.Prober
 
loss(LabeledVector, WeightVector) - Static method in class org.apache.flink.ml.optimization.GenericLossFunction
 
loss(double, double) - Method in class org.apache.flink.ml.optimization.HingeLoss$
Calculates the loss for a given prediction/truth pair
loss(double, double) - Static method in class org.apache.flink.ml.optimization.HingeLoss
Calculates the loss for a given prediction/truth pair
loss(double, double) - Method in class org.apache.flink.ml.optimization.LogisticLoss$
Calculates the loss depending on the label and the prediction
loss(double, double) - Static method in class org.apache.flink.ml.optimization.LogisticLoss
Calculates the loss depending on the label and the prediction
loss(LabeledVector, WeightVector) - Method in interface org.apache.flink.ml.optimization.LossFunction
Calculates the loss given the prediction and label value
loss(double, double) - Method in interface org.apache.flink.ml.optimization.PartialLossFunction
Calculates the loss depending on the label and the prediction
loss(double, double) - Method in class org.apache.flink.ml.optimization.SquaredLoss$
Calculates the loss depending on the label and the prediction
loss(double, double) - Static method in class org.apache.flink.ml.optimization.SquaredLoss
Calculates the loss depending on the label and the prediction
LossFunction - Interface in org.apache.flink.ml.optimization
Abstract class that implements some of the functionality for common loss functions
lossFunction() - Method in class org.apache.flink.ml.regression.MultipleLinearRegression$
 
lossFunction() - Static method in class org.apache.flink.ml.regression.MultipleLinearRegression
 
LossFunction$() - Constructor for class org.apache.flink.ml.optimization.Solver.LossFunction$
 
lossGradient(LabeledVector, WeightVector) - Method in class org.apache.flink.ml.optimization.GenericLossFunction
Calculates the gradient as well as the loss given a data point and the weight vector
lossGradient(LabeledVector, WeightVector) - Method in interface org.apache.flink.ml.optimization.LossFunction
Calculates the gradient as well as the loss given a data point and the weight vector
LOWER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
Lower - Class in org.apache.flink.table.expressions
Returns str with all characters changed to lowercase.
Lower(Expression) - Constructor for class org.apache.flink.table.expressions.Lower
 
Lower$ - Class in org.apache.flink.table.expressions
 
Lower$() - Constructor for class org.apache.flink.table.expressions.Lower$
 
lowerCase() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Returns all of the characters in a string in lower case using the rules of the default locale.
lowerPart - Variable in class org.apache.flink.util.AbstractID
The lower part of the actual ID
LRUCache<V> - Class in org.apache.flink.runtime.util
 
LRUCache() - Constructor for class org.apache.flink.runtime.util.LRUCache
 
LRUCacheMap<K,V> - Class in org.apache.flink.runtime.util
 
LRUCacheMap() - Constructor for class org.apache.flink.runtime.util.LRUCacheMap
 

M

MacroContextHolder<C extends scala.reflect.macros.Context> - Class in org.apache.flink.api.scala.codegen
 
MacroContextHolder(C) - Constructor for class org.apache.flink.api.scala.codegen.MacroContextHolder
 
MacroContextHolder$ - Class in org.apache.flink.api.scala.codegen
 
MacroContextHolder$() - Constructor for class org.apache.flink.api.scala.codegen.MacroContextHolder$
 
MAGIC_NUMBER - Static variable in class org.apache.flink.runtime.checkpoint.savepoint.SavepointStore
Magic number for sanity checks against stored savepoints.
magnitude() - Method in class org.apache.flink.ml.math.DenseVector
Magnitude of a vector
magnitude() - Method in class org.apache.flink.ml.math.SparseVector
Magnitude of a vector
magnitude() - Method in interface org.apache.flink.ml.math.Vector
Magnitude of a vector
main(String[]) - Static method in class org.apache.flink.api.java.JarHelper
 
main(String[]) - Method in class org.apache.flink.api.scala.FlinkShell$
 
main(String[]) - Static method in class org.apache.flink.api.scala.FlinkShell
 
main(String[]) - Static method in class org.apache.flink.client.CliFrontend
Submits the job based on the arguments
main(String[]) - Static method in class org.apache.flink.examples.java.clustering.KMeans
 
main(String[]) - Static method in class org.apache.flink.examples.java.clustering.util.KMeansDataGenerator
Main method to generate data for the KMeans example program.
main(String[]) - Static method in class org.apache.flink.examples.java.distcp.DistCp
 
main(String...) - Static method in class org.apache.flink.examples.java.graph.ConnectedComponents
 
main(String[]) - Static method in class org.apache.flink.examples.java.graph.EnumTriangles
 
main(String[]) - Static method in class org.apache.flink.examples.java.graph.PageRank
 
main(String...) - Static method in class org.apache.flink.examples.java.graph.TransitiveClosureNaive
 
main(String[]) - Static method in class org.apache.flink.examples.java.misc.CollectionExecutionExample
 
main(String[]) - Static method in class org.apache.flink.examples.java.misc.PiEstimation
 
main(String[]) - Static method in class org.apache.flink.examples.java.ml.LinearRegression
 
main(String[]) - Static method in class org.apache.flink.examples.java.ml.util.LinearRegressionDataGenerator
Main method to generate data for the LinearRegression example program.
main(String[]) - Static method in class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator
 
main(String[]) - Static method in class org.apache.flink.examples.java.relational.TPCHQuery10
 
main(String[]) - Static method in class org.apache.flink.examples.java.relational.TPCHQuery3
 
main(String[]) - Static method in class org.apache.flink.examples.java.relational.util.WebLogDataGenerator
Main method to generate data for the WebLogAnalysis example program.
main(String[]) - Static method in class org.apache.flink.examples.java.relational.WebLogAnalysis
 
main(String[]) - Static method in class org.apache.flink.examples.java.wordcount.WordCount
 
main(String[]) - Static method in class org.apache.flink.examples.java.wordcount.WordCountPojo
 
main(String[]) - Method in class org.apache.flink.examples.scala.clustering.KMeans$
 
main(String[]) - Static method in class org.apache.flink.examples.scala.clustering.KMeans
 
main(String[]) - Method in class org.apache.flink.examples.scala.graph.ConnectedComponents$
 
main(String[]) - Static method in class org.apache.flink.examples.scala.graph.ConnectedComponents
 
main(String[]) - Method in class org.apache.flink.examples.scala.graph.DeltaPageRank$
 
main(String[]) - Static method in class org.apache.flink.examples.scala.graph.DeltaPageRank
 
main(String[]) - Method in class org.apache.flink.examples.scala.graph.EnumTriangles$
 
main(String[]) - Static method in class org.apache.flink.examples.scala.graph.EnumTriangles
 
main(String[]) - Method in class org.apache.flink.examples.scala.graph.PageRankBasic$
 
main(String[]) - Static method in class org.apache.flink.examples.scala.graph.PageRankBasic
 
main(String[]) - Method in class org.apache.flink.examples.scala.graph.TransitiveClosureNaive$
 
main(String[]) - Static method in class org.apache.flink.examples.scala.graph.TransitiveClosureNaive
 
main(String[]) - Method in class org.apache.flink.examples.scala.misc.PiEstimation$
 
main(String[]) - Static method in class org.apache.flink.examples.scala.misc.PiEstimation
 
main(String[]) - Method in class org.apache.flink.examples.scala.ml.LinearRegression$
 
main(String[]) - Static method in class org.apache.flink.examples.scala.ml.LinearRegression
 
main(String[]) - Method in class org.apache.flink.examples.scala.relational.TPCHQuery10$
 
main(String[]) - Static method in class org.apache.flink.examples.scala.relational.TPCHQuery10
 
main(String[]) - Method in class org.apache.flink.examples.scala.relational.TPCHQuery3$
 
main(String[]) - Static method in class org.apache.flink.examples.scala.relational.TPCHQuery3
 
main(String[]) - Method in class org.apache.flink.examples.scala.relational.WebLogAnalysis$
 
main(String[]) - Static method in class org.apache.flink.examples.scala.relational.WebLogAnalysis
 
main(String[]) - Method in class org.apache.flink.examples.scala.wordcount.WordCount$
 
main(String[]) - Static method in class org.apache.flink.examples.scala.wordcount.WordCount
 
main(String[]) - Static method in class org.apache.flink.graph.examples.EuclideanGraphWeighing
 
main(String[]) - Static method in class org.apache.flink.graph.examples.GSASingleSourceShortestPaths
 
main(String[]) - Static method in class org.apache.flink.graph.examples.IncrementalSSSP
 
main(String[]) - Static method in class org.apache.flink.graph.examples.MusicProfiles
 
main(String[]) - Static method in class org.apache.flink.graph.examples.PregelSSSP
 
main(String[]) - Static method in class org.apache.flink.graph.examples.SingleSourceShortestPaths
 
main(String[]) - Static method in class org.apache.flink.graph.Runner
 
main(String[]) - Method in class org.apache.flink.graph.scala.examples.ConnectedComponents$
 
main(String[]) - Static method in class org.apache.flink.graph.scala.examples.ConnectedComponents
 
main(String[]) - Method in class org.apache.flink.graph.scala.examples.GSASingleSourceShortestPaths$
 
main(String[]) - Static method in class org.apache.flink.graph.scala.examples.GSASingleSourceShortestPaths
 
main(String[]) - Method in class org.apache.flink.graph.scala.examples.SingleSourceShortestPaths$
 
main(String[]) - Static method in class org.apache.flink.graph.scala.examples.SingleSourceShortestPaths
 
main(String[]) - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosApplicationMasterRunner
The entry point for the Mesos AppMaster.
main(String[]) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager$
Entry point (main method) to run the TaskManager on Mesos.
main(String[]) - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
Entry point (main method) to run the TaskManager on Mesos.
main(String[]) - Static method in class org.apache.flink.python.api.PythonPlanBinder
Entry point for the execution of a python plan.
main(String[]) - Method in class org.apache.flink.runtime.jobmanager.JobManager$
Entry point (main method) to run the JobManager in a standalone fashion.
main(String[]) - Static method in class org.apache.flink.runtime.jobmanager.JobManager
Entry point (main method) to run the JobManager in a standalone fashion.
main(String[]) - Method in class org.apache.flink.runtime.taskmanager.TaskManager$
Entry point (main method) to run the TaskManager in a standalone fashion.
main(String[]) - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
Entry point (main method) to run the TaskManager in a standalone fashion.
main(String[]) - Static method in class org.apache.flink.runtime.webmonitor.history.HistoryServer
 
main(String[]) - Static method in class org.apache.flink.runtime.zookeeper.FlinkZooKeeperQuorumPeer
 
main(String[]) - Static method in class org.apache.flink.storm.exclamation.ExclamationLocal
 
main(String[]) - Static method in class org.apache.flink.storm.exclamation.ExclamationWithBolt
 
main(String[]) - Static method in class org.apache.flink.storm.exclamation.ExclamationWithSpout
 
main(String[]) - Static method in class org.apache.flink.storm.join.SingleJoinExample
 
main(String[]) - Static method in class org.apache.flink.storm.print.PrintSampleStream
 
main(String[]) - Static method in class org.apache.flink.storm.split.SpoutSplitExample
 
main(String[]) - Static method in class org.apache.flink.storm.wordcount.BoltTokenizerWordCount
 
main(String[]) - Static method in class org.apache.flink.storm.wordcount.BoltTokenizerWordCountPojo
 
main(String[]) - Static method in class org.apache.flink.storm.wordcount.BoltTokenizerWordCountWithNames
 
main(String[]) - Static method in class org.apache.flink.storm.wordcount.SpoutSourceWordCount
 
main(String[]) - Static method in class org.apache.flink.storm.wordcount.WordCountLocal
 
main(String[]) - Static method in class org.apache.flink.storm.wordcount.WordCountLocalByName
 
main(String[]) - Static method in class org.apache.flink.storm.wordcount.WordCountRemoteByClient
 
main(String[]) - Static method in class org.apache.flink.storm.wordcount.WordCountRemoteBySubmitter
 
main(String[]) - Static method in class org.apache.flink.streaming.examples.async.AsyncIOExample
 
main(String[]) - Static method in class org.apache.flink.streaming.examples.iteration.IterateExample
 
main(String[]) - Static method in class org.apache.flink.streaming.examples.join.WindowJoin
 
main(String[]) - Static method in class org.apache.flink.streaming.examples.kafka.ReadFromKafka
 
main(String[]) - Static method in class org.apache.flink.streaming.examples.kafka.WriteIntoKafka
 
main(String[]) - Static method in class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton
 
main(String[]) - Static method in class org.apache.flink.streaming.examples.sideoutput.SideOutputExample
 
main(String[]) - Static method in class org.apache.flink.streaming.examples.socket.SocketWindowWordCount
 
main(String[]) - Static method in class org.apache.flink.streaming.examples.twitter.TwitterExample
 
main(String[]) - Static method in class org.apache.flink.streaming.examples.windowing.GroupedProcessingTimeWindowExample
 
main(String[]) - Static method in class org.apache.flink.streaming.examples.windowing.SessionWindowing
 
main(String[]) - Static method in class org.apache.flink.streaming.examples.windowing.TopSpeedWindowing
 
main(String[]) - Static method in class org.apache.flink.streaming.examples.windowing.WindowWordCount
 
main(String[]) - Static method in class org.apache.flink.streaming.examples.wordcount.PojoExample
 
main(String[]) - Static method in class org.apache.flink.streaming.examples.wordcount.WordCount
 
main(String[]) - Method in class org.apache.flink.streaming.scala.examples.async.AsyncIOExample$
 
main(String[]) - Static method in class org.apache.flink.streaming.scala.examples.async.AsyncIOExample
 
main(String[]) - Method in class org.apache.flink.streaming.scala.examples.join.WindowJoin$
 
main(String[]) - Static method in class org.apache.flink.streaming.scala.examples.join.WindowJoin
 
main(String[]) - Method in class org.apache.flink.streaming.scala.examples.socket.SocketWindowWordCount$
Main program method
main(String[]) - Static method in class org.apache.flink.streaming.scala.examples.socket.SocketWindowWordCount
Main program method
main(String[]) - Method in class org.apache.flink.streaming.scala.examples.windowing.TopSpeedWindowing$
 
main(String[]) - Static method in class org.apache.flink.streaming.scala.examples.windowing.TopSpeedWindowing
 
main(String[]) - Static method in class org.apache.flink.table.examples.java.WordCountSQL
 
main(String[]) - Static method in class org.apache.flink.table.examples.java.WordCountTable
 
main(String[]) - Method in class org.apache.flink.table.examples.scala.StreamSQLExample$
 
main(String[]) - Static method in class org.apache.flink.table.examples.scala.StreamSQLExample
 
main(String[]) - Method in class org.apache.flink.table.examples.scala.StreamTableExample$
 
main(String[]) - Static method in class org.apache.flink.table.examples.scala.StreamTableExample
 
main(String[]) - Method in class org.apache.flink.table.examples.scala.TPCHQuery3Table$
 
main(String[]) - Static method in class org.apache.flink.table.examples.scala.TPCHQuery3Table
 
main(String[]) - Method in class org.apache.flink.table.examples.scala.WordCountSQL$
 
main(String[]) - Static method in class org.apache.flink.table.examples.scala.WordCountSQL
 
main(String[]) - Method in class org.apache.flink.table.examples.scala.WordCountTable$
 
main(String[]) - Static method in class org.apache.flink.table.examples.scala.WordCountTable
 
main(String[]) - Static method in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
 
main(String[]) - Static method in class org.apache.flink.yarn.YarnApplicationMasterRunner
The entry point for the YARN application master.
main(String[]) - Static method in class org.apache.flink.yarn.YarnFlinkApplicationMasterRunner
The entry point for the YARN application master.
main(String[]) - Static method in class org.apache.flink.yarn.YarnTaskExecutorRunner
The entry point for the YARN task executor runner.
main(String[]) - Method in class org.apache.flink.yarn.YarnTaskManager$
Entry point (main method) to run the TaskManager on YARN.
main(String[]) - Static method in class org.apache.flink.yarn.YarnTaskManager
Entry point (main method) to run the TaskManager on YARN.
MainThreadExecutable - Interface in org.apache.flink.runtime.rpc
Interface to execute Runnable and Callable in the main thread of the underlying RPC endpoint.
MainThreadValidatorUtil - Class in org.apache.flink.runtime.rpc
This utility exists to bridge between the visibility of the currentMainThread field in the RpcEndpoint.
MainThreadValidatorUtil(RpcEndpoint<?>) - Constructor for class org.apache.flink.runtime.rpc.MainThreadValidatorUtil
 
makeCached() - Method in enum org.apache.flink.optimizer.dag.TempMode
 
makeChildren() - Method in class org.apache.flink.ml.nn.QuadTree.Node
Makes children nodes by partitioning the box into equal sub-boxes and adding a node for each sub-box
makeCoGroupWithSolutionSet(int) - Method in class org.apache.flink.optimizer.dag.CoGroupNode
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.api.CurrentRange
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.api.CurrentRow
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.api.UnboundedRange
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.api.UnboundedRow
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Abs
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Acos
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.AggFunctionCall
 
makeCopy(Object[]) - Method in class org.apache.flink.table.expressions.Alias
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.And
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.ArrayCardinality
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.ArrayConstructor
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.ArrayElement
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.ArrayElementAt
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Asc
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Asin
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Atan
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Avg
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Call
 
makeCopy(Object[]) - Method in class org.apache.flink.table.expressions.Cast
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Ceil
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.CharLength
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Cos
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Cot
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Count
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.CurrentDate
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.CurrentTime
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.CurrentTimestamp
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Degrees
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Desc
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Div
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.EqualTo
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Exp
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Extract
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Flattening
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Floor
 
makeCopy(Object[]) - Method in class org.apache.flink.table.expressions.GetCompositeField
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.GreaterThan
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.GreaterThanOrEqual
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.If
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.InitCap
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.IsFalse
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.IsNotFalse
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.IsNotNull
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.IsNotTrue
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.IsNull
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.IsTrue
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.LessThan
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.LessThanOrEqual
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Like
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Literal
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Ln
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.LocalTime
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.LocalTimestamp
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Log10
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Lower
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Max
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Min
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Minus
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Mod
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Mul
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Not
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.NotEqualTo
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Null
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Or
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.OverCall
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Overlay
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Pi
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Plus
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Position
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Power
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.ProctimeAttribute
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Quarter
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Radians
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.ResolvedFieldReference
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Round
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.RowtimeAttribute
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.ScalarFunctionCall
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Sign
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Similar
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Sin
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Sqrt
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.StddevPop
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.StddevSamp
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Substring
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Sum
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Sum0
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.SymbolExpression
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.TableFunctionCall
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Tan
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.TemporalCeil
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.TemporalFloor
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.TemporalOverlaps
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Trim
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.UnaryMinus
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.UnresolvedAlias
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.UnresolvedFieldReference
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.UnresolvedOverCall
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.Upper
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.VarPop
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.VarSamp
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.WindowEnd
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.WindowReference
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.expressions.WindowStart
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.plan.logical.Aggregate
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.plan.logical.AliasNode
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.plan.logical.CatalogNode
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.plan.logical.Distinct
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.plan.logical.Filter
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.plan.logical.Intersect
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.plan.logical.Join
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.plan.logical.Limit
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.plan.logical.LogicalRelNode
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.plan.logical.LogicalTableFunctionCall
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.plan.logical.Minus
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.plan.logical.Project
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.plan.logical.Sort
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.plan.logical.Union
 
makeCopy(Object[]) - Static method in class org.apache.flink.table.plan.logical.WindowAggregate
 
makeCopy(Object[]) - Method in class org.apache.flink.table.plan.TreeNode
Creates a new copy of this expression with new children.
makeCost(double, double, double) - Method in class org.apache.flink.table.plan.cost.DataSetCostFactory
 
makeHugeCost() - Method in class org.apache.flink.table.plan.cost.DataSetCostFactory
 
makeInfiniteCost() - Method in class org.apache.flink.table.plan.cost.DataSetCostFactory
 
makeJoinWithSolutionSet(int) - Method in class org.apache.flink.optimizer.dag.JoinNode
 
makeNonCached() - Method in enum org.apache.flink.optimizer.dag.TempMode
 
makePipelineBreaker() - Method in enum org.apache.flink.optimizer.dag.TempMode
 
makeQualified(FileSystem) - Method in class org.apache.flink.core.fs.Path
Returns a qualified path object.
makeRegular() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
makeSpace(int) - Method in class org.apache.flink.types.Record
Reserves space for at least the given number of fields in the internal arrays.
makeStart() - Method in class org.apache.flink.cep.nfa.State
 
makeTinyCost() - Method in class org.apache.flink.table.plan.cost.DataSetCostFactory
 
makeTransition(FSM.State<S, D>) - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
makeTransition(FSM.State<S, D>) - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
makeTransition(FSM.State<S, D>) - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
makeTransition(FSM.State<S, D>) - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
makeZeroCost() - Method in class org.apache.flink.table.plan.cost.DataSetCostFactory
 
MalformedPatternException - Exception in org.apache.flink.cep.pattern
An exception used to indicate that a Pattern was not specified correctly.
MalformedPatternException(String) - Constructor for exception org.apache.flink.cep.pattern.MalformedPatternException
 
MANAGED_MEMORY_FRACTION - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Fraction of free memory allocated by the memory manager if TaskManagerOptions.MANAGED_MEMORY_SIZE is not set.
MANAGED_MEMORY_PRE_ALLOCATE - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Whether TaskManager managed memory should be pre-allocated when the TaskManager is starting.
MANAGED_MEMORY_SIZE - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Amount of memory to be allocated by the task manager's memory manager (in megabytes).
ManagedInitializationContext - Interface in org.apache.flink.runtime.state
This interface provides a context in which operators can initialize by registering to managed state (i.e.
ManagedSnapshotContext - Interface in org.apache.flink.runtime.state
This interface provides a context in which operators that use managed state (i.e.
ManhattanDistanceMetric - Class in org.apache.flink.ml.metrics.distances
This class implements a Manhattan distance metric.
ManhattanDistanceMetric() - Constructor for class org.apache.flink.ml.metrics.distances.ManhattanDistanceMetric
 
ManhattanDistanceMetric$ - Class in org.apache.flink.ml.metrics.distances
 
ManhattanDistanceMetric$() - Constructor for class org.apache.flink.ml.metrics.distances.ManhattanDistanceMetric$
 
MANIFEST_ATTRIBUTE_ASSEMBLER_CLASS - Static variable in class org.apache.flink.client.program.PackagedProgram
Property name of the entry in JAR manifest file that describes the Flink specific entry point.
MANIFEST_ATTRIBUTE_MAIN_CLASS - Static variable in class org.apache.flink.client.program.PackagedProgram
Property name of the entry in JAR manifest file that describes the class with the main method.
ManuallyTriggeredDirectExecutor - Class in org.apache.flink.core.testutils
An executor that does not immediately execute a Runnable, but only executes it upon an explicit trigger.
ManuallyTriggeredDirectExecutor() - Constructor for class org.apache.flink.core.testutils.ManuallyTriggeredDirectExecutor
 
map(T) - Method in interface org.apache.flink.api.common.functions.MapFunction
The mapping method.
map(IN) - Method in class org.apache.flink.api.common.functions.RichMapFunction
 
map(MapFunction<T, R>) - Method in class org.apache.flink.api.java.DataSet
Applies a Map transformation on this DataSet.
The transformation calls a MapFunction for each element of the DataSet.
map(T) - Method in class org.apache.flink.api.java.functions.FormattingMapper
 
map(T) - Method in class org.apache.flink.api.java.operators.translation.KeyExtractingMapper
 
map(Tuple2<K, T>) - Method in class org.apache.flink.api.java.operators.translation.KeyRemovingMapper
 
map(Tuple) - Method in class org.apache.flink.api.java.operators.translation.PlanProjectOperator.MapProjector
 
map(T) - Method in class org.apache.flink.api.java.operators.translation.TwoKeyExtractingMapper
 
map(MapFunction<T, R>, TypeInformation<R>, ClassTag<R>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
map(Function1<T, R>, TypeInformation<R>, ClassTag<R>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
map(MapFunction<T, R>, TypeInformation<R>, ClassTag<R>) - Method in class org.apache.flink.api.scala.DataSet
Creates a new DataSet by applying the given function to every element of this DataSet.
map(Function1<T, R>, TypeInformation<R>, ClassTag<R>) - Method in class org.apache.flink.api.scala.DataSet
Creates a new DataSet by applying the given function to every element of this DataSet.
map(Tuple3<Integer, KMeans.Point, Long>) - Method in class org.apache.flink.examples.java.clustering.KMeans.CentroidAverager
 
map(Tuple2<Integer, KMeans.Point>) - Method in class org.apache.flink.examples.java.clustering.KMeans.CountAppender
 
map(KMeans.Point) - Method in class org.apache.flink.examples.java.clustering.KMeans.SelectNearestCenter
 
map(T) - Method in class org.apache.flink.examples.java.graph.ConnectedComponents.DuplicateValue
 
map(Tuple2<Integer, Integer>) - Method in class org.apache.flink.examples.java.graph.EnumTriangles.TupleEdgeConverter
 
map(Tuple2<Long, Double>) - Method in class org.apache.flink.examples.java.graph.PageRank.Dampener
 
map(Long) - Method in class org.apache.flink.examples.java.graph.PageRank.RankAssigner
 
map(Long) - Method in class org.apache.flink.examples.java.misc.PiEstimation.Sampler
 
map(LinearRegression.Data) - Method in class org.apache.flink.examples.java.ml.LinearRegression.SubUpdate
 
map(Tuple2<LinearRegression.Params, Integer>) - Method in class org.apache.flink.examples.java.ml.LinearRegression.Update
 
map(KMeans.Point) - Method in class org.apache.flink.examples.scala.clustering.KMeans.SelectNearestCenter
 
map(LinearRegression.Data) - Method in class org.apache.flink.examples.scala.ml.LinearRegression.SubUpdate
 
map(Edge<K, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.DegreeAnnotationFunctions.MapEdgeToSourceId
 
map(Edge<K, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.DegreeAnnotationFunctions.MapEdgeToTargetId
 
map(String) - Method in class org.apache.flink.graph.examples.MusicProfiles.ExtractMismatchSongIds
 
map(Vertex<K, Long>) - Method in class org.apache.flink.graph.library.CommunityDetection.AddScoreToVertexValuesMapper
 
map(Vertex<K, Tuple2<Long, Double>>) - Method in class org.apache.flink.graph.library.CommunityDetection.RemoveScoreFromVertexValuesMapper
 
map(Vertex<K, VV>) - Method in class org.apache.flink.graph.library.GSASingleSourceShortestPaths.InitVerticesMapper
 
map(Vertex<K, VV>) - Method in class org.apache.flink.graph.library.SingleSourceShortestPaths.InitVerticesMapper
 
map(Edge<K, EV>) - Method in class org.apache.flink.graph.scala.utils.EdgeToTuple3Map
 
map(Tuple2<K, VV>) - Method in class org.apache.flink.graph.scala.utils.Tuple2ToVertexMap
 
map(Tuple3<K, K, EV>) - Method in class org.apache.flink.graph.scala.utils.Tuple3ToEdgeMap
 
map(Vertex<K, VV>) - Method in class org.apache.flink.graph.scala.utils.VertexToTuple2Map
 
map(Edge<K, EV>) - Method in class org.apache.flink.graph.utils.EdgeToTuple2Map
 
map(Edge<K, EV>) - Method in class org.apache.flink.graph.utils.EdgeToTuple3Map
 
map(T) - Method in class org.apache.flink.graph.utils.GraphUtils.IdentityMapper
 
map(I) - Method in class org.apache.flink.graph.utils.GraphUtils.MapTo
 
map(T) - Method in class org.apache.flink.graph.utils.GraphUtils.NonForwardingIdentityMapper
 
map(Tuple2<K, K>) - Method in class org.apache.flink.graph.utils.Tuple2ToEdgeMap
 
map(Tuple2<K, VV>) - Method in class org.apache.flink.graph.utils.Tuple2ToVertexMap
 
map(Tuple3<K, K, EV>) - Method in class org.apache.flink.graph.utils.Tuple3ToEdgeMap
 
map(Vertex<K, VV>) - Method in class org.apache.flink.graph.utils.VertexToTuple2Map
 
map() - Method in class org.apache.flink.ml.common.ParameterMap
 
map(Tuple2<T, byte[]>) - Method in class org.apache.flink.python.api.functions.util.KeyDiscarder
 
map(IN) - Method in class org.apache.flink.python.api.functions.util.NestedKeyDiscarder
 
map(IN) - Method in class org.apache.flink.python.api.functions.util.SerializerMap
 
map(byte[]) - Method in class org.apache.flink.python.api.functions.util.StringDeserializerMap
 
map(byte[]) - Method in class org.apache.flink.python.api.functions.util.StringTupleDeserializerMap
 
map(Tuple2<Integer, T>) - Method in class org.apache.flink.runtime.operators.udf.RemoveRangeIndex
 
map(EvictingBoundedList.Function<T, R>) - Method in class org.apache.flink.runtime.util.EvictingBoundedList
Creates a new list that replaces its elements with transformed elements.
map(Integer) - Method in class org.apache.flink.storm.split.SpoutSplitExample.Enrich
 
map(SplitStreamType<T>) - Method in class org.apache.flink.storm.util.SplitStreamMapper
 
map(CoMapFunction<IN1, IN2, R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
Applies a CoMap transformation on a ConnectedStreams and maps the output to a common type.
map(MapFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Applies a Map transformation on a DataStream.
map(Function1<IN1, R>, Function1<IN2, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.ConnectedStreams
Applies a CoMap transformation on the connected streams.
map(CoMapFunction<IN1, IN2, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.ConnectedStreams
Applies a CoMap transformation on these connected streams.
map(Function1<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Creates a new DataStream by applying the given function to every element of this DataStream.
map(MapFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Creates a new DataStream by applying the given function to every element of this DataStream.
map(Tuple2<Integer, Integer>) - Method in class org.apache.flink.streaming.examples.iteration.IterateExample.InputMap
 
map(Tuple5<Integer, Integer, Integer, Integer, Integer>) - Method in class org.apache.flink.streaming.examples.iteration.IterateExample.OutputMap
 
map(Tuple5<Integer, Integer, Integer, Integer, Integer>) - Method in class org.apache.flink.streaming.examples.iteration.IterateExample.Step
 
MAP(TypeInformation<?>, TypeInformation<?>) - Method in class org.apache.flink.table.api.Types$
Generates type information for a Java HashMap.
MAP(TypeInformation<?>, TypeInformation<?>) - Static method in class org.apache.flink.table.api.Types
Generates type information for a Java HashMap.
map(Row) - Method in class org.apache.flink.table.runtime.aggregate.DataSetWindowAggMapFunction
 
map(CRow) - Method in class org.apache.flink.table.runtime.CRowInputJavaTupleOutputMapRunner
 
map(CRow) - Method in class org.apache.flink.table.runtime.CRowInputMapRunner
 
map(CRow) - Method in class org.apache.flink.table.runtime.CRowInputScalaTupleOutputMapRunner
 
map(Object) - Method in class org.apache.flink.table.runtime.CRowOutputMapRunner
 
map(IN) - Method in class org.apache.flink.table.runtime.MapRunner
 
map(Row) - Method in class org.apache.flink.table.sinks.CsvFormatter
 
map1(IN1) - Method in interface org.apache.flink.streaming.api.functions.co.CoMapFunction
This method is called for each element in the first of the connected streams.
map1(Integer) - Method in class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.Predictor
 
map2(IN2) - Method in interface org.apache.flink.streaming.api.functions.co.CoMapFunction
This method is called for each element in the second of the connected streams.
map2(Double[]) - Method in class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.Predictor
 
MAP_QUERY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The MAP Query Constructor.
MAP_VALUE_CONSTRUCTOR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The MAP Value Constructor, e.g.
mapAggregateCall(AggregateCall) - Method in class org.apache.flink.table.plan.schema.RowSchema
Converts logical indices of a aggregate call to physical ones.
MapDescriptor - Class in org.apache.flink.optimizer.operators
 
MapDescriptor() - Constructor for class org.apache.flink.optimizer.operators.MapDescriptor
 
MapDriver<IT,OT> - Class in org.apache.flink.runtime.operators
Map task which is executed by a Task Manager.
MapDriver() - Constructor for class org.apache.flink.runtime.operators.MapDriver
 
mapEdges(MapFunction<Edge<K, EV>, NV>) - Method in class org.apache.flink.graph.Graph
Apply a function to the attribute of each edge in the graph.
mapEdges(MapFunction<Edge<K, EV>, NV>, TypeInformation<Edge<K, NV>>) - Method in class org.apache.flink.graph.Graph
Apply a function to the attribute of each edge in the graph.
mapEdges(MapFunction<Edge<K, EV>, NV>, TypeInformation<NV>, ClassTag<NV>) - Method in class org.apache.flink.graph.scala.Graph
Apply a function to the attribute of each edge in the graph.
mapEdges(Function1<Edge<K, EV>, NV>, TypeInformation<NV>, ClassTag<NV>) - Method in class org.apache.flink.graph.scala.Graph
Apply a function to the attribute of each edge in the graph.
MapEdgeToSourceId() - Constructor for class org.apache.flink.graph.asm.degree.annotate.DegreeAnnotationFunctions.MapEdgeToSourceId
 
MapEdgeToTargetId() - Constructor for class org.apache.flink.graph.asm.degree.annotate.DegreeAnnotationFunctions.MapEdgeToTargetId
 
MapFunction<T,O> - Interface in org.apache.flink.api.common.functions
Base interface for Map functions.
mapIndex(int) - Method in class org.apache.flink.table.plan.schema.RowSchema
Converts logical indices to physical indices based on this schema.
MapJoinLeftRunner<IN1,IN2,OUT> - Class in org.apache.flink.table.runtime
 
MapJoinLeftRunner(String, String, boolean, TypeInformation<OUT>, String) - Constructor for class org.apache.flink.table.runtime.MapJoinLeftRunner
 
MapJoinRightRunner<IN1,IN2,OUT> - Class in org.apache.flink.table.runtime
 
MapJoinRightRunner(String, String, boolean, TypeInformation<OUT>, String) - Constructor for class org.apache.flink.table.runtime.MapJoinRightRunner
 
mapNext() - Method in class org.apache.flink.api.avro.DataInputDecoder
 
mapNext() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
MapNode - Class in org.apache.flink.optimizer.dag
The optimizer's internal representation of a Map operator node.
MapNode(SingleInputOperator<?, ?, ?>) - Constructor for class org.apache.flink.optimizer.dag.MapNode
Creates a new MapNode for the given operator.
MapOperator<IN,OUT> - Class in org.apache.flink.api.java.operators
This operator represents the application of a "map" function on a data set, and the result data set produced by the function.
MapOperator(DataSet<IN>, TypeInformation<OUT>, MapFunction<IN, OUT>, String) - Constructor for class org.apache.flink.api.java.operators.MapOperator
 
MapOperatorBase<IN,OUT,FT extends MapFunction<IN,OUT>> - Class in org.apache.flink.api.common.operators.base
 
MapOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.MapOperatorBase
 
MapOperatorBase(FT, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.MapOperatorBase
 
MapOperatorBase(Class<? extends FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.MapOperatorBase
 
mapPartition(Iterable<T>, Collector<O>) - Method in interface org.apache.flink.api.common.functions.MapPartitionFunction
A user-implemented function that modifies or transforms an incoming object.
mapPartition(Iterable<I>, Collector<O>) - Method in class org.apache.flink.api.common.functions.RichMapPartitionFunction
 
mapPartition(MapPartitionFunction<T, R>) - Method in class org.apache.flink.api.java.DataSet
Applies a Map-style operation to the entire partition of the data.
mapPartition(Iterable<T>, Collector<IntermediateSampleData<T>>) - Method in class org.apache.flink.api.java.functions.SampleInPartition
 
mapPartition(Iterable<T>, Collector<T>) - Method in class org.apache.flink.api.java.functions.SampleWithFraction
 
mapPartition(MapPartitionFunction<T, R>, TypeInformation<R>, ClassTag<R>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
mapPartition(Function2<Iterator<T>, Collector<R>, BoxedUnit>, TypeInformation<R>, ClassTag<R>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
mapPartition(Function1<Iterator<T>, TraversableOnce<R>>, TypeInformation<R>, ClassTag<R>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
mapPartition(MapPartitionFunction<T, R>, TypeInformation<R>, ClassTag<R>) - Method in class org.apache.flink.api.scala.DataSet
Creates a new DataSet by applying the given function to each parallel partition of the DataSet.
mapPartition(Function2<Iterator<T>, Collector<R>, BoxedUnit>, TypeInformation<R>, ClassTag<R>) - Method in class org.apache.flink.api.scala.DataSet
Creates a new DataSet by applying the given function to each parallel partition of the DataSet.
mapPartition(Function1<Iterator<T>, TraversableOnce<R>>, TypeInformation<R>, ClassTag<R>) - Method in class org.apache.flink.api.scala.DataSet
Creates a new DataSet by applying the given function to each parallel partition of the DataSet.
mapPartition(Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.python.api.functions.PythonMapPartition
 
mapPartition(Iterable<IN>, Collector<Tuple2<Integer, IN>>) - Method in class org.apache.flink.runtime.operators.udf.AssignRangeIndex
 
mapPartition(Iterable<T>, Collector<Object[][]>) - Method in class org.apache.flink.runtime.operators.udf.RangeBoundaryBuilder
 
mapPartition(Iterable<Row>, Collector<Row>) - Method in class org.apache.flink.table.runtime.aggregate.DataSetPreAggFunction
 
mapPartition(Iterable<Row>, Collector<Row>) - Method in class org.apache.flink.table.runtime.aggregate.DataSetSessionWindowAggregatePreProcessor
Divide window based on the rowtime (current'rowtime - previous&rsquo;rowtime > gap), and then merge data (within a unified window) into an aggregate buffer.
mapPartition(Iterable<IN>, Collector<Tuple2<Object, Object>>) - Method in class org.apache.flink.table.runtime.CountPartitionFunction
 
MapPartitionDescriptor - Class in org.apache.flink.optimizer.operators
 
MapPartitionDescriptor() - Constructor for class org.apache.flink.optimizer.operators.MapPartitionDescriptor
 
MapPartitionDriver<IT,OT> - Class in org.apache.flink.runtime.operators
MapPartition task which is executed by a Task Manager.
MapPartitionDriver() - Constructor for class org.apache.flink.runtime.operators.MapPartitionDriver
 
MapPartitionFunction<T,O> - Interface in org.apache.flink.api.common.functions
Interface for "mapPartition" functions.
MapPartitionNode - Class in org.apache.flink.optimizer.dag
The optimizer's internal representation of a MapPartition operator node.
MapPartitionNode(SingleInputOperator<?, ?, ?>) - Constructor for class org.apache.flink.optimizer.dag.MapPartitionNode
Creates a new MapNode for the given contract.
MapPartitionOperator<IN,OUT> - Class in org.apache.flink.api.java.operators
This operator represents the application of a "mapPartition" function on a data set, and the result data set produced by the function.
MapPartitionOperator(DataSet<IN>, TypeInformation<OUT>, MapPartitionFunction<IN, OUT>, String) - Constructor for class org.apache.flink.api.java.operators.MapPartitionOperator
 
MapPartitionOperatorBase<IN,OUT,FT extends MapPartitionFunction<IN,OUT>> - Class in org.apache.flink.api.common.operators.base
 
MapPartitionOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.MapPartitionOperatorBase
 
MapPartitionOperatorBase(FT, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.MapPartitionOperatorBase
 
MapPartitionOperatorBase(Class<? extends FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.base.MapPartitionOperatorBase
 
mapPartitionWith(Function1<Stream<T>, R>, TypeInformation<R>, ClassTag<R>) - Method in class org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions.OnDataSet
Applies a function fun to a partition as a whole
mapper - Variable in class org.apache.flink.graph.GraphCsvReader
 
mapper - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraPojoSink
 
mappingManager - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraPojoSink
 
mapredOutputFormat - Variable in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
 
mapreduceOutputFormat - Variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
 
MapRelDataType - Class in org.apache.flink.table.plan.schema
 
MapRelDataType(TypeInformation<?>, RelDataType, RelDataType, boolean) - Constructor for class org.apache.flink.table.plan.schema.MapRelDataType
 
mapResultToOutType(Result) - Method in class org.apache.flink.addons.hbase.AbstractTableInputFormat
HBase returns an instance of Result.
mapResultToOutType(Result) - Method in class org.apache.flink.addons.hbase.HBaseRowInputFormat
 
mapResultToOutType(Result) - Method in class org.apache.flink.addons.hbase.TableInputFormat
 
mapResultToTuple(Result) - Method in class org.apache.flink.addons.hbase.TableInputFormat
The output from HBase is always an instance of Result.
mapRexNode(RexNode) - Method in class org.apache.flink.table.plan.schema.RowSchema
Converts logical field references of a RexNode to physical ones.
MapRFileSystem - Class in org.apache.flink.runtime.fs.maprfs
Concrete implementation of the FileSystem base class for the MapR file system.
MapRFileSystem() - Constructor for class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
Creates a new MapRFileSystem object to access the MapR file system.
MapRunner<IN,OUT> - Class in org.apache.flink.table.runtime
 
MapRunner(String, String, TypeInformation<OUT>) - Constructor for class org.apache.flink.table.runtime.MapRunner
 
MapSerializer<K,V> - Class in org.apache.flink.api.common.typeutils.base
A serializer for Map.
MapSerializer(TypeSerializer<K>, TypeSerializer<V>) - Constructor for class org.apache.flink.api.common.typeutils.base.MapSerializer
Creates a map serializer that uses the given serializers to serialize the key-value pairs in the map.
MapSerializerConfigSnapshot<K,V> - Class in org.apache.flink.api.common.typeutils.base
Configuration snapshot for serializers of maps, containing the configuration snapshot of its key serializer and value serializer.
MapSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.base.MapSerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
MapSerializerConfigSnapshot(TypeSerializer<K>, TypeSerializer<V>) - Constructor for class org.apache.flink.api.common.typeutils.base.MapSerializerConfigSnapshot
 
MapSideJoinRunner<IN1,IN2,SINGLE_IN,MULTI_IN,OUT> - Class in org.apache.flink.table.runtime
 
MapSideJoinRunner(String, String, TypeInformation<OUT>, String) - Constructor for class org.apache.flink.table.runtime.MapSideJoinRunner
 
MapState<UK,UV> - Interface in org.apache.flink.api.common.state
State interface for partitioned key-value state.
MapStateDescriptor<UK,UV> - Class in org.apache.flink.api.common.state
MapStateDescriptor(String, TypeSerializer<UK>, TypeSerializer<UV>) - Constructor for class org.apache.flink.api.common.state.MapStateDescriptor
Create a new MapStateDescriptor with the given name and the given type serializers.
MapStateDescriptor(String, TypeInformation<UK>, TypeInformation<UV>) - Constructor for class org.apache.flink.api.common.state.MapStateDescriptor
Create a new MapStateDescriptor with the given name and the given type informations.
MapStateDescriptor(String, Class<UK>, Class<UV>) - Constructor for class org.apache.flink.api.common.state.MapStateDescriptor
Create a new MapStateDescriptor with the given name and the given type information.
MapTo(O) - Constructor for class org.apache.flink.graph.utils.GraphUtils.MapTo
Map each element to the given object.
MapTypeInfo<K,V> - Class in org.apache.flink.api.java.typeutils
Special TypeInformation used by MapStateDescriptor.
MapTypeInfo(TypeInformation<K>, TypeInformation<V>) - Constructor for class org.apache.flink.api.java.typeutils.MapTypeInfo
 
MapTypeInfo(Class<K>, Class<V>) - Constructor for class org.apache.flink.api.java.typeutils.MapTypeInfo
 
MapValue<K extends Value,V extends Value> - Class in org.apache.flink.types
Generic map base type for PACT programs that implements the Value and Map interfaces.
MapValue() - Constructor for class org.apache.flink.types.MapValue
Initializes the encapsulated map with an empty HashMap.
MapValue(Map<K, V>) - Constructor for class org.apache.flink.types.MapValue
Initializes the encapsulated map with a HashMap filled with all entries of the provided map.
mapVertices(MapFunction<Vertex<K, VV>, NV>) - Method in class org.apache.flink.graph.Graph
Apply a function to the attribute of each vertex in the graph.
mapVertices(MapFunction<Vertex<K, VV>, NV>, TypeInformation<Vertex<K, NV>>) - Method in class org.apache.flink.graph.Graph
Apply a function to the attribute of each vertex in the graph.
mapVertices(MapFunction<Vertex<K, VV>, NV>, TypeInformation<NV>, ClassTag<NV>) - Method in class org.apache.flink.graph.scala.Graph
Apply a function to the attribute of each vertex in the graph.
mapVertices(Function1<Vertex<K, VV>, NV>, TypeInformation<NV>, ClassTag<NV>) - Method in class org.apache.flink.graph.scala.Graph
Apply a function to the attribute of each vertex in the graph.
mapWith(Function1<T, R>, TypeInformation<R>, ClassTag<R>) - Method in class org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions.OnDataSet
Applies a function fun to each item of the data set
mapWith(Function1<IN1, R>, Function1<IN2, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.extensions.impl.acceptPartialFunctions.OnConnectedStream
Applies a CoMap transformation on the connected streams.
mapWith(Function1<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.extensions.impl.acceptPartialFunctions.OnDataStream
Applies a function fun to each item of the stream
mapWithState(Function2<T, Option<S>, Tuple2<R, Option<S>>>, TypeInformation<R>, TypeInformation<S>) - Method in class org.apache.flink.streaming.api.scala.KeyedStream
Creates a new DataStream by applying the given stateful function to every element of this DataStream.
mark(int) - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
 
mark - Variable in class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
 
mark(int) - Method in class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
 
mark() - Method in class org.apache.flink.dropwizard.metrics.FlinkMeterWrapper
 
mark(long) - Method in class org.apache.flink.dropwizard.metrics.FlinkMeterWrapper
 
mark() - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
 
mark() - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
 
mark() - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
 
mark() - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
 
mark() - Method in interface org.apache.flink.graph.types.valuearray.ValueArray
Saves the array index, which can be restored by calling reset().
mark(int) - Method in class org.apache.flink.runtime.state.BoundedInputStream
 
mark(int) - Method in class org.apache.flink.runtime.util.NonClosingStreamDecorator
 
markActive() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
Mark this slot as active.
markAllOutgoingConnectionsAsPipelineBreaking() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
markAsTemporarilyIdle() - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction.SourceContext
Marks the source to be temporarily idle.
markBreaksPipeline() - Method in class org.apache.flink.optimizer.dag.DagConnection
Marks that this connection should do a decoupled data exchange (such as batched) rather then pipeline data.
markCanceledOrStopped() - Method in class org.apache.flink.streaming.api.operators.StreamSource
Marks this source as canceled or stopped.
markDead() - Method in class org.apache.flink.runtime.instance.Instance
 
markEvent() - Method in class org.apache.flink.dropwizard.metrics.DropwizardMeterWrapper
 
markEvent(long) - Method in class org.apache.flink.dropwizard.metrics.DropwizardMeterWrapper
 
markEvent() - Method in interface org.apache.flink.metrics.Meter
Mark occurrence of an event.
markEvent(long) - Method in interface org.apache.flink.metrics.Meter
Mark occurrence of multiple events.
markEvent() - Method in class org.apache.flink.metrics.MeterView
 
markEvent(long) - Method in class org.apache.flink.metrics.MeterView
 
markEvent() - Method in class org.apache.flink.metrics.util.TestMeter
 
markEvent(long) - Method in class org.apache.flink.metrics.util.TestMeter
 
markFree() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
Mark the slot as free.
markIdle() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
markInactive() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
Mark the slot as inactive/allocated.
markReleasing() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
Mark this slot as releasing.
markSlotActive(AllocationID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Marks the slot under the given allocation id as active.
markSlotInactive(AllocationID, Time) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Marks the slot under the given allocation id as inactive.
markSupported() - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
 
markSupported() - Method in class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
 
markSupported() - Method in class org.apache.flink.runtime.state.BoundedInputStream
 
markSupported() - Method in class org.apache.flink.runtime.util.NonClosingStreamDecorator
 
markUsed() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
MasterHooks - Class in org.apache.flink.runtime.checkpoint.hooks
Collection of methods to deal with checkpoint master hooks.
masterInfo() - Method in class org.apache.flink.mesos.scheduler.messages.Registered
 
masterInfo() - Method in class org.apache.flink.mesos.scheduler.messages.ReRegistered
 
MasterState - Class in org.apache.flink.runtime.checkpoint
Simple encapsulation of state generated by checkpoint coordinator.
MasterState(String, byte[], int) - Constructor for class org.apache.flink.runtime.checkpoint.MasterState
 
MasterTriggerRestoreHook<T> - Interface in org.apache.flink.runtime.checkpoint
The interface for hooks that can be called by the checkpoint coordinator when triggering or restoring a checkpoint.
MasterTriggerRestoreHook.Factory - Interface in org.apache.flink.runtime.checkpoint
A factory to instantiate a MasterTriggerRestoreHook.
masterUrl() - Method in class org.apache.flink.mesos.util.MesosConfiguration
The Mesos connection string.
matches(RelOptRuleCall) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregateConverter
 
matches(RelOptRuleCall) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoinConverter
 
matches(RelOptRuleCall) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScanConverter
 
matches(RelOptRuleCall) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScanConverter
 
matches(RelOptRuleCall) - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnionConverter
Only translate UNION ALL.
matches(RelOptRuleCall) - Method in class org.apache.flink.table.plan.rules.common.LogicalWindowAggregateRule
 
matches(RelOptRuleCall) - Method in class org.apache.flink.table.plan.rules.common.WindowStartEndPropertiesBaseRule
 
matches(RelOptRuleCall) - Method in class org.apache.flink.table.plan.rules.dataSet.BatchTableSourceScanRule
Rule must only match if TableScan targets a BatchTableSource
matches(RelOptRuleCall) - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateRule
 
matches(RelOptRuleCall) - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateWithNullValuesRule
 
matches(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetCalcRule
 
matches(RelOptRuleCall) - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetCorrelateRule
 
matches(RelOptRuleCall) - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetDistinctRule
 
matches(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetIntersectRule
 
matches(RelOptRuleCall) - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetJoinRule
 
matches(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetLogicalWindowAggregateRule
 
matches(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetMinusRule
 
matches(RelOptRuleCall) - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetScanRule
If the input is not a DataSetTable, we want the TableScanRule to match instead
matches(RelOptRuleCall) - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetSingleRowJoinRule
 
matches(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetSortRule
 
matches(RelOptRuleCall) - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetUnionRule
Only translate UNION ALL.
matches(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetValuesRule
 
matches(RelOptRuleCall) - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetWindowAggregateRule
 
matches(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamCalcRule
 
matches(RelOptRuleCall) - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamCorrelateRule
 
matches(RelOptRuleCall) - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupAggregateRule
 
matches(RelOptRuleCall) - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupWindowAggregateRule
 
matches(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamLogicalWindowAggregateRule
 
matches(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamOverAggregateRule
 
matches(RelOptRuleCall) - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamScanRule
 
matches(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamUnionRule
 
matches(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamValuesRule
 
matches(RelOptRuleCall) - Method in class org.apache.flink.table.plan.rules.datastream.StreamTableSourceScanRule
Rule must only match if TableScan targets a StreamTableSource
matches(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.logical.EnumerableToLogicalTableScan
 
matches(RelOptRuleCall) - Method in class org.apache.flink.table.plan.rules.logical.LogicalUnnestRule
 
matches(RelOptRuleCall) - Method in class org.apache.flink.table.plan.rules.logical.PushFilterIntoTableSourceScanRule
 
matches(RelOptRuleCall) - Method in class org.apache.flink.table.plan.rules.logical.PushProjectIntoTableSourceScanRule
 
matchesOrderedPartitioning(Ordering) - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
 
MaterializationExpiredException - Exception in org.apache.flink.runtime.broadcast
 
MaterializationExpiredException() - Constructor for exception org.apache.flink.runtime.broadcast.MaterializationExpiredException
 
materializeBroadcastVariable(String, int, BatchTask<?, ?>, MutableReader<?>, TypeSerializerFactory<T>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableManager
 
materializeVariable(MutableReader<?>, TypeSerializerFactory<?>, BatchTask<?, ?>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableMaterialization
 
MathFunctions - Class in org.apache.flink.table.functions.utils
 
MathFunctions() - Constructor for class org.apache.flink.table.functions.utils.MathFunctions
 
MathFunctions$ - Class in org.apache.flink.table.functions.utils
 
MathFunctions$() - Constructor for class org.apache.flink.table.functions.utils.MathFunctions$
 
MathUtils - Class in org.apache.flink.util
Collection of simple mathematical routines.
Matrix - Interface in org.apache.flink.ml.math
Base trait for a matrix representation
Matrix2BreezeConverter(Matrix) - Constructor for class org.apache.flink.ml.math.Breeze.Matrix2BreezeConverter
 
MAX - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
MAX aggregate function.
max(int) - Method in class org.apache.flink.api.java.DataSet
Syntactic sugar for DataSet.aggregate(Aggregations, int) using Aggregations.MAX as the aggregation function.
max(int) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Syntactic sugar for aggregate (MAX, field)
max(Short, Short) - Static method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
Like Math.max() except for shorts
max(int) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
max(String) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
max(int) - Method in class org.apache.flink.api.scala.DataSet
Syntactic sugar for aggregate with MAX
max(String) - Method in class org.apache.flink.api.scala.DataSet
Syntactic sugar for aggregate with MAX
max(int) - Method in class org.apache.flink.api.scala.GroupedDataSet
Syntactic sugar for aggregate with MAX
max(String) - Method in class org.apache.flink.api.scala.GroupedDataSet
Syntactic sugar for aggregate with MAX
max - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
max(int) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies an aggregation that gives the maximum value of every window of the data stream at the given position.
max(String) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies an aggregation that that gives the maximum value of the pojo data stream at the given field expression for every window.
max(int) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Applies an aggregation that gives the current maximum of the data stream at the given position by the given key.
max(String) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Applies an aggregation that gives the current maximum of the data stream at the given field expression by the given key.
max(int) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies an aggregation that gives the maximum value of every window of the data stream at the given position.
max(String) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies an aggregation that that gives the maximum value of the pojo data stream at the given field expression for every window.
max(int) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Applies an aggregation that that gives the maximum of the elements in the window at the given position.
max(String) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Applies an aggregation that that gives the maximum of the elements in the window at the given field.
max(int) - Method in class org.apache.flink.streaming.api.scala.KeyedStream
Applies an aggregation that that gives the current maximum of the data stream at the given position by the given key.
max(String) - Method in class org.apache.flink.streaming.api.scala.KeyedStream
Applies an aggregation that that gives the current maximum of the data stream at the given field by the given key.
max(int) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Applies an aggregation that that gives the maximum of the elements in the window at the given position.
max(String) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Applies an aggregation that that gives the maximum of the elements in the window at the given field.
max() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Returns the maximum value of field across all input values.
max(String, RexNode) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
Max - Class in org.apache.flink.table.expressions
 
Max(Expression) - Constructor for class org.apache.flink.table.expressions.Max
 
max() - Method in class org.apache.flink.table.plan.stats.ColumnStats
 
Max$() - Constructor for class org.apache.flink.ml.preprocessing.MinMaxScaler.Max$
 
Max$ - Class in org.apache.flink.table.expressions
 
Max$() - Constructor for class org.apache.flink.table.expressions.Max$
 
MAX_ARITY - Static variable in class org.apache.flink.api.java.tuple.Tuple
 
MAX_ATTEMPTS_HISTORY_SIZE - Static variable in class org.apache.flink.configuration.JobManagerOptions
The maximum number of prior execution attempts kept in history.
MAX_BLOB_PORT - Static variable in class org.apache.flink.runtime.taskexecutor.TaskExecutor
Max blob port which is accepted
MAX_DLOSS() - Method in class org.apache.flink.ml.optimization.IterativeSolver$
 
MAX_DLOSS() - Static method in class org.apache.flink.ml.optimization.IterativeSolver
 
MAX_DYNAMIC_PATH_COST_WEIGHT - Static variable in class org.apache.flink.optimizer.dag.OptimizerNode
 
MAX_FILE_STATE_THRESHOLD - Static variable in class org.apache.flink.migration.runtime.state.filesystem.FsStateBackend
Deprecated.
Maximum size of state that is stored with the metadata, rather than in files
MAX_ITERATIONS - Static variable in class org.apache.flink.graph.examples.data.CommunityDetectionData
 
MAX_ITERATIONS - Static variable in class org.apache.flink.graph.examples.data.ConnectedComponentsDefaultData
 
MAX_ITERATIONS - Static variable in class org.apache.flink.graph.examples.data.MusicProfilesData
 
MAX_NUM_PENDING_CHECKPOINTS - Static variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
The maximum number of pending non-committed checkpoints to track, to avoid memory leaks
MAX_NUM_WRITE_BUFFERS - Static variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
The maximal number of buffers to use by the writers.
MAX_REGISTRATION_DURATION() - Method in class org.apache.flink.yarn.ApplicationClient$
 
MAX_REGISTRATION_DURATION() - Static method in class org.apache.flink.yarn.ApplicationClient
 
MAX_REGISTRATION_TIMEOUT() - Method in class org.apache.flink.yarn.ApplicationClient$
 
MAX_REGISTRATION_TIMEOUT() - Static method in class org.apache.flink.yarn.ApplicationClient
 
MAX_RETAINED_CHECKPOINTS - Static variable in class org.apache.flink.configuration.CoreOptions
The maximum number of completed checkpoint instances to retain.
MAX_ROWS() - Method in class org.apache.flink.ml.math.DenseMatrix$
 
MAX_ROWS() - Static method in class org.apache.flink.ml.math.DenseMatrix
 
MAX_STARTUP_CONNECT_TIME() - Method in class org.apache.flink.runtime.taskmanager.TaskManager$
Maximum time (milli seconds) that the TaskManager will spend searching for a
MAX_STARTUP_CONNECT_TIME() - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
Maximum time (milli seconds) that the TaskManager will spend searching for a
MAX_VERTEX_COUNT - Static variable in class org.apache.flink.graph.asm.translate.translators.LongValueToSignedIntValue
 
MAX_VERTEX_COUNT - Static variable in class org.apache.flink.graph.asm.translate.translators.LongValueToUnsignedIntValue
 
MAX_WATERMARK - Static variable in class org.apache.flink.streaming.api.watermark.Watermark
The watermark that signifies end-of-event-time.
MaxAccumulator<T> - Class in org.apache.flink.table.functions.aggfunctions
The initial accumulator for Max aggregate function
MaxAccumulator() - Constructor for class org.apache.flink.table.functions.aggfunctions.MaxAccumulator
 
MaxAggFunction<T> - Class in org.apache.flink.table.functions.aggfunctions
Base class for built-in Max aggregate function
MaxAggFunction(Ordering<T>) - Constructor for class org.apache.flink.table.functions.aggfunctions.MaxAggFunction
 
MaxAggregationFunction<T extends Comparable<T>> - Class in org.apache.flink.api.java.aggregation
 
MaxAggregationFunction() - Constructor for class org.apache.flink.api.java.aggregation.MaxAggregationFunction
 
MaxAggregationFunction.ImmutableMaxAgg<U extends Comparable<U>> - Class in org.apache.flink.api.java.aggregation
 
MaxAggregationFunction.MaxAggregationFunctionFactory - Class in org.apache.flink.api.java.aggregation
 
MaxAggregationFunction.MutableMaxAgg<U extends Comparable<U> & ResettableValue<U> & CopyableValue<U>> - Class in org.apache.flink.api.java.aggregation
 
MaxAggregationFunctionFactory() - Constructor for class org.apache.flink.api.java.aggregation.MaxAggregationFunction.MaxAggregationFunctionFactory
 
maxBy(int...) - Method in class org.apache.flink.api.java.DataSet
Selects an element with maximum value.
maxBy(int...) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Applies a special case of a reduce transformation (maxBy) on a grouped DataSet.
The transformation consecutively calls a ReduceFunction until only a single element remains which is the result of the transformation.
maxBy(Seq<Object>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
maxBy(Seq<Object>) - Method in class org.apache.flink.api.scala.DataSet
Selects an element with maximum value.
maxBy(Seq<Object>) - Method in class org.apache.flink.api.scala.GroupedDataSet
Applies a special case of a reduce transformation maxBy on a grouped DataSet The transformation consecutively calls a ReduceFunction until only a single element remains which is the result of the transformation.
maxBy(int) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies an aggregation that gives the maximum element of every window of the data stream by the given position.
maxBy(String) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies an aggregation that gives the maximum element of every window of the data stream by the given position.
maxBy(int, boolean) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies an aggregation that gives the maximum element of every window of the data stream by the given position.
maxBy(String, boolean) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies an aggregation that that gives the maximum element of the pojo data stream by the given field expression for every window.
maxBy(String, boolean) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Applies an aggregation that gives the current maximum element of the data stream by the given field expression by the given key.
maxBy(int) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Applies an aggregation that gives the current element with the maximum value at the given position by the given key.
maxBy(String) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Applies an aggregation that gives the current element with the maximum value at the given position by the given key.
maxBy(int, boolean) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Applies an aggregation that gives the current element with the maximum value at the given position by the given key.
maxBy(int) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies an aggregation that gives the maximum element of every window of the data stream by the given position.
maxBy(String) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies an aggregation that gives the maximum element of every window of the data stream by the given field.
maxBy(int, boolean) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies an aggregation that gives the maximum element of every window of the data stream by the given position.
maxBy(String, boolean) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies an aggregation that that gives the maximum element of the pojo data stream by the given field expression for every window.
maxBy(int) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Applies an aggregation that that gives the maximum element of the window by the given position.
maxBy(String) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Applies an aggregation that that gives the maximum element of the window by the given field.
maxBy(int) - Method in class org.apache.flink.streaming.api.scala.KeyedStream
Applies an aggregation that that gives the current maximum element of the data stream by the given position by the given key.
maxBy(String) - Method in class org.apache.flink.streaming.api.scala.KeyedStream
Applies an aggregation that that gives the current maximum element of the data stream by the given field by the given key.
maxBy(int) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Applies an aggregation that that gives the maximum element of the window by the given position.
maxBy(String) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Applies an aggregation that that gives the maximum element of the window by the given field.
MaxDoubleAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MaxDoubleAggregator
 
maxFanIn - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 
MaxFloatAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MaxFloatAggregator
 
maxId() - Static method in class org.apache.flink.table.expressions.TimeIntervalUnit
 
maxId() - Static method in class org.apache.flink.table.expressions.TimePointUnit
 
maxId() - Static method in class org.apache.flink.table.expressions.TrimMode
 
maxId() - Static method in class org.apache.flink.table.plan.nodes.datastream.AccMode
 
MAXIMUM_BLOCK_COUNT - Static variable in class org.apache.flink.graph.generator.random.AbstractGeneratorFactory
 
MaximumDegree<K,VV,EV> - Class in org.apache.flink.graph.asm.degree.filter.undirected
Removes vertices from a graph with degree greater than the given maximum.
MaximumDegree(long) - Constructor for class org.apache.flink.graph.asm.degree.filter.undirected.MaximumDegree
Filter out vertices with degree greater than the given maximum.
MaxIntegerAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MaxIntegerAggregator
 
MaxIterations$() - Constructor for class org.apache.flink.ml.outlier.StochasticOutlierSelection.MaxIterations$
 
maxLen() - Method in class org.apache.flink.table.plan.stats.ColumnStats
 
MaxLongAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MaxLongAggregator
 
maxRetentionTime() - Method in class org.apache.flink.table.runtime.aggregate.ProcessFunctionWithCleanupState
 
maxRetentionTime() - Method in class org.apache.flink.table.runtime.triggers.StateCleaningCountTrigger
 
MaxShortAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MaxShortAggregator
 
maxStackTraceDepth() - Method in class org.apache.flink.runtime.messages.StackTraceSampleMessages.SampleTaskStackTrace
 
maxStackTraceDepth() - Method in class org.apache.flink.runtime.messages.StackTraceSampleMessages.TriggerStackTraceSample
 
maxTimestamp() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow
 
maxTimestamp() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
Gets the largest timestamp that still belongs to this window.
maxTimestamp() - Method in class org.apache.flink.streaming.api.windowing.windows.Window
Gets the largest timestamp that still belongs to this window.
MaxWithRetractAccumulator<T> - Class in org.apache.flink.table.functions.aggfunctions
The initial accumulator for Max with retraction aggregate function
MaxWithRetractAccumulator() - Constructor for class org.apache.flink.table.functions.aggfunctions.MaxWithRetractAccumulator
 
MaxWithRetractAggFunction<T> - Class in org.apache.flink.table.functions.aggfunctions
Base class for built-in Max with retraction aggregate function
MaxWithRetractAggFunction(Ordering<T>) - Constructor for class org.apache.flink.table.functions.aggfunctions.MaxWithRetractAggFunction
 
maybeMkAsInstanceOf(scala.reflect.macros.Context.universe, TypeTags.WeakTypeTag<S>, TypeTags.WeakTypeTag<T>) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mean() - Method in class org.apache.flink.ml.preprocessing.StandardScaler.StandardScalerTransformOperation
 
mean - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
Mean$() - Constructor for class org.apache.flink.ml.preprocessing.StandardScaler.Mean$
 
Media - Class in org.apache.flink.contrib.tweetinputformat.model.tweet.entities
Represents media elements uploaded with the Tweet.
Media() - Constructor for class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Media
 
median - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
MEMBER_OF - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Multiset MEMBER OF, which returns whether a element belongs to a multiset.
MemCheckpointStreamFactory - Class in org.apache.flink.runtime.state.memory
CheckpointStreamFactory that produces streams that write to in-memory byte arrays.
MemCheckpointStreamFactory(int) - Constructor for class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory
Creates a new in-memory stream factory that accepts states whose serialized forms are up to the given number of bytes.
MemCheckpointStreamFactory.MemoryCheckpointOutputStream - Class in org.apache.flink.runtime.state.memory
A CheckpointStateOutputStream that writes into a byte array.
MemFoldingState<K,N,T,ACC> - Class in org.apache.flink.migration.runtime.state.memory
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
MemFoldingState() - Constructor for class org.apache.flink.migration.runtime.state.memory.MemFoldingState
Deprecated.
 
MemFoldingState.Snapshot<K,N,T,ACC> - Class in org.apache.flink.migration.runtime.state.memory
Deprecated.
 
MemListState<K,N,V> - Class in org.apache.flink.migration.runtime.state.memory
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
MemListState() - Constructor for class org.apache.flink.migration.runtime.state.memory.MemListState
Deprecated.
 
MemListState.Snapshot<K,N,V> - Class in org.apache.flink.migration.runtime.state.memory
Deprecated.
 
memManager - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 
memo(Parsers.Parser<T>) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
MEMORY_OFF_HEAP - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Memory allocation method (JVM heap or off-heap), used for managed memory of the TaskManager as well as the network buffers.
MEMORY_SEGMENT_SIZE - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Size of memory buffers used by the network stack and the memory manager (in bytes).
MEMORY_STATE_BACKEND_NAME - Static variable in class org.apache.flink.runtime.state.AbstractStateBackend
The shortcut configuration name for the MemoryState backend that checkpoints to the JobManager
MEMORY_THRESHOLD_CONF_KEY - Static variable in class org.apache.flink.runtime.state.filesystem.FsStateBackendFactory
The key under which the config stores the threshold for state to be store in memory, rather than in files
MemoryAllocationException - Exception in org.apache.flink.runtime.memory
An exception to be thrown when a memory allocation operation is not successful.
MemoryAllocationException() - Constructor for exception org.apache.flink.runtime.memory.MemoryAllocationException
 
MemoryAllocationException(String, Throwable) - Constructor for exception org.apache.flink.runtime.memory.MemoryAllocationException
 
MemoryAllocationException(String) - Constructor for exception org.apache.flink.runtime.memory.MemoryAllocationException
 
MemoryAllocationException(Throwable) - Constructor for exception org.apache.flink.runtime.memory.MemoryAllocationException
 
MemoryArchivist - Class in org.apache.flink.runtime.jobmanager
Actor which stores terminated Flink jobs.
MemoryArchivist(int, Option<Path>) - Constructor for class org.apache.flink.runtime.jobmanager.MemoryArchivist
 
memoryArchivistClass() - Method in class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
MemoryBlockIterator - Interface in org.apache.flink.runtime.util
The memory block iterator is an iterator that always buffers a block of elements in memory.
MemoryCheckpointOutputStream(int) - Constructor for class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
 
MemoryLogger - Class in org.apache.flink.runtime.taskmanager
A thread the periodically logs statistics about: Heap and non-heap memory usage Memory pools and pool usage Garbage collection times and counts
MemoryLogger(Logger, long, ActorSystem) - Constructor for class org.apache.flink.runtime.taskmanager.MemoryLogger
Creates a new memory logger that logs in the given interval and lives as long as the given actor system.
memoryManager() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
MemoryManager - Class in org.apache.flink.runtime.memory
The memory manager governs the memory that Flink uses for sorting, hashing, and caching.
MemoryManager(long, int) - Constructor for class org.apache.flink.runtime.memory.MemoryManager
Creates a memory manager with the given capacity, using the default page size.
MemoryManager(long, int, int, MemoryType, boolean) - Constructor for class org.apache.flink.runtime.memory.MemoryManager
Creates a memory manager with the given capacity and given page size.
memoryManager - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
memoryManager - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
memoryManager - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
The memory manager through which memory is allocated and released.
memoryManager() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
 
memoryManager() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
MemorySegment - Class in org.apache.flink.core.memory
This class represents a piece of memory managed by Flink.
MemorySegmentFactory - Class in org.apache.flink.core.memory
A factory for memory segments.
MemorySegmentFactory() - Constructor for class org.apache.flink.core.memory.MemorySegmentFactory
 
MemorySegmentFactory.Factory - Interface in org.apache.flink.core.memory
A concrete factory for memory segments.
MemorySegmentSource - Interface in org.apache.flink.core.memory
Interface describing entities that can provide memory segments.
MemorySize - Class in org.apache.flink.configuration
MemorySize is a representation of a number of bytes, viewable in different units.
MemorySize(long) - Constructor for class org.apache.flink.configuration.MemorySize
Constructs a new MemorySize.
MemoryStateBackend - Class in org.apache.flink.runtime.state.memory
A AbstractStateBackend that stores all its data and checkpoints in memory and has no capabilities to spill to disk.
MemoryStateBackend() - Constructor for class org.apache.flink.runtime.state.memory.MemoryStateBackend
Creates a new memory state backend that accepts states whose serialized forms are up to the default state size (5 MB).
MemoryStateBackend(int) - Constructor for class org.apache.flink.runtime.state.memory.MemoryStateBackend
Creates a new memory state backend that accepts states whose serialized forms are up to the given number of bytes.
MemoryStateBackend(boolean) - Constructor for class org.apache.flink.runtime.state.memory.MemoryStateBackend
Creates a new memory state backend that accepts states whose serialized forms are up to the default state size (5 MB).
MemoryStateBackend(int, boolean) - Constructor for class org.apache.flink.runtime.state.memory.MemoryStateBackend
Creates a new memory state backend that accepts states whose serialized forms are up to the given number of bytes.
MemoryType - Enum in org.apache.flink.core.memory
The class of memory, such as heap or off-heap.
memoryType() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
MemoryUtils - Class in org.apache.flink.core.memory
Utility class for memory operations.
MemReducingState<K,N,V> - Class in org.apache.flink.migration.runtime.state.memory
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
MemReducingState() - Constructor for class org.apache.flink.migration.runtime.state.memory.MemReducingState
Deprecated.
 
MemReducingState.Snapshot<K,N,V> - Class in org.apache.flink.migration.runtime.state.memory
Deprecated.
 
MemValueState<K,N,V> - Class in org.apache.flink.migration.runtime.state.memory
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
MemValueState() - Constructor for class org.apache.flink.migration.runtime.state.memory.MemValueState
Deprecated.
 
MemValueState.Snapshot<K,N,V> - Class in org.apache.flink.migration.runtime.state.memory
Deprecated.
 
merge(Accumulator<V, R>) - Method in interface org.apache.flink.api.common.accumulators.Accumulator
Used by system internally to merge the collected parts of an accumulator at the end of the job.
merge(Accumulator<Double, Double>) - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
 
merge(Accumulator<Double, Double>) - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
 
merge(Accumulator<Double, Double>) - Method in class org.apache.flink.api.common.accumulators.DoubleMaximum
 
merge(Accumulator<Double, Double>) - Method in class org.apache.flink.api.common.accumulators.DoubleMinimum
 
merge(Accumulator<Integer, TreeMap<Integer, Integer>>) - Method in class org.apache.flink.api.common.accumulators.Histogram
 
merge(Accumulator<Integer, Integer>) - Method in class org.apache.flink.api.common.accumulators.IntCounter
 
merge(Accumulator<Integer, Integer>) - Method in class org.apache.flink.api.common.accumulators.IntMaximum
 
merge(Accumulator<Integer, Integer>) - Method in class org.apache.flink.api.common.accumulators.IntMinimum
 
merge(Accumulator<T, ArrayList<T>>) - Method in class org.apache.flink.api.common.accumulators.ListAccumulator
 
merge(Accumulator<Long, Long>) - Method in class org.apache.flink.api.common.accumulators.LongCounter
 
merge(Accumulator<Long, Long>) - Method in class org.apache.flink.api.common.accumulators.LongMaximum
 
merge(Accumulator<Long, Long>) - Method in class org.apache.flink.api.common.accumulators.LongMinimum
 
merge(Accumulator<T, ArrayList<byte[]>>) - Method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
merge(ACC, ACC) - Method in interface org.apache.flink.api.common.functions.AggregateFunction
Merges two accumulators, returning an accumulator with the merged state.
merge(ACC, ACC) - Method in class org.apache.flink.api.common.functions.RichAggregateFunction
 
merge(ResourceSpec) - Method in class org.apache.flink.api.common.operators.ResourceSpec
Used by system internally to merge the other resources of chained operators when generating the job graph or merge the resource consumed by state backend.
merge(Frame, Interpreter) - Method in class org.apache.flink.api.java.sca.ModifiedASMFrame
 
merge(BasicValue, BasicValue) - Method in class org.apache.flink.api.java.sca.NestedMethodAnalyzer
 
merge(Accumulator<Utils.ChecksumHashCode, Utils.ChecksumHashCode>) - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
 
merge(Accumulator<Integer, ArrayList<Integer>>) - Method in class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator.VectorAccumulator
 
merge(Accumulator<ChecksumHashCode.Checksum, ChecksumHashCode.Checksum>) - Method in class org.apache.flink.graph.asm.dataset.ChecksumHashCode.Checksum
 
merge(Collection<W>, W) - Method in interface org.apache.flink.streaming.api.windowing.assigners.MergingWindowAssigner.MergeCallback
Specifies that the given windows should be merged into the result window.
merge(W, Collection<W>, W, Collection<W>) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet.MergeFunction
This gets called when a merge occurs.
merge(BigIntegralAvgAccumulator, Iterable<BigIntegralAvgAccumulator>) - Method in class org.apache.flink.table.functions.aggfunctions.BigIntegralAvgAggFunction
 
merge(CountAccumulator, Iterable<CountAccumulator>) - Method in class org.apache.flink.table.functions.aggfunctions.CountAggFunction
 
merge(DecimalAvgAccumulator, Iterable<DecimalAvgAccumulator>) - Method in class org.apache.flink.table.functions.aggfunctions.DecimalAvgAggFunction
 
merge(DecimalSumAccumulator, Iterable<DecimalSumAccumulator>) - Method in class org.apache.flink.table.functions.aggfunctions.DecimalSumAggFunction
 
merge(DecimalSumWithRetractAccumulator, Iterable<DecimalSumWithRetractAccumulator>) - Method in class org.apache.flink.table.functions.aggfunctions.DecimalSumWithRetractAggFunction
 
merge(FloatingAvgAccumulator, Iterable<FloatingAvgAccumulator>) - Method in class org.apache.flink.table.functions.aggfunctions.FloatingAvgAggFunction
 
merge(IntegralAvgAccumulator, Iterable<IntegralAvgAccumulator>) - Method in class org.apache.flink.table.functions.aggfunctions.IntegralAvgAggFunction
 
merge(MaxAccumulator<T>, Iterable<MaxAccumulator<T>>) - Method in class org.apache.flink.table.functions.aggfunctions.MaxAggFunction
 
merge(MaxWithRetractAccumulator<T>, Iterable<MaxWithRetractAccumulator<T>>) - Method in class org.apache.flink.table.functions.aggfunctions.MaxWithRetractAggFunction
 
merge(MinAccumulator<T>, Iterable<MinAccumulator<T>>) - Method in class org.apache.flink.table.functions.aggfunctions.MinAggFunction
 
merge(MinWithRetractAccumulator<T>, Iterable<MinWithRetractAccumulator<T>>) - Method in class org.apache.flink.table.functions.aggfunctions.MinWithRetractAggFunction
 
merge(SumAccumulator<T>, Iterable<SumAccumulator<T>>) - Method in class org.apache.flink.table.functions.aggfunctions.SumAggFunction
 
merge(SumWithRetractAccumulator<T>, Iterable<SumWithRetractAccumulator<T>>) - Method in class org.apache.flink.table.functions.aggfunctions.SumWithRetractAggFunction
 
merge(Row, Row) - Method in class org.apache.flink.table.runtime.aggregate.AggregateAggFunction
 
MERGE_ITERATION_AUX_TASKS_KEY - Static variable in class org.apache.flink.optimizer.plantranslate.JobGraphGenerator
 
mergeAccumulatorsPair(Row, Row) - Method in class org.apache.flink.table.runtime.aggregate.GeneratedAggregations
Merges two rows of accumulators into one row.
mergeBranchPlanMaps(PlanNode, PlanNode) - Method in class org.apache.flink.optimizer.plan.PlanNode
 
mergeBranchPlanMaps(Map<OptimizerNode, PlanNode>, Map<OptimizerNode, PlanNode>) - Method in class org.apache.flink.optimizer.plan.PlanNode
 
mergeBranchPlanMaps(Map<OptimizerNode, PlanNode>, Map<OptimizerNode, PlanNode>) - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
Merging can only take place after the solutionSetDelta and nextWorkset PlanNode has been set, because they can contain also some of the branching nodes.
mergeBranchPlanMaps() - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
 
mergeChannelList(List<UnilateralSortMerger.ChannelWithBlockCount>, List<MemorySegment>, List<MemorySegment>) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Merges the given sorted runs to a smaller number of sorted runs.
mergeChannels(List<UnilateralSortMerger.ChannelWithBlockCount>, List<List<MemorySegment>>, List<MemorySegment>) - Method in class org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger.CombiningSpillingThread
Merges the sorted runs described by the given Channel IDs into a single sorted run.
mergeChannels(List<UnilateralSortMerger.ChannelWithBlockCount>, List<List<MemorySegment>>, List<MemorySegment>) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Merges the sorted runs described by the given Channel IDs into a single sorted run.
mergeConfiguration(GraphAlgorithmWrappingDataSet) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.EdgeDegreesPair
 
mergeConfiguration(GraphAlgorithmWrappingDataSet) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.EdgeSourceDegrees
 
mergeConfiguration(GraphAlgorithmWrappingDataSet) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.EdgeTargetDegrees
 
mergeConfiguration(GraphAlgorithmWrappingDataSet) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees
 
mergeConfiguration(GraphAlgorithmWrappingDataSet) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexInDegree
 
mergeConfiguration(GraphAlgorithmWrappingDataSet) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexOutDegree
 
mergeConfiguration(GraphAlgorithmWrappingDataSet) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeDegreePair
 
mergeConfiguration(GraphAlgorithmWrappingDataSet) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeSourceDegree
 
mergeConfiguration(GraphAlgorithmWrappingDataSet) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeTargetDegree
 
mergeConfiguration(GraphAlgorithmWrappingDataSet) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.VertexDegree
 
mergeConfiguration(GraphAlgorithmWrappingGraph) - Method in class org.apache.flink.graph.asm.degree.filter.undirected.MaximumDegree
 
mergeConfiguration(GraphAlgorithmWrappingGraph) - Method in class org.apache.flink.graph.asm.simple.directed.Simplify
 
mergeConfiguration(GraphAlgorithmWrappingGraph) - Method in class org.apache.flink.graph.asm.simple.undirected.Simplify
 
mergeConfiguration(GraphAlgorithmWrappingGraph) - Method in class org.apache.flink.graph.asm.translate.TranslateEdgeValues
 
mergeConfiguration(GraphAlgorithmWrappingGraph) - Method in class org.apache.flink.graph.asm.translate.TranslateGraphIds
 
mergeConfiguration(GraphAlgorithmWrappingGraph) - Method in class org.apache.flink.graph.asm.translate.TranslateVertexValues
 
mergeConfiguration(GraphAlgorithmWrappingDataSet) - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient
 
mergeConfiguration(GraphAlgorithmWrappingDataSet) - Method in class org.apache.flink.graph.library.clustering.directed.TriangleListing
 
mergeConfiguration(GraphAlgorithmWrappingDataSet) - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient
 
mergeConfiguration(GraphAlgorithmWrappingDataSet) - Method in class org.apache.flink.graph.library.clustering.undirected.TriangleListing
 
mergeConfiguration(GraphAlgorithmWrappingDataSet) - Method in class org.apache.flink.graph.library.link_analysis.HITS
 
mergeConfiguration(GraphAlgorithmWrappingDataSet) - Method in class org.apache.flink.graph.library.link_analysis.PageRank
 
mergeConfiguration(GraphAlgorithmWrappingDataSet) - Method in class org.apache.flink.graph.library.similarity.AdamicAdar
 
mergeConfiguration(GraphAlgorithmWrappingDataSet) - Method in class org.apache.flink.graph.library.similarity.JaccardIndex
 
mergeConfiguration(GraphAlgorithmWrappingDataSet) - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingDataSet
An algorithm must first test whether the configurations can be merged before merging individual fields.
mergeConfiguration(GraphAlgorithmWrappingGraph) - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingGraph
An algorithm must first test whether the configurations can be merged before merging individual fields.
mergeContainers(List<TaggedValue>) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
 
MergedInputsBoltWrapper<IN,OUT> - Class in org.apache.flink.storm.wrappers
A MergedInputsBoltWrapper is a BoltWrapper that expects input tuples of type StormTuple.
MergedInputsBoltWrapper(IRichBolt) - Constructor for class org.apache.flink.storm.wrappers.MergedInputsBoltWrapper
Instantiates a new MergedInputsBoltWrapper that wraps the given Storm bolt such that it can be used within a Flink streaming program.
MergedInputsBoltWrapper(IRichBolt, String[]) - Constructor for class org.apache.flink.storm.wrappers.MergedInputsBoltWrapper
Instantiates a new MergedInputsBoltWrapper that wraps the given Storm bolt such that it can be used within a Flink streaming program.
MergedInputsBoltWrapper(IRichBolt, Collection<String>) - Constructor for class org.apache.flink.storm.wrappers.MergedInputsBoltWrapper
Instantiates a new MergedInputsBoltWrapper that wraps the given Storm bolt such that it can be used within a Flink streaming program.
MergedInputsBoltWrapper(IRichBolt, String, Collection<String>) - Constructor for class org.apache.flink.storm.wrappers.MergedInputsBoltWrapper
Instantiates a new MergedInputsBoltWrapper that wraps the given Storm bolt such that it can be used within a Flink streaming program.
mergedWindows - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
mergeHadoopConf(JobConf) - Static method in class org.apache.flink.api.java.hadoop.mapred.utils.HadoopUtils
Merge HadoopConfiguration into JobConf.
mergeHadoopConf(Configuration) - Static method in class org.apache.flink.api.java.hadoop.mapreduce.utils.HadoopUtils
Merge HadoopConfiguration into Configuration.
mergeInputs(List<TaggedValue>) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
 
mergeInto(Map<String, Accumulator<?, ?>>, Map<String, Accumulator<?, ?>>) - Static method in class org.apache.flink.api.common.accumulators.AccumulatorHelper
Merge two collections of accumulators.
mergeInto(CoLocationGroup) - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
 
MergeIterator<E> - Class in org.apache.flink.runtime.operators.sort
An iterator that returns a sorted merge of the sequences of elements from a set of iterators, assuming those sequences are ordered themselves.
MergeIterator(List<MutableObjectIterator<E>>, TypeComparator<E>) - Constructor for class org.apache.flink.runtime.operators.sort.MergeIterator
 
mergeLists(List<OptimizerNode.UnclosedBranchDescriptor>, List<OptimizerNode.UnclosedBranchDescriptor>, List<OptimizerNode.UnclosedBranchDescriptor>, boolean) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
The node IDs are assigned in graph-traversal order (pre-order), hence, each list is sorted by ID in ascending order and all consecutive lists start with IDs in ascending order.
mergeNamespaces(N, Collection<N>) - Method in class org.apache.flink.contrib.streaming.state.RocksDBAggregatingState
 
mergeNamespaces(N, Collection<N>) - Method in class org.apache.flink.contrib.streaming.state.RocksDBListState
 
mergeNamespaces(N, Collection<N>) - Method in class org.apache.flink.contrib.streaming.state.RocksDBReducingState
 
mergeNamespaces(N, Collection<N>) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapMergingState
 
mergeNamespaces(N, Collection<N>) - Method in interface org.apache.flink.runtime.state.internal.InternalMergingState
Merges the state of the current key for the given source namespaces into the state of the target namespace.
mergePartitionedState(StateDescriptor<S, ?>) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.OnMergeContext
 
mergePartitionedState(StateDescriptor<S, ?>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
mergePriority - Variable in class org.apache.flink.api.java.sca.ModifiedASMFrame
 
mergeReadMemory - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 
mergeReturnValues(List<TaggedValue>) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
 
mergeState(SV, SV) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapMergingState
 
mergeState(ACC, ACC) - Method in class org.apache.flink.runtime.state.heap.HeapAggregatingState
 
mergeState(ArrayList<V>, ArrayList<V>) - Method in class org.apache.flink.runtime.state.heap.HeapListState
 
mergeState(V, V) - Method in class org.apache.flink.runtime.state.heap.HeapReducingState
 
mergeWindows(Collection<TimeWindow>, MergingWindowAssigner.MergeCallback<TimeWindow>) - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
Merge overlapping TimeWindows.
mergeWindows(Collection<W>, MergingWindowAssigner.MergeCallback<W>) - Method in class org.apache.flink.streaming.api.windowing.assigners.MergingWindowAssigner
Determines which windows (if any) should be merged.
mergeWindows(Collection<TimeWindow>, MergingWindowAssigner.MergeCallback<TimeWindow>) - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
Merge overlapping TimeWindows.
mergeWindows(Collection<TimeWindow>, MergingWindowAssigner.MergeCallback<TimeWindow>) - Static method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
Merge overlapping TimeWindows.
mergeWith(ParameterTool) - Method in class org.apache.flink.api.java.utils.ParameterTool
Merges two ParameterTool
mergeWith(OptionalBoolean) - Method in class org.apache.flink.graph.utils.proxy.OptionalBoolean
State transitions: if the states are the same then no change if either state is unset then change to the other state if the states are conflicting then set to the conflicting state
MergingState<IN,OUT> - Interface in org.apache.flink.api.common.state
Extension of AppendingState that allows merging of state.
MergingWindowAssigner<T,W extends Window> - Class in org.apache.flink.streaming.api.windowing.assigners
A WindowAssigner that can merge windows.
MergingWindowAssigner() - Constructor for class org.apache.flink.streaming.api.windowing.assigners.MergingWindowAssigner
 
MergingWindowAssigner.MergeCallback<W> - Interface in org.apache.flink.streaming.api.windowing.assigners
Callback to be used in MergingWindowAssigner.mergeWindows(Collection, MergeCallback) for specifying which windows should be merged.
MergingWindowSet<W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing
Utility for keeping track of merging Windows when using a MergingWindowAssigner in a WindowOperator.
MergingWindowSet(MergingWindowAssigner<?, W>, ListState<Tuple2<W, W>>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
Restores a MergingWindowSet from the given state.
MergingWindowSet.MergeFunction<W> - Interface in org.apache.flink.streaming.runtime.operators.windowing
MergingWindowStateStore() - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.MergingWindowStateStore
 
MersenneTwisterFactory - Class in org.apache.flink.graph.generator.random
Uses a seeded MersenneTwister to generate seeds for the distributed collection of MersenneTwister.
MersenneTwisterFactory() - Constructor for class org.apache.flink.graph.generator.random.MersenneTwisterFactory
 
MersenneTwisterFactory(long) - Constructor for class org.apache.flink.graph.generator.random.MersenneTwisterFactory
 
MESOS_ARTIFACT_SERVER_PORT_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
The config parameter defining the Mesos artifact server port to use.
MESOS_ARTIFACT_SERVER_SSL_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
Config parameter to override SSL support for the Artifact Server
MESOS_CONSTRAINTS_HARD_HOSTATTR - Static variable in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
 
MESOS_FAILOVER_TIMEOUT_SECONDS - Static variable in class org.apache.flink.configuration.ConfigConstants
The failover timeout for the Mesos scheduler, after which running tasks are automatically shut down.
MESOS_INITIAL_TASKS - Static variable in class org.apache.flink.configuration.ConfigConstants
The initial number of Mesos tasks to allocate.
MESOS_MASTER_URL - Static variable in class org.apache.flink.configuration.ConfigConstants
The Mesos master URL.
MESOS_MAX_FAILED_TASKS - Static variable in class org.apache.flink.configuration.ConfigConstants
The maximum number of failed Mesos tasks before entirely stopping the Mesos session / job on Mesos.
MESOS_RESOURCEMANAGER_FRAMEWORK_NAME - Static variable in class org.apache.flink.configuration.ConfigConstants
 
MESOS_RESOURCEMANAGER_FRAMEWORK_PRINCIPAL - Static variable in class org.apache.flink.configuration.ConfigConstants
 
MESOS_RESOURCEMANAGER_FRAMEWORK_ROLE - Static variable in class org.apache.flink.configuration.ConfigConstants
 
MESOS_RESOURCEMANAGER_FRAMEWORK_SECRET - Static variable in class org.apache.flink.configuration.ConfigConstants
 
MESOS_RESOURCEMANAGER_FRAMEWORK_USER - Static variable in class org.apache.flink.configuration.ConfigConstants
 
MESOS_RESOURCEMANAGER_TASKS_CONTAINER_TYPE_DOCKER - Static variable in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
Value for MESOS_RESOURCEMANAGER_TASKS_CONTAINER_TYPE setting.
MESOS_RESOURCEMANAGER_TASKS_CONTAINER_TYPE_MESOS - Static variable in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
Value for MESOS_RESOURCEMANAGER_TASKS_CONTAINER_TYPE setting.
MESOS_RM_CONTAINER_IMAGE_NAME - Static variable in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
 
MESOS_RM_CONTAINER_TYPE - Static variable in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
 
MESOS_RM_CONTAINER_VOLUMES - Static variable in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
 
MESOS_RM_TASKS_CPUS - Static variable in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
 
MESOS_RM_TASKS_MEMORY_MB - Static variable in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
 
MESOS_RM_TASKS_SLOTS - Static variable in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
 
MESOS_TM_BOOTSTRAP_CMD - Static variable in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
 
MESOS_TM_HOSTNAME - Static variable in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
 
MesosApplicationMasterRunner - Class in org.apache.flink.mesos.runtime.clusterframework
This class is the executable entry point for the Mesos Application Master.
MesosApplicationMasterRunner() - Constructor for class org.apache.flink.mesos.runtime.clusterframework.MesosApplicationMasterRunner
 
MesosArtifactResolver - Interface in org.apache.flink.mesos.util
An interface for resolving artifact URIs.
MesosArtifactServer - Class in org.apache.flink.mesos.util
A generic Mesos artifact server, designed specifically for use by the Mesos Fetcher.
MesosArtifactServer(String, String, int, Configuration) - Constructor for class org.apache.flink.mesos.util.MesosArtifactServer
 
MesosArtifactServer.UnknownFileHandler - Class in org.apache.flink.mesos.util
Handle a request for a non-existent file.
MesosArtifactServer.VirtualFileServerHandler - Class in org.apache.flink.mesos.util
Handle HEAD and GET requests for a specific file.
MesosConfigKeys - Class in org.apache.flink.mesos.runtime.clusterframework
The Mesos environment variables used for settings of the containers.
MesosConfiguration - Class in org.apache.flink.mesos.util
The typed configuration settings associated with a Mesos scheduler.
MesosConfiguration(String, Protos.FrameworkInfo.Builder, Option<Protos.Credential.Builder>) - Constructor for class org.apache.flink.mesos.util.MesosConfiguration
 
MesosFlinkResourceManager - Class in org.apache.flink.mesos.runtime.clusterframework
Flink Resource Manager for Apache Mesos.
MesosFlinkResourceManager(Configuration, MesosConfiguration, MesosWorkerStore, LeaderRetrievalService, MesosTaskManagerParameters, ContainerSpecification, MesosArtifactResolver, int, int) - Constructor for class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
 
MesosJobManager - Class in org.apache.flink.mesos.runtime.clusterframework
JobManager actor for execution on Mesos.
MesosJobManager(Configuration, ScheduledExecutorService, Executor, InstanceManager, Scheduler, BlobLibraryCacheManager, ActorRef, RestartStrategyFactory, FiniteDuration, LeaderElectionService, SubmittedJobGraphStore, CheckpointRecoveryFactory, FiniteDuration, Option<MetricRegistry>) - Constructor for class org.apache.flink.mesos.runtime.clusterframework.MesosJobManager
 
MesosServices - Interface in org.apache.flink.mesos.runtime.clusterframework.services
Service factory interface for Mesos.
MesosServicesUtils - Class in org.apache.flink.mesos.runtime.clusterframework.services
 
MesosServicesUtils() - Constructor for class org.apache.flink.mesos.runtime.clusterframework.services.MesosServicesUtils
 
MesosTaskManager - Class in org.apache.flink.mesos.runtime.clusterframework
An extension of the TaskManager that listens for additional Mesos-related messages.
MesosTaskManager(TaskManagerConfiguration, ResourceID, TaskManagerLocation, MemoryManager, IOManager, NetworkEnvironment, int, HighAvailabilityServices, MetricRegistry) - Constructor for class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
MesosTaskManager$ - Class in org.apache.flink.mesos.runtime.clusterframework
 
MesosTaskManager$() - Constructor for class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager$
 
MesosTaskManagerParameters - Class in org.apache.flink.mesos.runtime.clusterframework
This class describes the Mesos-specific parameters for launching a TaskManager process.
MesosTaskManagerParameters(double, MesosTaskManagerParameters.ContainerType, Option<String>, ContaineredTaskManagerParameters, List<Protos.Volume>, List<ConstraintEvaluator>, Option<String>, Option<String>) - Constructor for class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
 
MesosTaskManagerParameters.ContainerType - Enum in org.apache.flink.mesos.runtime.clusterframework
 
MesosTaskManagerRunner - Class in org.apache.flink.mesos.runtime.clusterframework
The entry point for running a TaskManager in a Mesos container.
MesosTaskManagerRunner() - Constructor for class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerRunner
 
MesosWorkerStore - Interface in org.apache.flink.mesos.runtime.clusterframework.store
A store of Mesos workers and associated framework information.
MesosWorkerStore.Worker - Class in org.apache.flink.mesos.runtime.clusterframework.store
A stored worker.
MesosWorkerStore.WorkerState - Enum in org.apache.flink.mesos.runtime.clusterframework.store
The (planned) state of the worker.
message() - Method in class org.apache.flink.mesos.scheduler.messages.Error
 
message() - Method in enum org.apache.flink.runtime.checkpoint.CheckpointDeclineReason
 
message() - Method in class org.apache.flink.runtime.clusterframework.messages.FatalErrorOccurred
 
message() - Method in class org.apache.flink.runtime.clusterframework.messages.InfoMessage
 
message() - Method in class org.apache.flink.runtime.clusterframework.messages.ResourceRemoved
Gets the optional message with details, for logging and debugging.
message() - Method in class org.apache.flink.runtime.clusterframework.messages.StopCluster
 
message() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.LeaderSessionMessage
 
message() - Method in class org.apache.flink.table.validate.ValidationFailure
 
MessageAcknowledgingSourceBase<Type,UId> - Class in org.apache.flink.streaming.api.functions.source
Abstract base class for data sources that receive elements from a message queue and acknowledge them back by IDs.
MessageAcknowledgingSourceBase(Class<UId>) - Constructor for class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
Creates a new MessageAcknowledgingSourceBase for IDs of the given type.
MessageAcknowledgingSourceBase(TypeInformation<UId>) - Constructor for class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
Creates a new MessageAcknowledgingSourceBase for IDs of the given type.
MessageCombiner<K,Message> - Class in org.apache.flink.graph.pregel
The base class for combining messages sent during a VertexCentricIteration.
MessageCombiner() - Constructor for class org.apache.flink.graph.pregel.MessageCombiner
 
MessageDecorator - Interface in org.apache.flink.runtime.messages
Interface for message decorators
MessageIterator<Message> - Class in org.apache.flink.graph.pregel
An iterator that returns messages.
MessageIterator() - Constructor for class org.apache.flink.graph.pregel.MessageIterator
 
MessageIterator<Message> - Class in org.apache.flink.graph.spargel
An iterator that returns messages.
MessageIterator() - Constructor for class org.apache.flink.graph.spargel.MessageIterator
 
Messages - Class in org.apache.flink.runtime.messages
Generic messages between JobManager, TaskManager, JobClient.
Messages() - Constructor for class org.apache.flink.runtime.messages.Messages
 
Messages$ - Class in org.apache.flink.runtime.messages
Generic messages between JobManager, TaskManager, JobClient.
Messages$() - Constructor for class org.apache.flink.runtime.messages.Messages$
 
Messages.Disconnect - Class in org.apache.flink.runtime.messages
Signals that the receiver (JobManager/TaskManager) shall disconnect the sender.
Messages.Disconnect$ - Class in org.apache.flink.runtime.messages
 
messagesQueue() - Method in class org.apache.flink.yarn.ApplicationClient
 
metadata(Class<M>, RelMetadataQuery) - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
metadata(Class<M>, RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
metadata(Class<M>, RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
metadata(Class<M>, RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
metadata(Class<M>, RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
metadata(Class<M>, RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
metadata(Class<M>, RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
metadata(Class<M>, RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
metadata(Class<M>, RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
metadata(Class<M>, RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
metadata(Class<M>, RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
metadata(Class<M>, RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
metadata(Class<M>, RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
metadata(Class<M>, RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
metadata(Class<M>, RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
metadata(Class<M>, RelMetadataQuery) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
metaInfo - Variable in class org.apache.flink.runtime.state.heap.StateTable
Combined meta information such as name and serializers for this state
meter(String, M) - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
 
meter(int, M) - Method in class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
 
Meter - Interface in org.apache.flink.metrics
Metric for measuring throughput.
meter(String, M) - Method in interface org.apache.flink.metrics.MetricGroup
Registers a new Meter with Flink.
meter(int, M) - Method in interface org.apache.flink.metrics.MetricGroup
Registers a new Meter with Flink.
meter(int, M) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
meter(String, M) - Method in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
 
meter(String, M) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
meter(int, M) - Method in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
MeterDump(QueryScopeInfo, String, double) - Constructor for class org.apache.flink.runtime.metrics.dump.MetricDump.MeterDump
 
meters - Variable in class org.apache.flink.metrics.reporter.AbstractReporter
 
MeterView - Class in org.apache.flink.metrics
A MeterView provides an average rate of events per second over a given time period.
MeterView(int) - Constructor for class org.apache.flink.metrics.MeterView
 
MeterView(Counter, int) - Constructor for class org.apache.flink.metrics.MeterView
 
MethodCallGen - Class in org.apache.flink.table.codegen.calls
Generates a function call by using a Method.
MethodCallGen(TypeInformation<?>, Method) - Constructor for class org.apache.flink.table.codegen.calls.MethodCallGen
 
methodName() - Method in class org.apache.flink.table.codegen.CodeGenUtils.ObjectMethodAccessor
 
MethodVisitorImpl(int) - Constructor for class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
Metric - Interface in org.apache.flink.metrics
Common super interface for all metrics.
METRIC_CATEGORY_COUNTER - Static variable in class org.apache.flink.runtime.metrics.dump.MetricDump
Categories to be returned by MetricDump.getCategory() to avoid instanceof checks.
METRIC_CATEGORY_GAUGE - Static variable in class org.apache.flink.runtime.metrics.dump.MetricDump
 
METRIC_CATEGORY_HISTOGRAM - Static variable in class org.apache.flink.runtime.metrics.dump.MetricDump
 
METRIC_CATEGORY_METER - Static variable in class org.apache.flink.runtime.metrics.dump.MetricDump
 
METRIC_NAME - Static variable in class org.apache.flink.runtime.executiongraph.metrics.DownTimeGauge
 
METRIC_NAME - Static variable in class org.apache.flink.runtime.executiongraph.metrics.NumberOfFullRestartsGauge
 
METRIC_NAME - Static variable in class org.apache.flink.runtime.executiongraph.metrics.RestartTimeGauge
 
METRIC_NAME - Static variable in class org.apache.flink.runtime.executiongraph.metrics.UpTimeGauge
 
METRIC_QUERY_SERVICE_NAME - Static variable in class org.apache.flink.runtime.metrics.dump.MetricQueryService
 
MetricConfig - Class in org.apache.flink.metrics
A properties class with added utility method to extract primitives.
MetricConfig() - Constructor for class org.apache.flink.metrics.MetricConfig
 
MetricDump - Class in org.apache.flink.runtime.metrics.dump
A container for a dumped metric that contains the scope, name and value(s) of the metric.
MetricDump.CounterDump - Class in org.apache.flink.runtime.metrics.dump
Container for the value of a Counter.
MetricDump.GaugeDump - Class in org.apache.flink.runtime.metrics.dump
Container for the value of a Gauge as a string.
MetricDump.HistogramDump - Class in org.apache.flink.runtime.metrics.dump
Container for the values of a Histogram.
MetricDump.MeterDump - Class in org.apache.flink.runtime.metrics.dump
Container for the rate of a Meter.
MetricDumpDeserializer() - Constructor for class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricDumpDeserializer
 
MetricDumpSerialization - Class in org.apache.flink.runtime.metrics.dump
Utility class for the serialization of metrics.
MetricDumpSerialization.MetricDumpDeserializer - Class in org.apache.flink.runtime.metrics.dump
 
MetricDumpSerialization.MetricDumpSerializer - Class in org.apache.flink.runtime.metrics.dump
 
MetricDumpSerialization.MetricSerializationResult - Class in org.apache.flink.runtime.metrics.dump
This class encapsulates all serialized metrics and a count for each metric type.
MetricDumpSerializer() - Constructor for class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricDumpSerializer
 
MetricFetcher - Class in org.apache.flink.runtime.webmonitor.metrics
The MetricFetcher can be used to fetch metrics from the JobManager and all registered TaskManagers.
MetricFetcher(ActorSystem, JobManagerRetriever, ExecutionContext) - Constructor for class org.apache.flink.runtime.webmonitor.metrics.MetricFetcher
 
MetricGroup - Interface in org.apache.flink.metrics
A MetricGroup is a named container for Metrics and further metric subgroups.
MetricNames - Class in org.apache.flink.runtime.metrics
 
MetricOptions - Class in org.apache.flink.configuration
 
MetricQueryService - Class in org.apache.flink.runtime.metrics.dump
The MetricQueryService creates a key-value representation of all metrics currently registered with Flink when queried.
MetricQueryService() - Constructor for class org.apache.flink.runtime.metrics.dump.MetricQueryService
 
MetricRegistry - Class in org.apache.flink.runtime.metrics
A MetricRegistry keeps track of all registered Metrics.
MetricRegistry(MetricRegistryConfiguration) - Constructor for class org.apache.flink.runtime.metrics.MetricRegistry
Creates a new MetricRegistry and starts the configured reporter.
MetricRegistryConfiguration - Class in org.apache.flink.runtime.metrics
Configuration object for MetricRegistry.
MetricRegistryConfiguration(ScopeFormats, char, List<Tuple2<String, Configuration>>) - Constructor for class org.apache.flink.runtime.metrics.MetricRegistryConfiguration
 
MetricReporter - Interface in org.apache.flink.metrics.reporter
Reporters are used to export Metrics to an external backend.
metrics - Variable in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
metrics - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
Metric group for the operator.
METRICS_LATENCY_HISTORY_SIZE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
METRICS_REPORTER_CLASS_SUFFIX - Static variable in class org.apache.flink.configuration.ConfigConstants
The class of the reporter to use.
METRICS_REPORTER_INTERVAL_SUFFIX - Static variable in class org.apache.flink.configuration.ConfigConstants
The interval between reports.
METRICS_REPORTER_PREFIX - Static variable in class org.apache.flink.configuration.ConfigConstants
The prefix for per-reporter configs.
METRICS_REPORTER_SCOPE_DELIMITER - Static variable in class org.apache.flink.configuration.ConfigConstants
The delimiter used to assemble the metric identifier.
METRICS_REPORTERS_LIST - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
METRICS_SCOPE_DELIMITER - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
METRICS_SCOPE_NAMING_JM - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
METRICS_SCOPE_NAMING_JM_JOB - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
METRICS_SCOPE_NAMING_OPERATOR - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
METRICS_SCOPE_NAMING_TASK - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
METRICS_SCOPE_NAMING_TM - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
METRICS_SCOPE_NAMING_TM_JOB - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
MetricSerializationResult(byte[], int, int, int, int) - Constructor for class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
 
metricsOption() - Method in class org.apache.flink.ml.preprocessing.MinMaxScaler
 
metricsOption() - Method in class org.apache.flink.ml.preprocessing.StandardScaler
 
metricsRegistry() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
metricsRegistry() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
metricsRegistry() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
 
metricsRegistry() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
MetricStore - Class in org.apache.flink.runtime.webmonitor.metrics
Nested data-structure to store metrics.
MetricStore() - Constructor for class org.apache.flink.runtime.webmonitor.metrics.MetricStore
 
MetricStore.JobManagerMetricStore - Class in org.apache.flink.runtime.webmonitor.metrics
Sub-structure containing metrics of the JobManager.
MetricStore.JobMetricStore - Class in org.apache.flink.runtime.webmonitor.metrics
Sub-structure containing metrics of a single Job.
MetricStore.SubtaskMetricStore - Class in org.apache.flink.runtime.webmonitor.metrics
Sub-structure containing metrics of a single Subtask.
MetricStore.TaskManagerMetricStore - Class in org.apache.flink.runtime.webmonitor.metrics
Sub-structure containing metrics of a single TaskManager.
MetricStore.TaskMetricStore - Class in org.apache.flink.runtime.webmonitor.metrics
Sub-structure containing metrics of a single Task.
MetricType - Enum in org.apache.flink.metrics.datadog
Metric types supported by Datadog
MetricUtils - Class in org.apache.flink.runtime.metrics.util
 
MICROSECOND() - Method in class org.apache.flink.table.expressions.TimePointUnit$
 
MICROSECOND() - Static method in class org.apache.flink.table.expressions.TimePointUnit
 
migrateGraph(State<T>) - Static method in class org.apache.flink.cep.nfa.compiler.NFACompiler
Used for migrating CEP graphs prior to 1.3.
Migration - Interface in org.apache.flink.util
Tagging interface for migration related classes.
MigrationInstantiationUtil - Class in org.apache.flink.migration.util
Utility class to deserialize legacy classes for migration.
MigrationInstantiationUtil.ClassLoaderObjectInputStream - Class in org.apache.flink.migration.util
 
MigrationKeyGroupStateHandle - Class in org.apache.flink.migration.state
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
MigrationKeyGroupStateHandle(KeyGroupRangeOffsets, StreamStateHandle) - Constructor for class org.apache.flink.migration.state.MigrationKeyGroupStateHandle
Deprecated.
 
MigrationNamespaceSerializerProxy - Class in org.apache.flink.migration
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
MigrationRestoreSnapshot<K,N,S> - Interface in org.apache.flink.migration.runtime.state.memory
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
MigrationStreamStateHandle - Class in org.apache.flink.migration.state
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
MigrationStreamStateHandle(StreamStateHandle) - Constructor for class org.apache.flink.migration.state.MigrationStreamStateHandle
Deprecated.
 
MigrationUtil - Class in org.apache.flink.migration
 
MigrationUtil() - Constructor for class org.apache.flink.migration.MigrationUtil
 
milli() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Creates an interval of the given number of milliseconds.
MILLI() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
MILLI() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
millis() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Creates an interval of the given number of milliseconds.
MILLIS() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
MILLIS() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
MILLISECOND() - Method in class org.apache.flink.table.expressions.TimePointUnit$
 
MILLISECOND() - Static method in class org.apache.flink.table.expressions.TimePointUnit
 
milliseconds(long) - Static method in class org.apache.flink.api.common.time.Time
Creates a new Time that represents the given number of milliseconds.
milliseconds(long) - Static method in class org.apache.flink.streaming.api.windowing.time.Time
Creates a new Time that represents the given number of milliseconds.
MimeTypes - Class in org.apache.flink.runtime.webmonitor.files
Simple utility class that resolves file extensions to MIME types.
MIN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
MIN aggregate function.
min(int) - Method in class org.apache.flink.api.java.DataSet
Syntactic sugar for DataSet.aggregate(Aggregations, int) using Aggregations.MIN as the aggregation function.
min(int) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Syntactic sugar for aggregate (MIN, field)
min(Short, Short) - Static method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
Like Math.min() except for shorts
min(int) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
min(String) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
min(int) - Method in class org.apache.flink.api.scala.DataSet
Syntactic sugar for aggregate with MIN
min(String) - Method in class org.apache.flink.api.scala.DataSet
Syntactic sugar for aggregate with MIN
min(int) - Method in class org.apache.flink.api.scala.GroupedDataSet
Syntactic sugar for aggregate with MIN
min(String) - Method in class org.apache.flink.api.scala.GroupedDataSet
Syntactic sugar for aggregate with MIN
min - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
min(int) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies an aggregation that that gives the minimum value of every window of the data stream at the given position.
min(String) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies an aggregation that that gives the minimum value of the pojo data stream at the given field expression for every window.
min(int) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Applies an aggregation that gives the current minimum of the data stream at the given position by the given key.
min(String) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Applies an aggregation that gives the current minimum of the data stream at the given field expression by the given key.
min(int) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies an aggregation that that gives the minimum value of every window of the data stream at the given position.
min(String) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies an aggregation that that gives the minimum value of the pojo data stream at the given field expression for every window.
min(int) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Applies an aggregation that that gives the minimum of the elements in the window at the given position.
min(String) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Applies an aggregation that that gives the minimum of the elements in the window at the given field.
min(int) - Method in class org.apache.flink.streaming.api.scala.KeyedStream
Applies an aggregation that that gives the current minimum of the data stream at the given position by the given key.
min(String) - Method in class org.apache.flink.streaming.api.scala.KeyedStream
Applies an aggregation that that gives the current minimum of the data stream at the given field by the given key.
min(int) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Applies an aggregation that that gives the minimum of the elements in the window at the given position.
min(String) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Applies an aggregation that that gives the minimum of the elements in the window at the given field.
min() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Returns the minimum value of field across all input values.
min(String, RexNode) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
Min - Class in org.apache.flink.table.expressions
 
Min(Expression) - Constructor for class org.apache.flink.table.expressions.Min
 
min() - Method in class org.apache.flink.table.plan.stats.ColumnStats
 
Min$() - Constructor for class org.apache.flink.ml.preprocessing.MinMaxScaler.Min$
 
Min$ - Class in org.apache.flink.table.expressions
 
Min$() - Constructor for class org.apache.flink.table.expressions.Min$
 
MIN_MONITORING_INTERVAL - Static variable in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
The minimum interval allowed between consecutive path scans.
MIN_NUM_SORT_MEM_SEGMENTS - Static variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
The minimum number of segments that are required for the sort to operate.
MIN_NUM_WRITE_BUFFERS - Static variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
The minimal number of buffers to use by the writers.
MIN_PAGE_SIZE - Static variable in class org.apache.flink.runtime.memory.MemoryManager
The minimal memory page size.
MinAccumulator<T> - Class in org.apache.flink.table.functions.aggfunctions
The initial accumulator for Min aggregate function
MinAccumulator() - Constructor for class org.apache.flink.table.functions.aggfunctions.MinAccumulator
 
MinAggFunction<T> - Class in org.apache.flink.table.functions.aggfunctions
Base class for built-in Min aggregate function
MinAggFunction(Ordering<T>) - Constructor for class org.apache.flink.table.functions.aggfunctions.MinAggFunction
 
MinAggregationFunction<T extends Comparable<T>> - Class in org.apache.flink.api.java.aggregation
 
MinAggregationFunction() - Constructor for class org.apache.flink.api.java.aggregation.MinAggregationFunction
 
MinAggregationFunction.ImmutableMinAgg<U extends Comparable<U>> - Class in org.apache.flink.api.java.aggregation
 
MinAggregationFunction.MinAggregationFunctionFactory - Class in org.apache.flink.api.java.aggregation
 
MinAggregationFunction.MutableMinAgg<U extends Comparable<U> & ResettableValue<U> & CopyableValue<U>> - Class in org.apache.flink.api.java.aggregation
 
MinAggregationFunctionFactory() - Constructor for class org.apache.flink.api.java.aggregation.MinAggregationFunction.MinAggregationFunctionFactory
 
minBy(int...) - Method in class org.apache.flink.api.java.DataSet
Selects an element with minimum value.
minBy(int...) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Applies a special case of a reduce transformation (minBy) on a grouped DataSet.
The transformation consecutively calls a ReduceFunction until only a single element remains which is the result of the transformation.
minBy(Seq<Object>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
minBy(Seq<Object>) - Method in class org.apache.flink.api.scala.DataSet
Selects an element with minimum value.
minBy(Seq<Object>) - Method in class org.apache.flink.api.scala.GroupedDataSet
Applies a special case of a reduce transformation minBy on a grouped DataSet.
minBy(int) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies an aggregation that gives the minimum element of every window of the data stream by the given position.
minBy(String) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies an aggregation that gives the minimum element of every window of the data stream by the given position.
minBy(int, boolean) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies an aggregation that gives the minimum element of every window of the data stream by the given position.
minBy(String, boolean) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies an aggregation that that gives the minimum element of the pojo data stream by the given field expression for every window.
minBy(String, boolean) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Applies an aggregation that gives the current minimum element of the data stream by the given field expression by the given key.
minBy(int) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Applies an aggregation that gives the current element with the minimum value at the given position by the given key.
minBy(String) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Applies an aggregation that gives the current element with the minimum value at the given position by the given key.
minBy(int, boolean) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Applies an aggregation that gives the current element with the minimum value at the given position by the given key.
minBy(int) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies an aggregation that gives the minimum element of every window of the data stream by the given position.
minBy(String) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies an aggregation that gives the minimum element of every window of the data stream by the given field.
minBy(int, boolean) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies an aggregation that gives the minimum element of every window of the data stream by the given position.
minBy(String, boolean) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies an aggregation that that gives the minimum element of the pojo data stream by the given field expression for every window.
minBy(int) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Applies an aggregation that that gives the minimum element of the window by the given position.
minBy(String) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Applies an aggregation that that gives the minimum element of the window by the given field.
minBy(int) - Method in class org.apache.flink.streaming.api.scala.KeyedStream
Applies an aggregation that that gives the current minimum element of the data stream by the given position by the given key.
minBy(String) - Method in class org.apache.flink.streaming.api.scala.KeyedStream
Applies an aggregation that that gives the current minimum element of the data stream by the given field by the given key.
minBy(int) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Applies an aggregation that that gives the minimum element of the window by the given position.
minBy(String) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Applies an aggregation that that gives the minimum element of the window by the given field.
minDist(Vector) - Method in class org.apache.flink.ml.nn.QuadTree.Node
minDist is defined so that every point in the box has distance to queryPoint greater than minDist (minDist adopted from "Nearest Neighbors Queries" by N.
MinDistanceMessenger() - Constructor for class org.apache.flink.graph.library.SingleSourceShortestPaths.MinDistanceMessenger
 
MinDoubleAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MinDoubleAggregator
 
MinFloatAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MinFloatAggregator
 
MiniCluster - Class in org.apache.flink.runtime.minicluster
 
MiniCluster() - Constructor for class org.apache.flink.runtime.minicluster.MiniCluster
Creates a new mini cluster with the default configuration: One JobManager One TaskManager One task slot in the TaskManager All components share the same RPC subsystem (minimizes communication overhead)
MiniCluster(MiniClusterConfiguration) - Constructor for class org.apache.flink.runtime.minicluster.MiniCluster
Creates a new Flink mini cluster based on the given configuration.
MiniCluster(Configuration) - Constructor for class org.apache.flink.runtime.minicluster.MiniCluster
MiniCluster(Configuration, boolean) - Constructor for class org.apache.flink.runtime.minicluster.MiniCluster
MiniClusterConfiguration - Class in org.apache.flink.runtime.minicluster
 
MiniClusterConfiguration() - Constructor for class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
MiniClusterConfiguration(Configuration) - Constructor for class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
MiniClusterJobDispatcher - Class in org.apache.flink.runtime.minicluster
The dispatcher that runs in the mini cluster, waits for jobs, and starts job masters upon receiving jobs.
MiniClusterJobDispatcher(Configuration, RpcService, HighAvailabilityServices, HeartbeatServices, MetricRegistry) - Constructor for class org.apache.flink.runtime.minicluster.MiniClusterJobDispatcher
Starts a mini cluster job dispatcher.
MiniClusterJobDispatcher(Configuration, HighAvailabilityServices, HeartbeatServices, MetricRegistry, int, RpcService[]) - Constructor for class org.apache.flink.runtime.minicluster.MiniClusterJobDispatcher
Starts a mini cluster job dispatcher.
MINIMUM_CYCLES_PER_BLOCK - Static variable in class org.apache.flink.graph.generator.random.JDKRandomGeneratorFactory
 
MINIMUM_CYCLES_PER_BLOCK - Static variable in class org.apache.flink.graph.generator.random.MersenneTwisterFactory
 
MINIMUM_DIMENSIONS - Static variable in class org.apache.flink.graph.generator.HypercubeGraph
 
MINIMUM_EDGE_COUNT - Static variable in class org.apache.flink.graph.generator.RMatGraph
 
MINIMUM_HEAP_SIZE_MB - Static variable in class org.apache.flink.test.util.TestBaseUtils
 
MINIMUM_OFFSET - Static variable in class org.apache.flink.graph.generator.CirculantGraph
 
MINIMUM_VERTEX_COUNT - Static variable in class org.apache.flink.graph.generator.CirculantGraph
 
MINIMUM_VERTEX_COUNT - Static variable in class org.apache.flink.graph.generator.CompleteGraph
 
MINIMUM_VERTEX_COUNT - Static variable in class org.apache.flink.graph.generator.CycleGraph
 
MINIMUM_VERTEX_COUNT - Static variable in class org.apache.flink.graph.generator.EchoGraph
 
MINIMUM_VERTEX_COUNT - Static variable in class org.apache.flink.graph.generator.EmptyGraph
 
MINIMUM_VERTEX_COUNT - Static variable in class org.apache.flink.graph.generator.PathGraph
 
MINIMUM_VERTEX_COUNT - Static variable in class org.apache.flink.graph.generator.RMatGraph
 
MINIMUM_VERTEX_COUNT - Static variable in class org.apache.flink.graph.generator.StarGraph
 
MINIMUM_VERTEX_DEGREE - Static variable in class org.apache.flink.graph.generator.EchoGraph
 
MINIMUM_VERTEX_PAIR_COUNT - Static variable in class org.apache.flink.graph.generator.SingletonEdgeGraph
 
MinIntegerAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MinIntegerAggregator
 
MinkowskiDistanceMetric - Class in org.apache.flink.ml.metrics.distances
This class implements a Minkowski distance metric.
MinkowskiDistanceMetric(double) - Constructor for class org.apache.flink.ml.metrics.distances.MinkowskiDistanceMetric
 
MinkowskiDistanceMetric$ - Class in org.apache.flink.ml.metrics.distances
 
MinkowskiDistanceMetric$() - Constructor for class org.apache.flink.ml.metrics.distances.MinkowskiDistanceMetric$
 
MinLongAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MinLongAggregator
 
MinMaxAvgStats - Class in org.apache.flink.runtime.checkpoint
Helper for keeping track of min/max/average summaries.
MinMaxScaler - Class in org.apache.flink.ml.preprocessing
Scales observations, so that all features are in a user-specified range.
MinMaxScaler() - Constructor for class org.apache.flink.ml.preprocessing.MinMaxScaler
 
MinMaxScaler$ - Class in org.apache.flink.ml.preprocessing
 
MinMaxScaler$() - Constructor for class org.apache.flink.ml.preprocessing.MinMaxScaler$
 
MinMaxScaler.Max$ - Class in org.apache.flink.ml.preprocessing
 
MinMaxScaler.Min$ - Class in org.apache.flink.ml.preprocessing
 
minResources - Variable in class org.apache.flink.api.java.operators.Operator
 
minResources() - Static method in class org.apache.flink.api.scala.CrossDataSet
 
minResources() - Method in class org.apache.flink.api.scala.DataSet
Returns the minimum resources of this operation.
minResources() - Method in class org.apache.flink.streaming.api.scala.DataStream
Returns the minimum resources of this operation.
minRetentionTime() - Method in class org.apache.flink.table.runtime.aggregate.ProcessFunctionWithCleanupState
 
minRetentionTime() - Method in class org.apache.flink.table.runtime.triggers.StateCleaningCountTrigger
 
MinShortAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MinShortAggregator
 
minSplitSize - Variable in class org.apache.flink.api.common.io.FileInputFormat
The minimal split size, set by the configure() method.
MINUS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Infix arithmetic minus operator, '-'.
minus(Table) - Method in class org.apache.flink.table.api.Table
Minus of two Tables with duplicate records removed.
minus(boolean) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
minus(boolean, int) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
Minus - Class in org.apache.flink.table.expressions
 
Minus(Expression, Expression) - Constructor for class org.apache.flink.table.expressions.Minus
 
minus(RelOptCost) - Method in class org.apache.flink.table.plan.cost.DataSetCost
 
Minus - Class in org.apache.flink.table.plan.logical
 
Minus(LogicalNode, LogicalNode, boolean) - Constructor for class org.apache.flink.table.plan.logical.Minus
 
Minus$ - Class in org.apache.flink.table.expressions
 
Minus$() - Constructor for class org.apache.flink.table.expressions.Minus$
 
Minus$ - Class in org.apache.flink.table.plan.logical
 
Minus$() - Constructor for class org.apache.flink.table.plan.logical.Minus$
 
MINUS_DATE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
A special operator for the subtraction of two DATETIMEs.
minusAll(Table) - Method in class org.apache.flink.table.api.Table
Minus of two Tables.
MinusCoGroupFunction<T> - Class in org.apache.flink.table.runtime
 
MinusCoGroupFunction(boolean) - Constructor for class org.apache.flink.table.runtime.MinusCoGroupFunction
 
MINUTE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The SQL MINUTE operator.
minute() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Creates an interval of the given number of minutes.
MINUTE() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
MINUTE() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
MINUTE() - Method in class org.apache.flink.table.expressions.TimeIntervalUnit$
 
MINUTE() - Static method in class org.apache.flink.table.expressions.TimeIntervalUnit
 
MINUTE() - Method in class org.apache.flink.table.expressions.TimePointUnit$
 
MINUTE() - Static method in class org.apache.flink.table.expressions.TimePointUnit
 
MINUTE_TO_SECOND() - Method in class org.apache.flink.table.expressions.TimeIntervalUnit$
 
MINUTE_TO_SECOND() - Static method in class org.apache.flink.table.expressions.TimeIntervalUnit
 
minutes(long) - Static method in class org.apache.flink.api.common.time.Time
Creates a new Time that represents the given number of minutes.
minutes(long) - Static method in class org.apache.flink.streaming.api.windowing.time.Time
Creates a new Time that represents the given number of minutes.
minutes() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Creates an interval of the given number of minutes.
MINUTES() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
MINUTES() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
MinWithRetractAccumulator<T> - Class in org.apache.flink.table.functions.aggfunctions
The initial accumulator for Min with retraction aggregate function
MinWithRetractAccumulator() - Constructor for class org.apache.flink.table.functions.aggfunctions.MinWithRetractAccumulator
 
MinWithRetractAggFunction<T> - Class in org.apache.flink.table.functions.aggfunctions
Base class for built-in Min with retraction aggregate function
MinWithRetractAggFunction(Ordering<T>) - Constructor for class org.apache.flink.table.functions.aggfunctions.MinWithRetractAggFunction
 
MISMATCHES - Static variable in class org.apache.flink.graph.examples.data.MusicProfilesData
 
MissingFieldTypeInfoException - Exception in org.apache.flink.optimizer.postpass
 
MissingFieldTypeInfoException(int) - Constructor for exception org.apache.flink.optimizer.postpass.MissingFieldTypeInfoException
 
MissingTypeInfo - Class in org.apache.flink.api.java.typeutils
A special type information signifying that the type extraction failed.
MissingTypeInfo(String) - Constructor for class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
MissingTypeInfo(String, InvalidTypesException) - Constructor for class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
mkAnd(scala.reflect.macros.Context.universe, scala.reflect.macros.Context.universe) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkArrayTypeInfo(TypeDescriptors<C>.ArrayDescriptor, TypeTags.WeakTypeTag<T>) - Method in interface org.apache.flink.api.scala.codegen.TypeInformationGen
 
mkAsInstanceOf(scala.reflect.macros.Context.universe, TypeTags.WeakTypeTag<T>) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkBuilderOf(scala.reflect.macros.Context.universe, scala.reflect.macros.Context.universe) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkCall(scala.reflect.macros.Context.universe, Seq<String>, List<Universe.TreeContextApi>) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkCanBuildFromOf(scala.reflect.macros.Context.universe, scala.reflect.macros.Context.universe, scala.reflect.macros.Context.universe) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkCaseClassTypeInfo(TypeDescriptors<C>.CaseClassDescriptor, TypeTags.WeakTypeTag<T>) - Method in interface org.apache.flink.api.scala.codegen.TypeInformationGen
 
mkClass(scala.reflect.macros.Context.universe, scala.reflect.macros.Context.universe, List<Types.TypeApi>, List<Universe.TreeContextApi>) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkCreateTupleInstance(TypeDescriptors<C>.CaseClassDescriptor, TypeTags.WeakTypeTag<T>) - Method in interface org.apache.flink.api.scala.codegen.TypeInformationGen
 
mkCtorCall(scala.reflect.macros.Context.universe, List<Universe.TreeContextApi>) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkDefault(scala.reflect.macros.Context.universe) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkdirs(Path) - Method in class org.apache.flink.core.fs.FileSystem
Make the given file and all non-existent parents into directories.
mkdirs(Path) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
Recursively creates the directory specified by the provided path.
mkdirs(Path) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
mkdirs(Path) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
 
mkdirs(Path) - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
 
mkEitherTypeInfo(TypeDescriptors<C>.EitherDescriptor, TypeTags.WeakTypeTag<T>) - Method in interface org.apache.flink.api.scala.codegen.TypeInformationGen
 
mkEnumValueTypeInfo(TypeDescriptors<C>.EnumValueDescriptor, TypeTags.WeakTypeTag<T>) - Method in interface org.apache.flink.api.scala.codegen.TypeInformationGen
 
mKeyValueRecord - Variable in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter.AvroKeyValue
The key/value generic record wrapped by this class.
mkGenericTypeInfo(TypeDescriptors<C>.UDTDescriptor, TypeTags.WeakTypeTag<T>) - Method in interface org.apache.flink.api.scala.codegen.TypeInformationGen
 
mkIf(scala.reflect.macros.Context.universe, scala.reflect.macros.Context.universe) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkIf(scala.reflect.macros.Context.universe, scala.reflect.macros.Context.universe, scala.reflect.macros.Context.universe) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkIteratorOf(scala.reflect.macros.Context.universe) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkJavaTuple(TypeDescriptors<C>.JavaTupleDescriptor, TypeTags.WeakTypeTag<T>) - Method in interface org.apache.flink.api.scala.codegen.TypeInformationGen
 
mkList(List<Universe.TreeContextApi>) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkList() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
mkListOf(scala.reflect.macros.Context.universe) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkMap(List<Universe.TreeContextApi>) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkMethod(String, scala.reflect.macros.Context.universe, List<Tuple2<String, Types.TypeApi>>, scala.reflect.macros.Context.universe, scala.reflect.macros.Context.universe) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkNull() - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkOne() - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkOptionTypeInfo(TypeDescriptors<C>.OptionDescriptor, TypeTags.WeakTypeTag<T>) - Method in interface org.apache.flink.api.scala.codegen.TypeInformationGen
 
mkPojo(TypeDescriptors<C>.PojoDescriptor, TypeTags.WeakTypeTag<T>) - Method in interface org.apache.flink.api.scala.codegen.TypeInformationGen
 
mkPrimitiveTypeInfo(scala.reflect.macros.Context.universe, TypeTags.WeakTypeTag<T>) - Method in interface org.apache.flink.api.scala.codegen.TypeInformationGen
 
mkSelect(String, Seq<String>) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkSelect(scala.reflect.macros.Context.universe, Seq<String>) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkSelectSyms(scala.reflect.macros.Context.universe, Seq<Universe.SymbolContextApi>) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkSeq(List<Universe.TreeContextApi>) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkSeqOf(scala.reflect.macros.Context.universe) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkSingle(Seq<Universe.TreeContextApi>) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkSuperCall(List<Universe.TreeContextApi>) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkThrow(scala.reflect.macros.Context.universe, scala.reflect.macros.Context.universe) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkThrow(scala.reflect.macros.Context.universe, String) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkThrow(String) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkTraversableTypeInfo(TypeDescriptors<C>.TraversableDescriptor, TypeTags.WeakTypeTag<T>) - Method in interface org.apache.flink.api.scala.codegen.TypeInformationGen
 
mkTryTypeInfo(TypeDescriptors<C>.TryDescriptor, TypeTags.WeakTypeTag<T>) - Method in interface org.apache.flink.api.scala.codegen.TypeInformationGen
 
mktSegment() - Method in class org.apache.flink.examples.scala.relational.TPCHQuery3.Customer
 
mktSegment() - Method in class org.apache.flink.table.examples.scala.TPCHQuery3Table.Customer
 
mkTypeInfo(TypeTags.WeakTypeTag<T>) - Method in interface org.apache.flink.api.scala.codegen.TypeInformationGen
 
mkTypeInfo(TypeDescriptors<C>.UDTDescriptor, TypeTags.WeakTypeTag<T>) - Method in interface org.apache.flink.api.scala.codegen.TypeInformationGen
 
mkTypeInfoFromFactory(TypeDescriptors<C>.FactoryTypeDescriptor, TypeTags.WeakTypeTag<T>) - Method in interface org.apache.flink.api.scala.codegen.TypeInformationGen
 
mkTypeParameter(TypeDescriptors<C>.TypeParameterDescriptor, TypeTags.WeakTypeTag<T>) - Method in interface org.apache.flink.api.scala.codegen.TypeInformationGen
 
mkUnit() - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkVal(String, scala.reflect.macros.Context.universe, boolean, scala.reflect.macros.Context.universe, scala.reflect.macros.Context.universe) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkValAndGetter(String, scala.reflect.macros.Context.universe, scala.reflect.macros.Context.universe, scala.reflect.macros.Context.universe) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkValueTypeInfo(TypeDescriptors<C>.UDTDescriptor, TypeTags.WeakTypeTag<T>) - Method in interface org.apache.flink.api.scala.codegen.TypeInformationGen
 
mkVar(String, scala.reflect.macros.Context.universe, boolean, scala.reflect.macros.Context.universe, scala.reflect.macros.Context.universe) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkVarAndLazyGetter(String, scala.reflect.macros.Context.universe, scala.reflect.macros.Context.universe, scala.reflect.macros.Context.universe) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkWhile(scala.reflect.macros.Context.universe, scala.reflect.macros.Context.universe) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
mkWritableTypeInfo(TypeDescriptors<C>.UDTDescriptor, TypeTags.WeakTypeTag<T>) - Method in interface org.apache.flink.api.scala.codegen.TypeInformationGen
 
mkZero() - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
MLUtils - Class in org.apache.flink.ml
Convenience functions for machine learning tasks
MLUtils() - Constructor for class org.apache.flink.ml.MLUtils
 
MLUtils$ - Class in org.apache.flink.ml
Convenience functions for machine learning tasks
MLUtils$() - Constructor for class org.apache.flink.ml.MLUtils$
 
MMAP_FILE_SIZE - Static variable in class org.apache.flink.python.api.PythonOptions
The config parameter defining the size of the memory-mapped files, in kb.
MOD - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
mod(Expression) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Calculates the remainder of division the given number by another one.
mod(RexBuilder, RelDataType, RexNode, BigDecimal) - Method in class org.apache.flink.table.expressions.ExpressionUtils$
Copy of org.apache.calcite.sql2rel.StandardConvertletTable#mod().
mod(RexBuilder, RelDataType, RexNode, BigDecimal) - Static method in class org.apache.flink.table.expressions.ExpressionUtils
Copy of org.apache.calcite.sql2rel.StandardConvertletTable#mod().
Mod - Class in org.apache.flink.table.expressions
 
Mod(Expression, Expression) - Constructor for class org.apache.flink.table.expressions.Mod
 
Mod$ - Class in org.apache.flink.table.expressions
 
Mod$() - Constructor for class org.apache.flink.table.expressions.Mod$
 
mode - Variable in class org.apache.flink.test.util.MultipleProgramsTestBase
 
ModifiedASMAnalyzer - Class in org.apache.flink.api.java.sca
Modified version of ASMs Analyzer.
ModifiedASMAnalyzer(Interpreter) - Constructor for class org.apache.flink.api.java.sca.ModifiedASMAnalyzer
 
ModifiedASMFrame - Class in org.apache.flink.api.java.sca
Modified version of ASMs Frame.
ModifiedASMFrame(int, int) - Constructor for class org.apache.flink.api.java.sca.ModifiedASMFrame
 
ModifiedASMFrame(Frame) - Constructor for class org.apache.flink.api.java.sca.ModifiedASMFrame
 
MODULE$ - Static variable in class org.apache.flink.api.scala.ClosureCleaner$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.scala.codegen.MacroContextHolder$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.scala.CrossDataSet$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.scala.ExecutionEnvironment$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.scala.FlinkShell$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.scala.FlinkShell.Config$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.scala.FlinkShell.ExecutionMode$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.scala.FlinkShell.YarnConfig$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.scala.metrics.ScalaGauge$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.scala.typeutils.EnumValueSerializer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.scala.typeutils.EnumValueSerializer.ScalaEnumSerializerConfigSnapshot$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.scala.typeutils.OptionSerializer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.scala.typeutils.OptionSerializer.OptionSerializerConfigSnapshot$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.scala.typeutils.OptionTypeComparator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.scala.typeutils.TrySerializer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.scala.typeutils.TrySerializer.TrySerializerConfigSnapshot$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.api.scala.typeutils.TypeUtils$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.cep.scala.CEP$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.cep.scala.pattern.Pattern$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.cep.scala.PatternStream$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.clustering.KMeans$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.clustering.KMeans.Centroid$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.clustering.KMeans.Point$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.graph.ConnectedComponents$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.graph.DeltaPageRank$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.graph.EnumTriangles$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.graph.EnumTriangles.Edge$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.graph.EnumTriangles.Triad$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.graph.PageRankBasic$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.graph.PageRankBasic.AdjacencyList$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.graph.PageRankBasic.Link$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.graph.PageRankBasic.Page$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.graph.TransitiveClosureNaive$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.misc.PiEstimation$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.ml.LinearRegression$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.ml.LinearRegression.Data$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.ml.LinearRegression.Params$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.relational.TPCHQuery10$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.relational.TPCHQuery3$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.relational.TPCHQuery3.Customer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.relational.TPCHQuery3.Lineitem$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.relational.TPCHQuery3.Order$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.relational.TPCHQuery3.ShippedItem$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.relational.WebLogAnalysis$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.examples.scala.wordcount.WordCount$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.graph.scala.examples.ConnectedComponents$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.graph.scala.examples.GSASingleSourceShortestPaths$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.graph.scala.examples.SingleSourceShortestPaths$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.graph.scala.Graph$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.hadoopcompatibility.scala.HadoopInputs$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.runtime.clusterframework.RegisteredMesosWorkerNode$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.ConnectionMonitor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.ConnectionMonitor.ConnectedState$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.ConnectionMonitor.ConnectingState$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.ConnectionMonitor.Start$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.ConnectionMonitor.Stop$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.ConnectionMonitor.StoppedState$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.LaunchCoordinator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.LaunchCoordinator.Assign$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.LaunchCoordinator.GatherData$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.LaunchCoordinator.GatheringOffers$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.LaunchCoordinator.Idle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.LaunchCoordinator.Launch$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.LaunchCoordinator.Suspended$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.LaunchCoordinator.Unassign$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator.Idle$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator.Reconcile$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator.ReconciliationData$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator.Reconciling$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator.Suspended$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.TaskMonitor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.TaskMonitor.Killing$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.TaskMonitor.Launched$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.TaskMonitor.New$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.TaskMonitor.Reconciling$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.TaskMonitor.Released$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.TaskMonitor.Running$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.TaskMonitor.Staging$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.TaskMonitor.StateData$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.TaskMonitor.Suspended$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.TaskMonitor.TaskGoalStateUpdated$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.TaskMonitor.TaskTerminated$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.mesos.scheduler.Tasks$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.classification.SVM$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.classification.SVM.Blocks$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.classification.SVM.Iterations$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.classification.SVM.LocalIterations$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.classification.SVM.OutputDecisionFunction$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.classification.SVM.Regularization$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.classification.SVM.Seed$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.classification.SVM.Stepsize$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.classification.SVM.ThresholdValue$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.common.Block$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.common.FlinkMLTools$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.common.FlinkMLTools.ModuloKeyPartitioner$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.common.LabeledVector$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.common.ParameterMap$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.common.WeightVector$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.math.BLAS$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.math.Breeze$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.math.DenseMatrix$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.math.DenseVector$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.math.distributed.DistributedMatrix$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.math.distributed.DistributedRowMatrix$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.math.distributed.IndexedRow$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.math.SparseMatrix$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.math.SparseVector$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.math.Vector$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.math.VectorBuilder$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.metrics.distances.ChebyshevDistanceMetric$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.metrics.distances.CosineDistanceMetric$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.metrics.distances.EuclideanDistanceMetric$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.metrics.distances.ManhattanDistanceMetric$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.metrics.distances.MinkowskiDistanceMetric$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.metrics.distances.SquaredEuclideanDistanceMetric$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.metrics.distances.TanimotoDistanceMetric$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.MLUtils$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.nn.KNN$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.nn.KNN.Blocks$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.nn.KNN.DistanceMetric$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.nn.KNN.K$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.nn.KNN.SizeHint$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.nn.KNN.UseQuadTree$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.optimization.GenericLossFunction$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.optimization.GradientDescent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.optimization.HingeLoss$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.optimization.IterativeSolver$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.optimization.IterativeSolver.ConvergenceThreshold$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.optimization.IterativeSolver.Iterations$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.optimization.IterativeSolver.LearningRate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.optimization.IterativeSolver.LearningRateMethodValue$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.optimization.L1Regularization$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.optimization.L2Regularization$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.optimization.LearningRateMethod$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.optimization.LearningRateMethod.Bottou$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.optimization.LearningRateMethod.Constant$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.optimization.LearningRateMethod.Default$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.optimization.LearningRateMethod.InvScaling$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.optimization.LearningRateMethod.Xu$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.optimization.LinearPrediction$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.optimization.LogisticLoss$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.optimization.NoRegularization$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.optimization.Solver$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.optimization.Solver.LossFunction$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.optimization.Solver.RegularizationConstant$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.optimization.Solver.RegularizationPenaltyValue$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.optimization.SquaredLoss$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.outlier.StochasticOutlierSelection$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.outlier.StochasticOutlierSelection.BreezeLabeledVector$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.outlier.StochasticOutlierSelection.ErrorTolerance$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.outlier.StochasticOutlierSelection.MaxIterations$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.outlier.StochasticOutlierSelection.Perplexity$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.pipeline.ChainedPredictor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.pipeline.ChainedTransformer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.pipeline.Estimator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.pipeline.Predictor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.pipeline.Transformer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.preprocessing.MinMaxScaler$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.preprocessing.MinMaxScaler.Max$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.preprocessing.MinMaxScaler.Min$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.preprocessing.PolynomialFeatures$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.preprocessing.PolynomialFeatures.Degree$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.preprocessing.Splitter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.preprocessing.Splitter.TrainTestDataSet$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.preprocessing.Splitter.TrainTestHoldoutDataSet$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.preprocessing.StandardScaler$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.preprocessing.StandardScaler.Mean$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.preprocessing.StandardScaler.Std$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.recommendation.ALS$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.recommendation.ALS.BlockedFactorization$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.recommendation.ALS.BlockRating$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.recommendation.ALS.Blocks$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.recommendation.ALS.Factorization$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.recommendation.ALS.Factors$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.recommendation.ALS.InBlockInformation$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.recommendation.ALS.Iterations$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.recommendation.ALS.Lambda$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.recommendation.ALS.NumFactors$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.recommendation.ALS.OutBlockInformation$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.recommendation.ALS.Rating$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.recommendation.ALS.Seed$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.recommendation.ALS.TemporaryPath$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.regression.MultipleLinearRegression$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.regression.MultipleLinearRegression.ConvergenceThreshold$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.regression.MultipleLinearRegression.Iterations$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.regression.MultipleLinearRegression.LearningRateMethodValue$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.ml.regression.MultipleLinearRegression.Stepsize$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.akka.AkkaUtils$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.akka.RemoteAddressExtension$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.jobmanager.JobInfo$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.jobmanager.JobManager$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsErroneous$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsFound$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsNotFound$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultStringsFound$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.accumulators.RequestAccumulatorResults$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.accumulators.RequestAccumulatorResultsStringified$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.ArchiveMessages$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.ArchiveMessages.ArchivedJob$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.ArchiveMessages.ArchivedJobs$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.ArchiveMessages.ArchiveExecutionGraph$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.ArchiveMessages.RequestArchivedJob$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.ArchiveMessages.RequestArchivedJobs$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.ArchiveMessages.RequestJobCounts$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.ExecutionGraphMessages$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.ExecutionGraphMessages.ExecutionStateChanged$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.ExecutionGraphMessages.JobStatusChanged$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobClientMessages$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobClientMessages.AttachToJobAndWait$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobClientMessages.ConnectionTimeout$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobClientMessages.JobManagerActorRef$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobClientMessages.JobManagerLeaderAddress$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobClientMessages.RegistrationTimeout$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobClientMessages.SubmissionTimeout$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobClientMessages.SubmitJobAndWait$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.CancelJob$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.CancelJobWithSavepoint$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.CancellationFailure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.CancellationSuccess$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.ClassloadingProps$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.CurrentJobStatus$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.DisposeSavepoint$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.DisposeSavepointFailure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.DisposeSavepointSuccess$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.GrantLeadership$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.JobFound$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.JobManagerStatusAlive$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.JobNotFound$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.JobResultFailure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.JobResultSuccess$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.JobSubmitSuccess$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.LeaderSessionMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.NextInputSplit$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.RecoverAllJobs$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.RecoverJob$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.RecoverSubmittedJob$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.RegisteredTaskManagers$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.RegisterJobClient$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.RegisterJobClientSuccess$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.RemoveCachedJob$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.RemoveJob$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.RequestArchive$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.RequestBlobManagerPort$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.RequestClassloadingProps$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.RequestJob$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.RequestJobManagerStatus$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.RequestJobStatus$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.RequestLeaderSessionID$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.RequestNextInputSplit$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.RequestNumberRegisteredTaskManager$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.RequestPartitionProducerState$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.RequestRegisteredTaskManagers$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.RequestRunningJobs$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.RequestRunningJobsStatus$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.RequestStackTrace$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.RequestTaskManagerInstance$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.RequestTotalNumberOfSlots$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.RequestWebMonitorPort$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.ResponseArchive$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.ResponseLeaderSessionID$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.ResponseWebMonitorPort$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.RevokeLeadership$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.RunningJobs$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.RunningJobsStatus$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.ScheduleOrUpdateConsumers$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.StopJob$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.StoppingFailure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.StoppingSuccess$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.SubmitJob$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.TaskManagerInstance$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.TriggerSavepoint$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.TriggerSavepointFailure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.JobManagerMessages.TriggerSavepointSuccess$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.Messages$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.Messages.Disconnect$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.RegistrationMessages$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.RegistrationMessages.AcknowledgeRegistration$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.RegistrationMessages.AlreadyRegistered$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.RegistrationMessages.RefuseRegistration$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.RegistrationMessages.RegisterTaskManager$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.RegistrationMessages.TriggerTaskManagerRegistration$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.StackTraceSampleMessages$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.StackTraceSampleMessages.SampleTaskStackTrace$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.StackTraceSampleMessages.TriggerStackTraceSample$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.TaskManagerMessages$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.TaskManagerMessages.FatalError$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.TaskManagerMessages.Heartbeat$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.TaskManagerMessages.JobManagerLeaderAddress$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.TaskManagerMessages.LogFileRequest$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.TaskManagerMessages.NotifyWhenRegisteredAtJobManager$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.TaskManagerMessages.RegisteredAtJobManager$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.TaskManagerMessages.RequestBroadcastVariablesWithReferences$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.TaskManagerMessages.RequestNumActiveConnections$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.TaskManagerMessages.RequestTaskManagerLog$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.TaskManagerMessages.ResponseBroadcastVariablesWithReferences$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.TaskManagerMessages.ResponseNumActiveConnections$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.TaskManagerMessages.SendHeartbeat$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.TaskManagerMessages.SendStackTrace$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.TaskManagerMessages.StackTrace$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.TaskManagerMessages.StdOutFileRequest$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.TaskMessages$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.TaskMessages.CancelTask$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.TaskMessages.FailIntermediateResultPartitions$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.TaskMessages.FailTask$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.TaskMessages.StopTask$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.TaskMessages.SubmitTask$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.TaskMessages.TaskInFinalState$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.TaskMessages.UpdateTaskExecutionState$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.TaskMessages.UpdateTaskMultiplePartitionInfos$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.messages.TaskMessages.UpdateTaskSinglePartitionInfo$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.runtime.taskmanager.TaskManager$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.streaming.api.scala.AsyncDataStream$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.streaming.api.scala.OutputTag$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.streaming.scala.examples.async.AsyncIOExample$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.streaming.scala.examples.join.WindowJoin$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.streaming.scala.examples.join.WindowJoin.Grade$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.streaming.scala.examples.join.WindowJoin.Person$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.streaming.scala.examples.join.WindowJoin.Salary$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.streaming.scala.examples.join.WindowJoinSampleData$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.streaming.scala.examples.socket.SocketWindowWordCount$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.streaming.scala.examples.socket.SocketWindowWordCount.WordWithCount$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.streaming.scala.examples.windowing.TopSpeedWindowing$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.streaming.scala.examples.windowing.TopSpeedWindowing.CarEvent$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.AmbiguousTableSourceConverterException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.CatalogAlreadyExistException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.CatalogNotExistException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.CurrentRange$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.CurrentRow$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.ExpressionParserException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.ExternalCatalogAlreadyExistException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.ExternalCatalogNotExistException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.java.Over$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.java.Session$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.java.Slide$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.java.Tumble$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.NoMatchedTableSourceConverterException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.OverWindow$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.scala.array$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.scala.currentDate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.scala.currentTime$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.scala.currentTimestamp$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.scala.localTime$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.scala.localTimestamp$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.scala.Over$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.scala.OverWindowWithOrderBy$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.scala.PartitionedOver$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.scala.pi$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.scala.Session$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.scala.Slide$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.scala.temporalOverlaps$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.scala.Tumble$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.SqlParserException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.TableAlreadyExistException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.TableConfig$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.TableEnvironment$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.TableException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.TableNotExistException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.Types$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.UnboundedRange$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.UnboundedRow$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.UnresolvedException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.api.ValidationException$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.calcite.CalciteConfig$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.calcite.FlinkPlannerImpl$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.calcite.FlinkRelBuilder$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.calcite.FlinkRelBuilder.NamedWindowProperty$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.calcite.FlinkRelOptClusterFactory$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.calcite.FlinkTypeFactory$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.calcite.RelTimeIndicatorConverter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.catalog.ExternalCatalogSchema$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.catalog.ExternalCatalogTable$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.catalog.ExternalTableSourceUtil$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.codegen.calls.BuiltInMethods$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.codegen.calls.CallGenerator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.codegen.calls.FloorCeilCallGen$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.codegen.calls.FunctionGenerator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.codegen.calls.ScalarOperators$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.codegen.CodeGenerator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.codegen.CodeGenUtils$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.codegen.CodeGenUtils.ObjectFieldAccessor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.codegen.CodeGenUtils.ObjectGenericFieldAccessor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.codegen.CodeGenUtils.ObjectMethodAccessor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.codegen.CodeGenUtils.ObjectPrivateFieldAccessor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.codegen.CodeGenUtils.ProductAccessor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.codegen.GeneratedAggregationsFunction$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.codegen.GeneratedCollector$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.codegen.GeneratedExpression$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.codegen.GeneratedFunction$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.codegen.GeneratedInput$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.codegen.Indenter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.examples.scala.StreamSQLExample$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.examples.scala.StreamSQLExample.Order$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.examples.scala.StreamTableExample$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.examples.scala.StreamTableExample.Order$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.examples.scala.TPCHQuery3Table$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.examples.scala.TPCHQuery3Table.Customer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.examples.scala.TPCHQuery3Table.Lineitem$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.examples.scala.TPCHQuery3Table.Order$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.examples.scala.WordCountSQL$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.examples.scala.WordCountSQL.WC$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.examples.scala.WordCountTable$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.examples.scala.WordCountTable.WC$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Abs$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Acos$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.AggFunctionCall$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Alias$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.And$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.ArrayCardinality$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.ArrayConstructor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.ArrayElement$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.ArrayElementAt$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Asc$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Asin$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Atan$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Avg$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Call$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Cast$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Ceil$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.CharLength$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Cos$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Cot$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Count$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.CurrentDate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.CurrentTime$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.CurrentTimestamp$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Degrees$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Desc$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Div$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.EqualTo$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Exp$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.ExpressionParser$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.ExpressionParser.Keyword$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.ExpressionUtils$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Extract$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Flattening$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Floor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.GetCompositeField$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.GreaterThan$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.GreaterThanOrEqual$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.If$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.InitCap$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.IsFalse$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.IsNotFalse$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.IsNotNull$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.IsNotTrue$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.IsNull$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.IsTrue$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.LessThan$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.LessThanOrEqual$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Like$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Literal$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Ln$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.LocalTime$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.LocalTimestamp$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Log10$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Lower$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Max$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Min$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Minus$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Mod$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Mul$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Not$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.NotEqualTo$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Null$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Or$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.OverCall$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Overlay$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Pi$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Plus$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Position$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Power$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.ProctimeAttribute$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Quarter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Radians$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.ResolvedFieldReference$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Round$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.RowtimeAttribute$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.ScalarFunctionCall$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Sign$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Similar$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Sin$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Sqrt$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.StddevPop$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.StddevSamp$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Substring$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Sum$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Sum0$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.SymbolExpression$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.TableFunctionCall$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Tan$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.TemporalCeil$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.TemporalFloor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.TemporalOverlaps$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.TimeIntervalUnit$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.TimePointUnit$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Trim$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.TrimConstants$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.TrimMode$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.UDAGGExpression$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.UnaryMinus$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.UnresolvedAlias$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.UnresolvedFieldReference$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.UnresolvedOverCall$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.Upper$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.VarPop$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.VarSamp$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.WindowEnd$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.WindowReference$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.expressions.WindowStart$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.functions.TimeMaterializationSqlFunction$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.functions.utils.AggSqlFunction$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.functions.utils.MathFunctions$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.functions.utils.ScalarSqlFunction$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.functions.utils.TableSqlFunction$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.cost.DataSetCost$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.cost.FlinkDefaultRelMetadataProvider$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.cost.FlinkRelMdRowCount$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.logical.Aggregate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.logical.AliasNode$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.logical.CatalogNode$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.logical.Distinct$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.logical.Filter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.logical.Intersect$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.logical.Join$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.logical.Limit$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.logical.LogicalRelNode$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.logical.LogicalTableFunctionCall$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.logical.Minus$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.logical.Project$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.logical.SessionGroupWindow$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.logical.SlidingGroupWindow$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.logical.Sort$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.logical.TumblingGroupWindow$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.logical.Union$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.logical.WindowAggregate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.nodes.datastream.AccMode$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.nodes.datastream.AccModeTrait$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.nodes.datastream.AccModeTraitDef$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.nodes.datastream.UpdateAsRetractionTrait$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.nodes.datastream.UpdateAsRetractionTraitDef$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.nodes.FlinkConventions$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.ProjectionTranslator$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.common.WindowStartEndPropertiesHavingRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.common.WindowStartEndPropertiesRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.dataSet.BatchTableSourceScanRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateWithNullValuesRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.dataSet.DataSetCalcRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.dataSet.DataSetCorrelateRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.dataSet.DataSetDistinctRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.dataSet.DataSetIntersectRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.dataSet.DataSetJoinRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.dataSet.DataSetLogicalWindowAggregateRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.dataSet.DataSetMinusRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.dataSet.DataSetScanRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.dataSet.DataSetSingleRowJoinRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.dataSet.DataSetSortRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.dataSet.DataSetUnionRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.dataSet.DataSetValuesRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.dataSet.DataSetWindowAggregateRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.datastream.DataStreamCalcRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.datastream.DataStreamCorrelateRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupAggregateRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupWindowAggregateRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.datastream.DataStreamLogicalWindowAggregateRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.datastream.DataStreamOverAggregateRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.datastream.DataStreamRetractionRules$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.datastream.DataStreamScanRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.datastream.DataStreamUnionRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.datastream.DataStreamValuesRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.datastream.StreamTableSourceScanRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.FlinkRuleSets$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.logical.EnumerableToLogicalTableScan$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.logical.LogicalUnnestRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.logical.PushFilterIntoTableSourceScanRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.rules.logical.PushProjectIntoTableSourceScanRule$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.schema.CompositeRelDataType$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.schema.DataSetTable$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.schema.DataStreamTable$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.schema.StreamTableSourceTable$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.schema.TableSourceTable$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.stats.ColumnStats$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.stats.FlinkStatistic$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.stats.TableStats$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.util.ExplodeFunctionUtil$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.util.RexProgramExtractor$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.plan.util.RexProgramRewriter$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.runtime.aggregate.AggregateUtil$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.runtime.triggers.StateCleaningCountTrigger$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.runtime.types.CRow$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.runtime.types.CRowSerializer$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.runtime.types.CRowSerializer.CRowSerializerConfigSnapshot$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.runtime.types.CRowTypeInfo$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.sinks.CsvTableSink$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.sources.CsvTableSource$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.typeutils.RowIntervalTypeInfo$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.typeutils.TypeCheckUtils$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.typeutils.TypeCoercion$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.validate.FunctionCatalog$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.validate.ValidationFailure$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.table.validate.ValidationSuccess$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.yarn.ApplicationClient$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.yarn.YarnMessages$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.yarn.YarnMessages.AcknowledgeApplicationClientRegistration$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.yarn.YarnMessages.ApplicationMasterStatus$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.yarn.YarnMessages.CheckForUserCommand$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.yarn.YarnMessages.HeartbeatWithYarn$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.yarn.YarnMessages.JobManagerLeaderAddress$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.yarn.YarnMessages.LocalGetYarnMessage$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.yarn.YarnMessages.LocalStopYarnSession$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.yarn.YarnMessages.RegisterApplicationClient$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.yarn.YarnMessages.StartYarnSession$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.yarn.YarnMessages.TriggerApplicationClientRegistration$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.yarn.YarnMessages.YarnContainersAllocated$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.yarn.YarnMessages.YarnContainersCompleted$
Static reference to the singleton instance of this Scala object.
MODULE$ - Static variable in class org.apache.flink.yarn.YarnTaskManager$
Static reference to the singleton instance of this Scala object.
ModuloKeyPartitioner$() - Constructor for class org.apache.flink.ml.common.FlinkMLTools.ModuloKeyPartitioner$
 
monitorTarget(ResourceID, HeartbeatTarget<O>) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatManager
Start monitoring a HeartbeatTarget.
monitorTarget(ResourceID, HeartbeatTarget<O>) - Method in class org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
 
MONTH - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The SQL MONTH operator.
month() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Creates an interval of the given number of months.
MONTH() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
MONTH() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
MONTH() - Method in class org.apache.flink.table.expressions.TimeIntervalUnit$
 
MONTH() - Static method in class org.apache.flink.table.expressions.TimeIntervalUnit
 
MONTH() - Method in class org.apache.flink.table.expressions.TimePointUnit$
 
MONTH() - Static method in class org.apache.flink.table.expressions.TimePointUnit
 
months() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Creates an interval of the given number of months.
MONTHS() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
MONTHS() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
moreAvailable() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel.BufferAndAvailability
 
msg - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
msg() - Method in exception org.apache.flink.table.api.ExpressionParserException
 
msg() - Method in exception org.apache.flink.table.api.SqlParserException
 
msg() - Method in exception org.apache.flink.table.api.TableException
 
msg() - Method in exception org.apache.flink.table.api.UnresolvedException
 
msg() - Method in exception org.apache.flink.table.api.ValidationException
 
Mul - Class in org.apache.flink.table.expressions
 
Mul(Expression, Expression) - Constructor for class org.apache.flink.table.expressions.Mul
 
Mul$ - Class in org.apache.flink.table.expressions
 
Mul$() - Constructor for class org.apache.flink.table.expressions.Mul$
 
multiple() - Static method in class org.apache.flink.table.plan.nodes.datastream.AccModeTraitDef
 
multiple() - Static method in class org.apache.flink.table.plan.nodes.datastream.UpdateAsRetractionTraitDef
 
MultipleIdsMessageAcknowledgingSourceBase<Type,UId,SessionId> - Class in org.apache.flink.streaming.api.functions.source
Abstract base class for data sources that receive elements from a message queue and acknowledge them back by IDs.
MultipleIdsMessageAcknowledgingSourceBase(Class<UId>) - Constructor for class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
Creates a new MessageAcknowledgingSourceBase for IDs of the given type.
MultipleIdsMessageAcknowledgingSourceBase(TypeInformation<UId>) - Constructor for class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
Creates a new MessageAcknowledgingSourceBase for IDs of the given type.
MultipleJobsDetails - Class in org.apache.flink.runtime.messages.webmonitor
An actor messages describing details of various jobs.
MultipleJobsDetails(JobDetails[], JobDetails[]) - Constructor for class org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails
 
MultipleLinearRegression - Class in org.apache.flink.ml.regression
Multiple linear regression using the ordinary least squares (OLS) estimator.
MultipleLinearRegression() - Constructor for class org.apache.flink.ml.regression.MultipleLinearRegression
 
MultipleLinearRegression$ - Class in org.apache.flink.ml.regression
 
MultipleLinearRegression$() - Constructor for class org.apache.flink.ml.regression.MultipleLinearRegression$
 
MultipleLinearRegression.ConvergenceThreshold$ - Class in org.apache.flink.ml.regression
 
MultipleLinearRegression.Iterations$ - Class in org.apache.flink.ml.regression
 
MultipleLinearRegression.LearningRateMethodValue$ - Class in org.apache.flink.ml.regression
 
MultipleLinearRegression.Stepsize$ - Class in org.apache.flink.ml.regression
 
MultipleProgramsTestBase - Class in org.apache.flink.test.util
Base class for unit tests that run multiple tests and want to reuse the same Flink cluster.
MultipleProgramsTestBase(MultipleProgramsTestBase.TestExecutionMode) - Constructor for class org.apache.flink.test.util.MultipleProgramsTestBase
 
MultipleProgramsTestBase.TestExecutionMode - Enum in org.apache.flink.test.util
Enum that defines which execution environment to run the next test on: An embedded local flink cluster, or the collection execution backend.
MultiplexingStreamRecordSerializer<T> - Class in org.apache.flink.migration.streaming.runtime.streamrecord
Legacy multiplexing TypeSerializer for stream records, watermarks and other stream elements.
MultiplexingStreamRecordSerializer(TypeSerializer<T>) - Constructor for class org.apache.flink.migration.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer
 
MultiplexingStreamRecordSerializer.MultiplexingStreamRecordSerializerConfigSnapshot<T> - Class in org.apache.flink.migration.streaming.runtime.streamrecord
Configuration snapshot specific to the MultiplexingStreamRecordSerializer.
MultiplexingStreamRecordSerializerConfigSnapshot() - Constructor for class org.apache.flink.migration.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer.MultiplexingStreamRecordSerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
MultiplexingStreamRecordSerializerConfigSnapshot(TypeSerializer<T>) - Constructor for class org.apache.flink.migration.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer.MultiplexingStreamRecordSerializerConfigSnapshot
 
MULTIPLY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Arithmetic multiplication operator, '*'.
multiplyBy(double) - Method in class org.apache.flink.table.plan.cost.DataSetCost
 
multiplyWith(int) - Method in class org.apache.flink.optimizer.costs.Costs
 
multiRandomSplit(DataSet<T>, double[], long, TypeInformation<T>, ClassTag<T>) - Method in class org.apache.flink.ml.preprocessing.Splitter$
Split a DataSet by the probability fraction of each element of a vector.
multiRandomSplit(DataSet<T>, double[], long, TypeInformation<T>, ClassTag<T>) - Static method in class org.apache.flink.ml.preprocessing.Splitter
Split a DataSet by the probability fraction of each element of a vector.
MULTISET_EXCEPT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The "MULTISET EXCEPT" operator.
MULTISET_EXCEPT_ALL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The "MULTISET EXCEPT ALL" operator.
MULTISET_INTERSECT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The "MULTISET INTERSECT" operator.
MULTISET_INTERSECT_ALL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The "MULTISET INTERSECT ALL" operator.
MULTISET_QUERY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The MULTISET Query Constructor.
MULTISET_UNION - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The "MULTISET UNION" operator.
MULTISET_UNION_ALL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The "MULTISET UNION ALL" operator.
MULTISET_VALUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The MULTISET Value Constructor.
MultiShotLatch - Class in org.apache.flink.core.testutils
Latch for synchronizing parts of code in tests.
MultiShotLatch() - Constructor for class org.apache.flink.core.testutils.MultiShotLatch
 
MultiStreamStateHandle - Class in org.apache.flink.runtime.state
Wrapper class that takes multiple StreamStateHandle and makes them look like a single one.
MultiStreamStateHandle(List<StreamStateHandle>) - Constructor for class org.apache.flink.runtime.state.MultiStreamStateHandle
 
MultiTypeMethodCallGen - Class in org.apache.flink.table.codegen.calls
Generates a function call that calls a method which returns the same type that it takes as first argument.
MultiTypeMethodCallGen(Method) - Constructor for class org.apache.flink.table.codegen.calls.MultiTypeMethodCallGen
 
Murmur3_32 - Class in org.apache.flink.graph.utils
A resettable implementation of the 32-bit MurmurHash algorithm.
Murmur3_32(int) - Constructor for class org.apache.flink.graph.utils.Murmur3_32
A resettable implementation of the 32-bit MurmurHash algorithm.
murmurHash(int) - Static method in class org.apache.flink.util.MathUtils
This function hashes an integer value.
MusicProfiles - Class in org.apache.flink.graph.examples
This example demonstrates how to mix the DataSet Flink API with the Gelly API.
MusicProfiles() - Constructor for class org.apache.flink.graph.examples.MusicProfiles
 
MusicProfiles.CreateSimilarUserEdges - Class in org.apache.flink.graph.examples
 
MusicProfiles.ExtractMismatchSongIds - Class in org.apache.flink.graph.examples
 
MusicProfiles.FilterOutMismatches - Class in org.apache.flink.graph.examples
 
MusicProfiles.FilterSongNodes - Class in org.apache.flink.graph.examples
 
MusicProfiles.GetTopSongPerUser - Class in org.apache.flink.graph.examples
 
MusicProfilesData - Class in org.apache.flink.graph.examples.data
Provides the default data sets used for the Music Profiles example program.
MusicProfilesData() - Constructor for class org.apache.flink.graph.examples.data.MusicProfilesData
 
mutable() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.CaseClassDescriptor
 
MutableHashTable<BT,PT> - Class in org.apache.flink.runtime.operators.hash
An implementation of a Hybrid Hash Join.
MutableHashTable(TypeSerializer<BT>, TypeSerializer<PT>, TypeComparator<BT>, TypeComparator<PT>, TypePairComparator<PT, BT>, List<MemorySegment>, IOManager) - Constructor for class org.apache.flink.runtime.operators.hash.MutableHashTable
 
MutableHashTable(TypeSerializer<BT>, TypeSerializer<PT>, TypeComparator<BT>, TypeComparator<PT>, TypePairComparator<PT, BT>, List<MemorySegment>, IOManager, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.MutableHashTable
 
MutableHashTable(TypeSerializer<BT>, TypeSerializer<PT>, TypeComparator<BT>, TypeComparator<PT>, TypePairComparator<PT, BT>, List<MemorySegment>, IOManager, int, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.MutableHashTable
 
MutableHashTable.HashBucketIterator<BT,PT> - Class in org.apache.flink.runtime.operators.hash
 
MutableHashTable.ProbeIterator<PT> - Class in org.apache.flink.runtime.operators.hash
 
MutableHashTable.UnmatchedBuildIterator<BT,PT> - Class in org.apache.flink.runtime.operators.hash
Iterate all the elements in memory which has not been probed during probe phase.
MutableIOMetrics - Class in org.apache.flink.runtime.webmonitor.utils
This class is a mutable version of the IOMetrics class that allows adding up IO-related metrics.
MutableIOMetrics() - Constructor for class org.apache.flink.runtime.webmonitor.utils.MutableIOMetrics
 
MutableMaxAgg() - Constructor for class org.apache.flink.api.java.aggregation.MaxAggregationFunction.MutableMaxAgg
 
MutableMinAgg() - Constructor for class org.apache.flink.api.java.aggregation.MinAggregationFunction.MutableMinAgg
 
MutableObjectIterator<E> - Interface in org.apache.flink.util
A simple iterator interface.
MutableReader<T extends IOReadableWritable> - Interface in org.apache.flink.runtime.io.network.api.reader
A record-oriented reader for mutable record types.
MutableRecordReader<T extends IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.reader
 
MutableRecordReader(InputGate, String[]) - Constructor for class org.apache.flink.runtime.io.network.api.reader.MutableRecordReader
Creates a new MutableRecordReader that de-serializes records from the given input gate and can spill partial records to disk, if they grow large.
mutableTypes() - Method in interface org.apache.flink.api.scala.codegen.TypeAnalyzer
 
myName() - Method in class org.apache.flink.api.scala.InnerClosureFinder
 
MySelector() - Constructor for class org.apache.flink.streaming.examples.iteration.IterateExample.MySelector
 

N

name - Variable in class org.apache.flink.api.common.operators.Operator
 
name - Variable in class org.apache.flink.api.common.state.StateDescriptor
Name that uniquely identifies state created from this StateDescriptor.
name(String) - Method in class org.apache.flink.api.java.operators.DataSink
 
name(String) - Method in class org.apache.flink.api.java.operators.DeltaIteration
Sets the name for the iteration.
name - Variable in class org.apache.flink.api.java.operators.Operator
 
name(String) - Method in class org.apache.flink.api.java.operators.Operator
Sets the name of this operator.
name() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.FieldDescriptor
 
name(String) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
name(String) - Method in class org.apache.flink.api.scala.DataSet
Sets the name of the DataSet.
name() - Method in class org.apache.flink.api.scala.FlinkShell.YarnConfig
 
name - Variable in class org.apache.flink.examples.java.misc.CollectionExecutionExample.User
 
name - Variable in class org.apache.flink.graph.drivers.parameter.SimpleParameter
 
name - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
name() - Method in class org.apache.flink.runtime.checkpoint.MasterState
 
name - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump
The name of the stored metric.
name(String) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
Sets the name of this sink.
name(String) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Sets the name of the current data stream.
name() - Method in class org.apache.flink.streaming.api.scala.DataStream
Gets the name of the current data stream.
name(String) - Method in class org.apache.flink.streaming.api.scala.DataStream
Sets the name of the current data stream.
name - Variable in class org.apache.flink.streaming.api.transformations.StreamTransformation
 
name(String) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink
Sets the name of this sink.
name(String) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010.FlinkKafkaProducer010Configuration
 
name() - Method in class org.apache.flink.streaming.scala.examples.join.WindowJoin.Grade
 
name() - Method in class org.apache.flink.streaming.scala.examples.join.WindowJoin.Person
 
name() - Method in class org.apache.flink.streaming.scala.examples.join.WindowJoin.Salary
 
name() - Method in class org.apache.flink.table.calcite.FlinkRelBuilder.NamedWindowProperty
 
name() - Method in class org.apache.flink.table.codegen.CodeGenUtils.ObjectGenericFieldAccessor
 
name() - Method in class org.apache.flink.table.codegen.GeneratedAggregationsFunction
 
name() - Method in class org.apache.flink.table.codegen.GeneratedCollector
 
name() - Method in class org.apache.flink.table.codegen.GeneratedFunction
 
name() - Method in class org.apache.flink.table.codegen.GeneratedInput
 
name() - Method in class org.apache.flink.table.expressions.Alias
 
name() - Method in interface org.apache.flink.table.expressions.NamedExpression
 
name() - Method in class org.apache.flink.table.expressions.ResolvedFieldReference
 
name() - Method in interface org.apache.flink.table.expressions.TableSymbol
 
name() - Method in class org.apache.flink.table.expressions.TableSymbols.TableSymbolValue
 
name() - Method in class org.apache.flink.table.expressions.UnresolvedAlias
 
name() - Method in class org.apache.flink.table.expressions.UnresolvedFieldReference
 
name() - Method in class org.apache.flink.table.expressions.WindowReference
 
NamedChannel - Class in org.apache.flink.optimizer.plan
 
NamedChannel(String, PlanNode) - Constructor for class org.apache.flink.optimizer.plan.NamedChannel
Initializes NamedChannel.
NamedChannel(String, PlanNode, TempMode) - Constructor for class org.apache.flink.optimizer.plan.NamedChannel
 
NamedExpression - Interface in org.apache.flink.table.expressions
 
NamedFlatFieldDescriptor(String, int, TypeInformation<?>) - Constructor for class org.apache.flink.api.java.typeutils.PojoTypeInfo.NamedFlatFieldDescriptor
 
NamedWindowProperty(String, WindowProperty) - Constructor for class org.apache.flink.table.calcite.FlinkRelBuilder.NamedWindowProperty
 
NamedWindowProperty$() - Constructor for class org.apache.flink.table.calcite.FlinkRelBuilder.NamedWindowProperty$
 
NAMES() - Method in class org.apache.flink.streaming.scala.examples.join.WindowJoinSampleData$
 
NAMES() - Static method in class org.apache.flink.streaming.scala.examples.join.WindowJoinSampleData
 
namespaceSerializer - Variable in class org.apache.flink.migration.runtime.state.filesystem.AbstractFsStateSnapshot
Deprecated.
Namespace Serializer
namespaceSerializer - Variable in class org.apache.flink.migration.runtime.state.memory.AbstractMemStateSnapshot
Deprecated.
Namespace Serializer
namespaceSerializer - Variable in class org.apache.flink.migration.runtime.state.memory.AbstractMigrationRestoreStrategy
Deprecated.
Namespace Serializer
namespaceSerializer - Variable in class org.apache.flink.runtime.state.heap.AbstractHeapState
 
naryOperation(AbstractInsnNode, List) - Method in class org.apache.flink.api.java.sca.NestedMethodAnalyzer
 
NAryUnionPlanNode - Class in org.apache.flink.optimizer.plan
A union operation over multiple inputs (2 or more).
NAryUnionPlanNode(BinaryUnionNode, List<Channel>, GlobalProperties, Costs) - Constructor for class org.apache.flink.optimizer.plan.NAryUnionPlanNode
 
NATIVE_BLOCK_SIZE - Static variable in class org.apache.flink.api.common.io.BinaryInputFormat
 
NATIVE_BLOCK_SIZE - Static variable in class org.apache.flink.api.common.io.BinaryOutputFormat
 
NATIVE_BYTE_ORDER - Static variable in class org.apache.flink.core.memory.MemoryUtils
The native byte order of the platform on which the system currently runs.
ndv() - Method in class org.apache.flink.table.plan.stats.ColumnStats
 
needle() - Method in class org.apache.flink.table.expressions.Position
 
needsConversion(TypeInformation<Object>, TypeInformation<T>) - Method in interface org.apache.flink.table.plan.nodes.CommonScan
We check if the input type is exactly the same as the internal row type.
needsSpace() - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
needsSpace() - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
needsSpace() - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
needsSpace() - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
needsUpdatesAsRetraction() - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupAggregate
 
needsUpdatesAsRetraction() - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
needsUpdatesAsRetraction() - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamOverAggregate
 
needsUpdatesAsRetraction() - Method in interface org.apache.flink.table.plan.nodes.datastream.DataStreamRel
Whether the DataStreamRel requires that update and delete changes are sent with retraction messages.
needsUpdatesAsRetraction(RelNode) - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamRetractionRules.SetUpdatesAsRetractionRule
Checks if a RelNode requires that update changes are sent with retraction messages.
needToCleanupState(long) - Method in class org.apache.flink.table.runtime.aggregate.ProcessFunctionWithCleanupState
 
Neighbor<VV,EV> - Class in org.apache.flink.graph.gsa
This class represents a <sourceVertex, edge> pair This is a wrapper around Tuple2<VV, EV> for convenience in the GatherFunction
Neighbor() - Constructor for class org.apache.flink.graph.gsa.Neighbor
 
Neighbor(VV, EV) - Constructor for class org.apache.flink.graph.gsa.Neighbor
 
NeighborsFunction<K,VV,EV,O> - Interface in org.apache.flink.graph
Interface to be implemented by the function applied to a vertex neighborhood in the Graph.groupReduceOnNeighbors(NeighborsFunction, EdgeDirection) method.
NeighborsFunction<K,VV,EV,T> - Class in org.apache.flink.graph.scala
 
NeighborsFunction() - Constructor for class org.apache.flink.graph.scala.NeighborsFunction
 
NeighborsFunctionWithVertexValue<K,VV,EV,O> - Interface in org.apache.flink.graph
Interface to be implemented by the function applied to a vertex neighborhood in the Graph.groupReduceOnNeighbors(NeighborsFunctionWithVertexValue, EdgeDirection) method.
NeighborsFunctionWithVertexValue<K,VV,EV,T> - Class in org.apache.flink.graph.scala
 
NeighborsFunctionWithVertexValue() - Constructor for class org.apache.flink.graph.scala.NeighborsFunctionWithVertexValue
 
NeighborWithComponentIDJoin() - Constructor for class org.apache.flink.examples.java.graph.ConnectedComponents.NeighborWithComponentIDJoin
 
NestedFieldsProjectableTableSource<T> - Interface in org.apache.flink.table.sources
Adds support for projection push-down to a TableSource with nested fields.
NestedKeyDiscarder<IN> - Class in org.apache.flink.python.api.functions.util
 
NestedKeyDiscarder() - Constructor for class org.apache.flink.python.api.functions.util.NestedKeyDiscarder
 
NestedMapsStateTable<K,N,S> - Class in org.apache.flink.runtime.state.heap
This implementation of StateTable uses nested HashMap objects.
NestedMapsStateTable(InternalKeyContext<K>, RegisteredKeyedBackendStateMetaInfo<N, S>) - Constructor for class org.apache.flink.runtime.state.heap.NestedMapsStateTable
Creates a new NestedMapsStateTable for the given key context and meta info.
NestedMethodAnalyzer - Class in org.apache.flink.api.java.sca
Extends ASM's BasicInterpreter.
NestedMethodAnalyzer(UdfAnalyzer, String, MethodNode, List<BasicValue>, int, boolean) - Constructor for class org.apache.flink.api.java.sca.NestedMethodAnalyzer
 
NettyBufferPool - Class in org.apache.flink.runtime.io.network.netty
Wrapper around Netty's PooledByteBufAllocator with strict control over the number of created arenas.
NettyBufferPool(int) - Constructor for class org.apache.flink.runtime.io.network.netty.NettyBufferPool
Creates Netty's buffer pool with the specified number of direct arenas.
NettyConfig - Class in org.apache.flink.runtime.io.network.netty
 
NettyConfig(InetAddress, int, int, int, Configuration) - Constructor for class org.apache.flink.runtime.io.network.netty.NettyConfig
 
nettyConfig() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
NettyConnectionManager - Class in org.apache.flink.runtime.io.network.netty
 
NettyConnectionManager(NettyConfig) - Constructor for class org.apache.flink.runtime.io.network.netty.NettyConnectionManager
 
NettyProtocol - Interface in org.apache.flink.runtime.io.network.netty
 
NetUtils - Class in org.apache.flink.util
 
NetUtils() - Constructor for class org.apache.flink.util.NetUtils
 
NetUtils.SocketFactory - Interface in org.apache.flink.util
 
network() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
network() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
 
network() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
NETWORK_BUFFERS_MEMORY_FRACTION - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Fraction of JVM memory to use for network buffers.
NETWORK_BUFFERS_MEMORY_MAX - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Maximum memory size for network buffers (in bytes)
NETWORK_BUFFERS_MEMORY_MIN - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Minimum memory size for network buffers (in bytes)
NETWORK_BUFFERS_PER_CHANNEL - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Number of network buffers to use for each outgoing/incoming channel (subpartition/input channel).
NETWORK_DETAILED_METRICS - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Boolean flag to enable/disable more detailed metrics about inbound/outbound network queue lengths.
NETWORK_EXTRA_BUFFERS_PER_GATE - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Number of extra network buffers to use for each outgoing/incoming gate (result partition/input gate).
NETWORK_NUM_BUFFERS - Static variable in class org.apache.flink.configuration.TaskManagerOptions
NETWORK_REQUEST_BACKOFF_INITIAL - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Minimum backoff for partition requests of input channels.
NETWORK_REQUEST_BACKOFF_MAX - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Maximum backoff for partition requests of input channels.
NetworkBufferPool - Class in org.apache.flink.runtime.io.network.buffer
The NetworkBufferPool is a fixed size pool of MemorySegment instances for the network stack.
NetworkBufferPool(int, int, MemoryType) - Constructor for class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
Allocates all MemorySegment instances managed by this pool.
networkBufferSize() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
networkBuffersPerChannel() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
networkBufFraction() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
networkBufMax() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
networkBufMin() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
NetworkEnvironment - Class in org.apache.flink.runtime.io.network
Network I/O components of each TaskManager instance.
NetworkEnvironment(NetworkBufferPool, ConnectionManager, ResultPartitionManager, TaskEventDispatcher, KvStateRegistry, KvStateServer, IOManager.IOMode, int, int, int, int) - Constructor for class org.apache.flink.runtime.io.network.NetworkEnvironment
 
NetworkEnvironmentConfiguration - Class in org.apache.flink.runtime.taskmanager
Configuration object for the network stack.
NetworkEnvironmentConfiguration(float, long, long, int, MemoryType, IOManager.IOMode, int, int, int, int) - Constructor for class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
Constructor for a setup with purely local communication (no netty).
NetworkEnvironmentConfiguration(float, long, long, int, MemoryType, IOManager.IOMode, int, int, int, int, NettyConfig) - Constructor for class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
NEVER_NULL() - Method in class org.apache.flink.table.codegen.GeneratedExpression$
 
NEVER_NULL() - Static method in class org.apache.flink.table.codegen.GeneratedExpression
 
NeverTrigger() - Constructor for class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
 
NEW - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
New(Protos.TaskID) - Constructor for class org.apache.flink.mesos.scheduler.TaskMonitor.New
 
New$() - Constructor for class org.apache.flink.mesos.scheduler.TaskMonitor.New$
 
newBuilder() - Static method in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
 
newBuilder() - Static method in class org.apache.flink.runtime.clusterframework.overlays.FlinkDistributionOverlay
 
newBuilder() - Static method in class org.apache.flink.runtime.clusterframework.overlays.HadoopConfOverlay
 
newBuilder() - Static method in class org.apache.flink.runtime.clusterframework.overlays.HadoopUserOverlay
 
newBuilder() - Static method in class org.apache.flink.runtime.clusterframework.overlays.KeytabOverlay
 
newBuilder() - Static method in class org.apache.flink.runtime.clusterframework.overlays.Krb5ConfOverlay
 
newBuilder() - Static method in class org.apache.flink.runtime.clusterframework.overlays.SSLStoreOverlay
 
newControlFlowEdge(int, int) - Method in class org.apache.flink.api.java.sca.ModifiedASMAnalyzer
 
newDynamicPropertiesOption() - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
Get an instance of the dynamic properties option.
newElement() - Method in class org.apache.flink.table.runtime.aggregate.SingleElementIterable.SingleElementIterator
 
newExecutionState() - Method in class org.apache.flink.runtime.messages.ExecutionGraphMessages.ExecutionStateChanged
 
newFieldTrimmer() - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Creates a RelFieldTrimmer.
newFrame(int, int) - Method in class org.apache.flink.api.java.sca.ModifiedASMAnalyzer
 
newFrame(Frame) - Method in class org.apache.flink.api.java.sca.ModifiedASMAnalyzer
 
newInstance(Class<T>) - Static method in class org.apache.flink.util.ReflectionUtil
 
newInstanceAvailable(Instance) - Method in interface org.apache.flink.runtime.instance.InstanceListener
Called when a new instance becomes available.
newInstanceAvailable(Instance) - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
newJobStatus() - Method in class org.apache.flink.runtime.messages.ExecutionGraphMessages.JobStatusChanged
 
NewLeaderAvailable - Class in org.apache.flink.runtime.clusterframework.messages
Message sent to the Flink resource manager to indicate that a new leader is available.
NewLeaderAvailable(String, UUID) - Constructor for class org.apache.flink.runtime.clusterframework.messages.NewLeaderAvailable
 
newLeases() - Method in class org.apache.flink.mesos.scheduler.LaunchCoordinator.GatherData
 
newMacroHelper(C) - Method in class org.apache.flink.api.scala.codegen.MacroContextHolder$
 
newMacroHelper(C) - Static method in class org.apache.flink.api.scala.codegen.MacroContextHolder
 
newName(String) - Method in class org.apache.flink.table.codegen.CodeGenUtils$
 
newName(String) - Static method in class org.apache.flink.table.codegen.CodeGenUtils
 
newOperation(AbstractInsnNode) - Method in class org.apache.flink.api.java.sca.NestedMethodAnalyzer
 
newSlotAvailable(Instance) - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
 
newSlotAvailable(Instance) - Method in interface org.apache.flink.runtime.jobmanager.scheduler.SlotAvailabilityListener
 
newStateTable(RegisteredKeyedBackendStateMetaInfo<N, V>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
newTaskID() - Method in interface org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore
Generate a new task ID for a worker.
newTaskID() - Method in class org.apache.flink.mesos.runtime.clusterframework.store.StandaloneMesosWorkerStore
 
newTaskID() - Method in class org.apache.flink.mesos.runtime.clusterframework.store.ZooKeeperMesosWorkerStore
Generates a new task ID.
newThread(Runnable) - Method in class org.apache.flink.runtime.highavailability.ServicesThreadFactory
 
newThread(Runnable) - Method in class org.apache.flink.runtime.taskmanager.DispatcherThreadFactory
 
newThread(Runnable) - Method in class org.apache.flink.runtime.util.ExecutorThreadFactory
 
newValue(Type) - Method in class org.apache.flink.api.java.sca.NestedMethodAnalyzer
 
newWorker(Protos.TaskID) - Static method in class org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore.Worker
Create a new worker with the given taskID.
NEXT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
NEXT function to be used within MATCH_RECOGNIZE.
next() - Method in class org.apache.flink.api.common.functions.util.CopyingIterator
 
next() - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase.SimpleListIterable.SimpleListIterator
 
next() - Method in class org.apache.flink.api.common.operators.util.ListKeyGroupedIterator.ValuesIterator
 
next() - Method in class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
 
next() - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
 
next() - Method in class org.apache.flink.api.scala.codegen.Counter
 
next(String) - Method in class org.apache.flink.cep.pattern.Pattern
Appends a new pattern to the existing one.
next(String) - Method in class org.apache.flink.cep.scala.pattern.Pattern
Appends a new pattern to the existing one.
next() - Method in class org.apache.flink.graph.generator.random.AbstractGeneratorFactory
 
next() - Method in class org.apache.flink.graph.generator.random.JDKRandomGeneratorFactory
 
next() - Method in class org.apache.flink.graph.generator.random.MersenneTwisterFactory
 
next() - Method in class org.apache.flink.graph.pregel.MessageIterator
 
next() - Method in class org.apache.flink.graph.spargel.MessageIterator
 
next() - Method in class org.apache.flink.hadoopcompatibility.mapred.wrapper.HadoopTupleUnwrappingIterator
 
next(E) - Method in class org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator
 
next() - Method in class org.apache.flink.runtime.io.disk.ChannelReaderInputViewIterator
 
next(E) - Method in class org.apache.flink.runtime.io.disk.InputViewIterator
 
next() - Method in class org.apache.flink.runtime.io.disk.InputViewIterator
 
next() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.Enumerator
 
next(T) - Method in interface org.apache.flink.runtime.io.network.api.reader.MutableReader
 
next(T) - Method in class org.apache.flink.runtime.io.network.api.reader.MutableRecordReader
 
next() - Method in interface org.apache.flink.runtime.io.network.api.reader.Reader
 
next() - Method in class org.apache.flink.runtime.io.network.api.reader.RecordReader
 
next(BT) - Method in class org.apache.flink.runtime.iterative.io.HashPartitionIterator
 
next() - Method in class org.apache.flink.runtime.iterative.io.HashPartitionIterator
 
next() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable.SimpleIterator
 
next(T) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable.EntryIterator
 
next() - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable.EntryIterator
 
next(T) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.EntryIterator
 
next() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.EntryIterator
 
next(BT) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable.HashBucketIterator
 
next() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable.HashBucketIterator
 
next() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable.ProbeIterator
 
next(BT) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable.UnmatchedBuildIterator
 
next() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable.UnmatchedBuildIterator
 
next(T) - Method in class org.apache.flink.runtime.operators.resettable.BlockResettableMutableObjectIterator
 
next() - Method in class org.apache.flink.runtime.operators.resettable.BlockResettableMutableObjectIterator
 
next() - Method in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
next() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
next(T) - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
next() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
next(E) - Method in class org.apache.flink.runtime.operators.sort.MergeIterator
Gets the next smallest element, with respect to the definition of order implied by the TypeSerializer provided to this iterator.
next() - Method in class org.apache.flink.runtime.operators.sort.MergeIterator
Gets the next smallest element, with respect to the definition of order implied by the TypeSerializer provided to this iterator.
next() - Method in class org.apache.flink.runtime.operators.sort.NonReusingSortMergeCoGroupIterator
 
next() - Method in class org.apache.flink.runtime.operators.sort.ReusingSortMergeCoGroupIterator
 
next() - Method in interface org.apache.flink.runtime.operators.util.CoGroupTaskIterator
Moves the internal pointer to the next key (if present).
next() - Method in class org.apache.flink.runtime.operators.util.metrics.CountingIterator
 
next(IN) - Method in class org.apache.flink.runtime.operators.util.metrics.CountingMutableObjectIterator
 
next() - Method in class org.apache.flink.runtime.operators.util.metrics.CountingMutableObjectIterator
 
next(T) - Method in class org.apache.flink.runtime.operators.util.ReaderIterator
 
next() - Method in class org.apache.flink.runtime.operators.util.ReaderIterator
 
next() - Method in class org.apache.flink.runtime.util.EmptyIterator
Always throws a NoSuchElementException.
next(E) - Method in class org.apache.flink.runtime.util.EmptyMutableObjectIterator
Always returns null.
next() - Method in class org.apache.flink.runtime.util.EmptyMutableObjectIterator
Always returns null.
next() - Method in class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator.ValuesIterator
 
next() - Method in class org.apache.flink.runtime.util.NonReusingMutableToRegularIteratorWrapper
 
next(T) - Method in class org.apache.flink.runtime.util.RegularToMutableObjectIterator
 
next() - Method in class org.apache.flink.runtime.util.RegularToMutableObjectIterator
 
next() - Method in class org.apache.flink.runtime.util.ReusingKeyGroupedIterator.ValuesIterator
Prior to call this method, call hasNext() once!
next() - Method in class org.apache.flink.runtime.util.ReusingMutableToRegularIteratorWrapper
 
next() - Method in class org.apache.flink.runtime.util.SingleElementIterator
 
next() - Method in class org.apache.flink.streaming.examples.join.WindowJoinSampleData.GradeSource
 
next() - Method in class org.apache.flink.streaming.examples.join.WindowJoinSampleData.SalarySource
 
next() - Method in class org.apache.flink.streaming.examples.utils.ThrottledIterator
 
next() - Method in class org.apache.flink.streaming.scala.examples.join.WindowJoinSampleData.GradeSource
 
next() - Method in class org.apache.flink.streaming.scala.examples.join.WindowJoinSampleData.SalarySource
 
next() - Method in class org.apache.flink.table.runtime.aggregate.SingleElementIterable.SingleElementIterator
 
next() - Method in class org.apache.flink.util.LongValueSequenceIterator
 
next(E) - Method in interface org.apache.flink.util.MutableObjectIterator
Gets the next element from the collection.
next() - Method in interface org.apache.flink.util.MutableObjectIterator
Gets the next element from the collection.
next() - Method in class org.apache.flink.util.NumberSequenceIterator
 
next(StringValue) - Method in class org.apache.flink.util.StringValueUtils.WhitespaceTokenizer
Gets the next token from the string.
next() - Method in class org.apache.flink.util.UnionIterator
 
next(int) - Method in class org.apache.flink.util.XORShiftRandom
All other methods like nextInt()/nextDouble()...
NEXT_VALUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The sequence next value function: NEXT VALUE FOR sequence
nextBlock() - Method in class org.apache.flink.runtime.operators.resettable.BlockResettableMutableObjectIterator
 
nextBlock() - Method in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
nextBlock() - Method in interface org.apache.flink.runtime.util.MemoryBlockIterator
Move the iterator to the next memory block.
nextElement - Variable in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
nextId() - Static method in class org.apache.flink.table.expressions.TimeIntervalUnit
 
nextId() - Static method in class org.apache.flink.table.expressions.TimePointUnit
 
nextId() - Static method in class org.apache.flink.table.expressions.TrimMode
 
nextId() - Static method in class org.apache.flink.table.plan.nodes.datastream.AccMode
 
nextId_$eq(int) - Static method in class org.apache.flink.table.expressions.TimeIntervalUnit
 
nextId_$eq(int) - Static method in class org.apache.flink.table.expressions.TimePointUnit
 
nextId_$eq(int) - Static method in class org.apache.flink.table.expressions.TrimMode
 
nextId_$eq(int) - Static method in class org.apache.flink.table.plan.nodes.datastream.AccMode
 
NextInputSplit(byte[]) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.NextInputSplit
 
NextInputSplit$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.NextInputSplit$
 
nextKey() - Method in class org.apache.flink.api.common.operators.util.ListKeyGroupedIterator
Moves the iterator to the next key.
nextKey() - Method in interface org.apache.flink.runtime.util.KeyGroupedIterator
 
nextKey() - Method in class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator
Moves the iterator to the next key.
nextKey() - Method in class org.apache.flink.runtime.util.ReusingKeyGroupedIterator
Moves the iterator to the next key.
nextName() - Static method in class org.apache.flink.table.expressions.TimeIntervalUnit
 
nextName() - Static method in class org.apache.flink.table.expressions.TimePointUnit
 
nextName() - Static method in class org.apache.flink.table.expressions.TrimMode
 
nextName() - Static method in class org.apache.flink.table.plan.nodes.datastream.AccMode
 
nextName_$eq(Iterator<String>) - Static method in class org.apache.flink.table.expressions.TimeIntervalUnit
 
nextName_$eq(Iterator<String>) - Static method in class org.apache.flink.table.expressions.TimePointUnit
 
nextName_$eq(Iterator<String>) - Static method in class org.apache.flink.table.expressions.TrimMode
 
nextName_$eq(Iterator<String>) - Static method in class org.apache.flink.table.plan.nodes.datastream.AccMode
 
nextOverflowBucket - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
 
nextOverflowBucket - Variable in class org.apache.flink.runtime.operators.hash.InMemoryPartition
 
nextRecord(T) - Method in class org.apache.flink.addons.hbase.AbstractTableInputFormat
 
nextRecord(T) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
 
nextRecord(OT) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
nextRecord(OT) - Method in interface org.apache.flink.api.common.io.InputFormat
Reads the next record from the input.
nextRecord(OT) - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
 
nextRecord(Tuple2<K, V>) - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormat
 
nextRecord(Tuple2<K, V>) - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormat
 
nextRecord(E) - Method in class org.apache.flink.api.java.io.AvroInputFormat
 
nextRecord(T) - Method in class org.apache.flink.api.java.io.CollectionInputFormat
 
nextRecord(OUT) - Method in class org.apache.flink.api.java.io.CsvInputFormat
 
nextRecord(T) - Method in class org.apache.flink.api.java.io.IteratorInputFormat
 
nextRecord(Row) - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat
Stores the next resultSet row in a tuple
nextRecord(T) - Method in class org.apache.flink.api.java.io.ParallelIteratorInputFormat
 
nextRecord(Tuple2<K, V>) - Method in class org.apache.flink.api.scala.hadoop.mapred.HadoopInputFormat
 
nextRecord(Tuple2<K, V>) - Method in class org.apache.flink.api.scala.hadoop.mapreduce.HadoopInputFormat
 
nextRecord(OUT) - Method in class org.apache.flink.batch.connectors.cassandra.CassandraInputFormat
 
nextRecord(Tweet) - Method in class org.apache.flink.contrib.tweetinputformat.io.SimpleTweetInputFormat
 
nextRecord(FileCopyTask) - Method in class org.apache.flink.examples.java.distcp.FileCopyTaskInputFormat
 
nextRecord(T) - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
 
nextRecord() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
nextRecord(CRow) - Method in class org.apache.flink.table.runtime.io.CRowValuesInputFormat
 
nextRecord(Row) - Method in class org.apache.flink.table.runtime.io.ValuesInputFormat
 
nextSegment() - Method in interface org.apache.flink.core.memory.MemorySegmentSource
Gets the next memory segment.
nextSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.FileChannelInputView
 
nextSegment(MemorySegment, int) - Method in class org.apache.flink.runtime.io.disk.FileChannelOutputView
 
nextSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
Gets the next segment from the asynchronous block reader.
nextSegment(MemorySegment, int) - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelWriterOutputView
 
nextSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.iomanager.HeaderlessChannelReaderInputView
 
nextSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.RandomAccessInputView
 
nextSegment(MemorySegment, int) - Method in class org.apache.flink.runtime.io.disk.RandomAccessOutputView
 
nextSegment(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
 
nextSegment(MemorySegment, int) - Method in class org.apache.flink.runtime.io.disk.SimpleCollectingOutputView
 
nextSegment(MemorySegment, int) - Method in class org.apache.flink.runtime.io.disk.SpillingBuffer
 
nextSegment(MemorySegment, int) - Method in class org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
 
nextSegment(MemorySegment) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
The method by which concrete subclasses realize page crossing.
nextSegment(MemorySegment, int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
This method must return a segment.
nextSegment() - Method in class org.apache.flink.runtime.memory.ListMemorySegmentSource
 
nextSegment(MemorySegment, int) - Method in class org.apache.flink.runtime.operators.hash.HashPartition.BuildSideBuffer
 
nextSegment(MemorySegment) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
 
nextSegment() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
This is the method called by the partitions to request memory to serialize records.
nextStateData() - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
nextStateData() - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
nextStateData() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
nextStateData() - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
nextStringEndPos(byte[], int, int, byte[]) - Method in class org.apache.flink.types.parser.FieldParser
Returns the end position of a string.
nextStringLength(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.FieldParser
Returns the length of a string.
nextTuple() - Method in class org.apache.flink.storm.split.operators.RandomSpout
 
nextTuple() - Method in class org.apache.flink.storm.util.FileSpout
 
nextTuple() - Method in class org.apache.flink.storm.util.FiniteFileSpout
 
nextTuple() - Method in class org.apache.flink.storm.util.InMemorySpout
 
nextTuple() - Method in class org.apache.flink.storm.util.NullTerminatingSpout
 
nextValue(V) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.KeyMap.TraversalEvaluator
Called for each value found for the current key.
NFA<T> - Class in org.apache.flink.cep.nfa
Non-deterministic finite automaton implementation.
NFA(TypeSerializer<T>, long, boolean) - Constructor for class org.apache.flink.cep.nfa.NFA
 
NFA.NFASerializer<T> - Class in org.apache.flink.cep.nfa
A TypeSerializer for NFA that uses Java Serialization.
NFA.NFASerializerConfigSnapshot<T> - Class in org.apache.flink.cep.nfa
The TypeSerializerConfigSnapshot serializer configuration to be stored with the managed state.
NFA.Serializer<T> - Class in org.apache.flink.cep.nfa
A TypeSerializer for NFA that uses Java Serialization.
NFACompiler - Class in org.apache.flink.cep.nfa.compiler
Compiler class containing methods to compile a Pattern into a NFA or a NFACompiler.NFAFactory.
NFACompiler() - Constructor for class org.apache.flink.cep.nfa.compiler.NFACompiler
 
NFACompiler.NFAFactory<T> - Interface in org.apache.flink.cep.nfa.compiler
Factory interface for NFA.
NFASerializer(TypeSerializer<T>) - Constructor for class org.apache.flink.cep.nfa.NFA.NFASerializer
 
NFASerializer(TypeSerializer<T>, TypeSerializer<SharedBuffer<String, T>>) - Constructor for class org.apache.flink.cep.nfa.NFA.NFASerializer
 
NFASerializerConfigSnapshot() - Constructor for class org.apache.flink.cep.nfa.NFA.NFASerializerConfigSnapshot
This empty constructor is required for deserializing the configuration.
NFASerializerConfigSnapshot(TypeSerializer<T>, TypeSerializer<SharedBuffer<String, T>>) - Constructor for class org.apache.flink.cep.nfa.NFA.NFASerializerConfigSnapshot
 
NFAStateNameHandler - Class in org.apache.flink.cep.nfa.compiler
A utility class used to handle name conventions and guarantee unique names for the states of our NFA.
NFAStateNameHandler() - Constructor for class org.apache.flink.cep.nfa.compiler.NFAStateNameHandler
 
NiFiDataPacket - Interface in org.apache.flink.streaming.connectors.nifi
The NiFiDataPacket provides a packaging around a NiFi FlowFile.
NiFiDataPacketBuilder<T> - Interface in org.apache.flink.streaming.connectors.nifi
A function that can create a NiFiDataPacket from an incoming instance of the given type.
NiFiSink<T> - Class in org.apache.flink.streaming.connectors.nifi
A sink that delivers data to Apache NiFi using the NiFi Site-to-Site client.
NiFiSink(SiteToSiteClientConfig, NiFiDataPacketBuilder<T>) - Constructor for class org.apache.flink.streaming.connectors.nifi.NiFiSink
Construct a new NiFiSink with the given client config and NiFiDataPacketBuilder.
NiFiSource - Class in org.apache.flink.streaming.connectors.nifi
A source that pulls data from Apache NiFi using the NiFi Site-to-Site client.
NiFiSource(SiteToSiteClientConfig) - Constructor for class org.apache.flink.streaming.connectors.nifi.NiFiSource
Constructs a new NiFiSource using the given client config and the default wait time of 1000 ms.
NiFiSource(SiteToSiteClientConfig, long) - Constructor for class org.apache.flink.streaming.connectors.nifi.NiFiSource
Constructs a new NiFiSource using the given client config and wait time.
NO_ALLOCATION_ID - Static variable in class org.apache.flink.runtime.instance.Slot
 
NO_CODE() - Method in class org.apache.flink.table.codegen.GeneratedExpression$
 
NO_CODE() - Static method in class org.apache.flink.table.codegen.GeneratedExpression
 
NO_CURRENT_KEY_GROUP - Static variable in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
 
NO_INDEX - Static variable in class org.apache.flink.api.java.typeutils.TypeExtractor
 
NO_OFFSET_SET - Static variable in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
 
NO_STRINGS - Static variable in class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
 
NO_TIMESTAMPS_WATERMARKS - Static variable in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
 
NO_VALUE_KEY - Static variable in class org.apache.flink.api.java.utils.ParameterTool
 
NO_VALUES - Static variable in class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
 
Node(Vector, Vector, Seq<QuadTree.Node>) - Constructor for class org.apache.flink.ml.nn.QuadTree.Node
 
Node - Class in org.apache.flink.table.explain
 
Node() - Constructor for class org.apache.flink.table.explain.Node
 
nodeChanged() - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
 
nodeChanged() - Method in class org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalService
 
nodeCosts - Variable in class org.apache.flink.optimizer.plan.PlanNode
 
nodeElements() - Method in class org.apache.flink.ml.nn.QuadTree.Node
 
noDefaultValue() - Method in class org.apache.flink.configuration.ConfigOptions.OptionBuilder
Creates a string-valued option with no default value.
NoFetchingInput - Class in org.apache.flink.api.java.typeutils.runtime
 
NoFetchingInput(InputStream) - Constructor for class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
noise - Variable in class org.apache.flink.graph.generator.RMatGraph
 
NoMatchedTableSourceConverterException - Exception in org.apache.flink.table.api
Exception for not finding a TableSourceConverter for a given table type.
NoMatchedTableSourceConverterException(String, Throwable) - Constructor for exception org.apache.flink.table.api.NoMatchedTableSourceConverterException
 
NoMatchedTableSourceConverterException(String) - Constructor for exception org.apache.flink.table.api.NoMatchedTableSourceConverterException
 
NoMatchedTableSourceConverterException$ - Class in org.apache.flink.table.api
 
NoMatchedTableSourceConverterException$() - Constructor for class org.apache.flink.table.api.NoMatchedTableSourceConverterException$
 
noMoreBlocks - Variable in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
NonClosingCheckpointOutputStream<T extends StreamStateHandle> - Class in org.apache.flink.runtime.state
Abstract class to implement custom checkpoint output streams which should not be closable for user code.
NonClosingCheckpointOutputStream(CheckpointStreamFactory.CheckpointStateOutputStream) - Constructor for class org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
 
NonClosingStreamDecorator - Class in org.apache.flink.runtime.util
Decorator for input streams that ignores calls to InputStream.close().
NonClosingStreamDecorator(InputStream) - Constructor for class org.apache.flink.runtime.util.NonClosingStreamDecorator
 
NonDuplicatingTypeSerializer<T> - Class in org.apache.flink.cep
Type serializer which keeps track of the serialized objects so that each object is only serialized once.
NonDuplicatingTypeSerializer(TypeSerializer<T>) - Constructor for class org.apache.flink.cep.NonDuplicatingTypeSerializer
 
none() - Static method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
 
none() - Static method in class org.apache.flink.runtime.jobgraph.tasks.ExternalizedCheckpointSettings
 
NonForwardingIdentityMapper() - Constructor for class org.apache.flink.graph.utils.GraphUtils.NonForwardingIdentityMapper
 
nonParallel - Variable in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Indicate this is a non-parallel operator and cannot set a non-1 degree of parallelism.
NonParallelInput - Interface in org.apache.flink.api.common.io
This interface acts as a marker for input formats for inputs which cannot be split.
NonReusingBlockResettableIterator<T> - Class in org.apache.flink.runtime.operators.resettable
Implementation of an iterator that fetches a block of data into main memory and offers resettable access to the data in that block.
NonReusingBlockResettableIterator(MemoryManager, Iterator<T>, TypeSerializer<T>, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
NonReusingBlockResettableIterator(MemoryManager, TypeSerializer<T>, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
NonReusingBuildFirstHashJoinIterator<V1,V2,O> - Class in org.apache.flink.runtime.operators.hash
An implementation of the JoinTaskIterator that uses a hybrid-hash-join internally to match the records with equal key.
NonReusingBuildFirstHashJoinIterator(MutableObjectIterator<V1>, MutableObjectIterator<V2>, TypeSerializer<V1>, TypeComparator<V1>, TypeSerializer<V2>, TypeComparator<V2>, TypePairComparator<V2, V1>, MemoryManager, IOManager, AbstractInvokable, double, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstHashJoinIterator
 
NonReusingBuildFirstReOpenableHashJoinIterator<V1,V2,O> - Class in org.apache.flink.runtime.operators.hash
 
NonReusingBuildFirstReOpenableHashJoinIterator(MutableObjectIterator<V1>, MutableObjectIterator<V2>, TypeSerializer<V1>, TypeComparator<V1>, TypeSerializer<V2>, TypeComparator<V2>, TypePairComparator<V2, V1>, MemoryManager, IOManager, AbstractInvokable, double, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstReOpenableHashJoinIterator
 
NonReusingBuildSecondHashJoinIterator<V1,V2,O> - Class in org.apache.flink.runtime.operators.hash
An implementation of the JoinTaskIterator that uses a hybrid-hash-join internally to match the records with equal key.
NonReusingBuildSecondHashJoinIterator(MutableObjectIterator<V1>, MutableObjectIterator<V2>, TypeSerializer<V1>, TypeComparator<V1>, TypeSerializer<V2>, TypeComparator<V2>, TypePairComparator<V1, V2>, MemoryManager, IOManager, AbstractInvokable, double, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondHashJoinIterator
 
NonReusingBuildSecondReOpenableHashJoinIterator<V1,V2,O> - Class in org.apache.flink.runtime.operators.hash
 
NonReusingBuildSecondReOpenableHashJoinIterator(MutableObjectIterator<V1>, MutableObjectIterator<V2>, TypeSerializer<V1>, TypeComparator<V1>, TypeSerializer<V2>, TypeComparator<V2>, TypePairComparator<V1, V2>, MemoryManager, IOManager, AbstractInvokable, double, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondReOpenableHashJoinIterator
 
NonReusingDeserializationDelegate<T> - Class in org.apache.flink.runtime.plugable
 
NonReusingDeserializationDelegate(TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.plugable.NonReusingDeserializationDelegate
 
NonReusingKeyGroupedIterator<E> - Class in org.apache.flink.runtime.util
The key grouped iterator returns a key and all values that share the same key.
NonReusingKeyGroupedIterator(MutableObjectIterator<E>, TypeComparator<E>) - Constructor for class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator
Initializes the KeyGroupedIterator.
NonReusingKeyGroupedIterator.ValuesIterator - Class in org.apache.flink.runtime.util
 
NonReusingMergeInnerJoinIterator<T1,T2,O> - Class in org.apache.flink.runtime.operators.sort
 
NonReusingMergeInnerJoinIterator(MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>, MemoryManager, IOManager, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.sort.NonReusingMergeInnerJoinIterator
 
NonReusingMergeOuterJoinIterator<T1,T2,O> - Class in org.apache.flink.runtime.operators.sort
 
NonReusingMergeOuterJoinIterator(OuterJoinOperatorBase.OuterJoinType, MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>, MemoryManager, IOManager, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.sort.NonReusingMergeOuterJoinIterator
 
NonReusingMutableToRegularIteratorWrapper<T> - Class in org.apache.flink.runtime.util
This class wraps a MutableObjectIterator into a regular Iterator.
NonReusingMutableToRegularIteratorWrapper(MutableObjectIterator<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.util.NonReusingMutableToRegularIteratorWrapper
 
NonReusingSortMergeCoGroupIterator<T1,T2> - Class in org.apache.flink.runtime.operators.sort
 
NonReusingSortMergeCoGroupIterator(MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>) - Constructor for class org.apache.flink.runtime.operators.sort.NonReusingSortMergeCoGroupIterator
 
NonRollingBucketer - Class in org.apache.flink.streaming.connectors.fs
Deprecated.
use BasePathBucketer instead.
NonRollingBucketer() - Constructor for class org.apache.flink.streaming.connectors.fs.NonRollingBucketer
Deprecated.
 
NonSerializableUserCodeException - Exception in org.apache.flink.api.common
An special case of the InvalidProgramException, indicating that a part of the program that needs to be serializable (for shipping) is not serializable.
NonSerializableUserCodeException() - Constructor for exception org.apache.flink.api.common.NonSerializableUserCodeException
Creates a new exception with no message.
NonSerializableUserCodeException(String) - Constructor for exception org.apache.flink.api.common.NonSerializableUserCodeException
Creates a new exception with the given message.
NoOpBinaryUdfOp<OUT> - Class in org.apache.flink.optimizer.util
 
NoOpBinaryUdfOp(TypeInformation<OUT>) - Constructor for class org.apache.flink.optimizer.util.NoOpBinaryUdfOp
 
NoOpChainedDriver<IT> - Class in org.apache.flink.runtime.operators
A chained driver that just passes on the input as the output
NoOpChainedDriver() - Constructor for class org.apache.flink.runtime.operators.NoOpChainedDriver
 
NoOpDescriptor - Class in org.apache.flink.optimizer.operators
 
NoOpDescriptor() - Constructor for class org.apache.flink.optimizer.operators.NoOpDescriptor
 
NoOpDriver<T> - Class in org.apache.flink.runtime.operators
A driver that does nothing but forward data from its input to its output.
NoOpDriver() - Constructor for class org.apache.flink.runtime.operators.NoOpDriver
 
NoOpFailureHandler - Class in org.apache.flink.streaming.connectors.elasticsearch.util
An ActionRequestFailureHandler that simply fails the sink on any failures.
NoOpFailureHandler() - Constructor for class org.apache.flink.streaming.connectors.elasticsearch.util.NoOpFailureHandler
 
NoOpFunction - Class in org.apache.flink.api.common.functions.util
 
NoOpFunction() - Constructor for class org.apache.flink.api.common.functions.util.NoOpFunction
 
NoOpNode - Class in org.apache.flink.optimizer.dag
The optimizer's internal representation of a No Operation node.
NoOpNode() - Constructor for class org.apache.flink.optimizer.dag.NoOpNode
 
NoOpNode(String) - Constructor for class org.apache.flink.optimizer.dag.NoOpNode
 
NoOpOperator<IN> - Class in org.apache.flink.api.java.operators
This operator will be ignored during translation.
NoOpOperator(DataSet<IN>, TypeInformation<IN>) - Constructor for class org.apache.flink.api.java.operators.NoOpOperator
 
NoOpUnaryUdfOp<OUT> - Class in org.apache.flink.optimizer.util
 
NoOpUnaryUdfOp() - Constructor for class org.apache.flink.optimizer.util.NoOpUnaryUdfOp
 
NoRegularization - Class in org.apache.flink.ml.optimization
No regularization penalty.
NoRegularization() - Constructor for class org.apache.flink.ml.optimization.NoRegularization
 
NoRegularization$ - Class in org.apache.flink.ml.optimization
No regularization penalty.
NoRegularization$() - Constructor for class org.apache.flink.ml.optimization.NoRegularization$
 
NoResourceAvailableException - Exception in org.apache.flink.runtime.jobmanager.scheduler
 
NoResourceAvailableException() - Constructor for exception org.apache.flink.runtime.jobmanager.scheduler.NoResourceAvailableException
 
NoResourceAvailableException(ScheduledUnit) - Constructor for exception org.apache.flink.runtime.jobmanager.scheduler.NoResourceAvailableException
 
NoResourceAvailableException(int, int, int) - Constructor for exception org.apache.flink.runtime.jobmanager.scheduler.NoResourceAvailableException
 
NoResourceAvailableException(String) - Constructor for exception org.apache.flink.runtime.jobmanager.scheduler.NoResourceAvailableException
 
NoResourceAvailableException(String, Throwable) - Constructor for exception org.apache.flink.runtime.jobmanager.scheduler.NoResourceAvailableException
 
noRestart() - Static method in class org.apache.flink.api.common.restartstrategy.RestartStrategies
Generates NoRestartStrategyConfiguration
NoRestartStrategy - Class in org.apache.flink.runtime.executiongraph.restart
Restart strategy which does not restart an ExecutionGraph.
NoRestartStrategy() - Constructor for class org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy
 
NoRestartStrategy.NoRestartStrategyFactory - Class in org.apache.flink.runtime.executiongraph.restart
 
NoRestartStrategyConfiguration() - Constructor for class org.apache.flink.api.common.restartstrategy.RestartStrategies.NoRestartStrategyConfiguration
 
NoRestartStrategyFactory() - Constructor for class org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy.NoRestartStrategyFactory
 
NormalizableKey<T> - Interface in org.apache.flink.types
The base interface for normalizable keys.
normalizableKeyPrefixLen - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
normalizedKeyLengths - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
NormalizedKeySorter<T> - Class in org.apache.flink.runtime.operators.sort
 
NormalizedKeySorter(TypeSerializer<T>, TypeComparator<T>, List<MemorySegment>) - Constructor for class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
NormalizedKeySorter(TypeSerializer<T>, TypeComparator<T>, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
NOT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
not(RexNode) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
not(Function0<Parsers.Parser<T>>) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
Not - Class in org.apache.flink.table.expressions
 
Not(Expression) - Constructor for class org.apache.flink.table.expressions.Not
 
Not$ - Class in org.apache.flink.table.expressions
 
Not$() - Constructor for class org.apache.flink.table.expressions.Not$
 
NOT_BETWEEN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
NOT_EQUALS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Logical not-equals operator, '<>'.
NOT_IN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
NOT IN operator tests for a value's membership in a sub-query or a list of values.
NOT_LIKE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
NOT_SIMILAR_TO - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
NotCallGenerator - Class in org.apache.flink.table.codegen.calls
Inverts the boolean value of a CallGenerator result.
NotCallGenerator(CallGenerator) - Constructor for class org.apache.flink.table.codegen.calls.NotCallGenerator
 
NotCondition<T> - Class in org.apache.flink.cep.pattern.conditions
A condition which negates the condition it wraps and returns true if the original condition returns false.
NotCondition(IterativeCondition<T>) - Constructor for class org.apache.flink.cep.pattern.conditions.NotCondition
 
notEqualTo() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
notEqualTo() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
NotEqualTo - Class in org.apache.flink.table.expressions
 
NotEqualTo(Expression, Expression) - Constructor for class org.apache.flink.table.expressions.NotEqualTo
 
NotEqualTo$ - Class in org.apache.flink.table.expressions
 
NotEqualTo$() - Constructor for class org.apache.flink.table.expressions.NotEqualTo$
 
notFollowedBy(String) - Method in class org.apache.flink.cep.pattern.Pattern
Appends a new pattern to the existing one.
notFollowedBy(String) - Method in class org.apache.flink.cep.scala.pattern.Pattern
Appends a new pattern to the existing one.
NotFoundException - Exception in org.apache.flink.runtime.webmonitor
A special exception that indicates that an element was not found and that the request should be answered with a 404 return code.
NotFoundException(String) - Constructor for exception org.apache.flink.runtime.webmonitor.NotFoundException
 
Nothing - Class in org.apache.flink.types
A type for (synthetic) operators that do not output data.
NothingDescriptor(int, scala.reflect.macros.Context.universe) - Constructor for class org.apache.flink.api.scala.codegen.TypeDescriptors.NothingDescriptor
 
NothingSerializer - Class in org.apache.flink.api.scala.typeutils
Serializer for cases where no serializer is required but the system still expects one.
NothingSerializer() - Constructor for class org.apache.flink.api.scala.typeutils.NothingSerializer
 
NothingTypeInfo - Class in org.apache.flink.api.common.typeinfo
Placeholder type information for the Nothing type.
NothingTypeInfo() - Constructor for class org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
NotificationListener - Interface in org.apache.flink.runtime.util.event
 
notifyAllocationFailure(JobID, AllocationID, Exception) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ResourceManagerActions
 
notifyBuffersAvailable(long) - Method in interface org.apache.flink.runtime.io.network.partition.BufferAvailabilityListener
Called whenever a new number of buffers becomes available.
notifyBuffersAvailable(long) - Method in class org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel
 
notifyBuffersAvailable(long) - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
 
notifyChannelNonEmpty() - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
Notifies the owning SingleInputGate that this channel became non-empty.
notifyCheckpointComplete(long) - Method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
 
notifyCheckpointComplete(long, long) - Method in class org.apache.flink.runtime.executiongraph.Execution
Notify the task of this execution about a completed checkpoint.
notifyCheckpointComplete(long) - Method in interface org.apache.flink.runtime.jobgraph.tasks.StatefulTask
Invoked when a checkpoint has been completed, i.e., when the checkpoint coordinator has received the notification from all participating tasks.
notifyCheckpointComplete(ExecutionAttemptID, JobID, long, long) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
notifyCheckpointComplete(ExecutionAttemptID, JobID, long, long) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Notify the given task about a completed checkpoint.
notifyCheckpointComplete(ExecutionAttemptID, JobID, long, long) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
NotifyCheckpointComplete - Class in org.apache.flink.runtime.messages.checkpoint
This message is sent from the JobManager to the TaskManager to tell a task that the checkpoint has been confirmed and that the task can commit the checkpoint to the outside world.
NotifyCheckpointComplete(JobID, ExecutionAttemptID, long, long) - Constructor for class org.apache.flink.runtime.messages.checkpoint.NotifyCheckpointComplete
 
notifyCheckpointComplete(long) - Method in interface org.apache.flink.runtime.state.CheckpointListener
This method is called as a notification once a distributed checkpoint has been completed.
notifyCheckpointComplete(long) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
notifyCheckpointComplete(long) - Method in class org.apache.flink.runtime.taskmanager.Task
 
notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
 
notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
 
notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
Deprecated.
 
notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
 
notifyCheckpointComplete(long) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
notifyClients(Object) - Method in class org.apache.flink.runtime.jobmanager.JobInfo
Notifies all clients by sending a message
notifyClients(Object, ListeningBehaviour) - Method in class org.apache.flink.runtime.jobmanager.JobInfo
Sends a message to job clients that match the listening behavior
notifyFatalError(String, Throwable) - Method in class org.apache.flink.runtime.taskmanager.ActorGatewayTaskManagerActions
 
notifyFatalError(String, Throwable) - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerActions
Notifies the task manager about a fatal error occurred in the task.
notifyFinalState(ExecutionAttemptID) - Method in class org.apache.flink.runtime.taskmanager.ActorGatewayTaskManagerActions
 
notifyFinalState(ExecutionAttemptID) - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerActions
Notifies the task manager that the given task is in a final state.
notifyHeartbeatTimeout(ResourceID) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatListener
Callback which is called if a heartbeat for the machine identified by the given resource ID times out.
notifyInfoMessage(InfoMessage) - Method in interface org.apache.flink.runtime.resourcemanager.InfoMessageListenerRpcGateway
Notifies when resource manager need to notify listener about InfoMessage
notifyInputGateNonEmpty(InputGate) - Method in interface org.apache.flink.runtime.io.network.partition.consumer.InputGateListener
Notification callback if the input gate moves from zero to non-zero available input channels with data.
notifyInputGateNonEmpty(InputGate) - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
 
notifyJobTimeout(JobID, UUID) - Method in interface org.apache.flink.runtime.resourcemanager.JobLeaderIdActions
Notify a job timeout.
notifyKvStateRegistered(JobVertexID, KeyGroupRange, String, KvStateID, KvStateServerAddress) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
notifyKvStateRegistered(JobVertexID, KeyGroupRange, String, KvStateID, KvStateServerAddress) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
 
notifyKvStateRegistered(JobVertexID, KeyGroupRange, String, KvStateID, KvStateServerAddress) - Method in class org.apache.flink.runtime.query.KvStateLocationRegistry
Notifies the registry about a registered KvState instance.
NotifyKvStateRegistered(JobID, JobVertexID, KeyGroupRange, String, KvStateID, KvStateServerAddress) - Constructor for class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
Notifies the JobManager about a registered InternalKvState instance.
notifyKvStateRegistered(JobID, JobVertexID, KeyGroupRange, String, KvStateID, KvStateServerAddress) - Method in interface org.apache.flink.runtime.query.KvStateRegistryGateway
Notifies the listener about a registered KvState instance.
notifyKvStateRegistered(JobID, JobVertexID, KeyGroupRange, String, KvStateID) - Method in interface org.apache.flink.runtime.query.KvStateRegistryListener
Notifies the listener about a registered KvState instance.
notifyKvStateRegistered(JobID, JobVertexID, KeyGroupRange, String, KvStateID) - Method in class org.apache.flink.runtime.taskexecutor.rpc.RpcKvStateRegistryListener
 
notifyKvStateRegistered(JobID, JobVertexID, KeyGroupRange, String, KvStateID) - Method in class org.apache.flink.runtime.taskmanager.ActorGatewayKvStateRegistryListener
 
notifyKvStateUnregistered(JobVertexID, KeyGroupRange, String) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
notifyKvStateUnregistered(JobVertexID, KeyGroupRange, String) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
 
notifyKvStateUnregistered(JobVertexID, KeyGroupRange, String) - Method in class org.apache.flink.runtime.query.KvStateLocationRegistry
Notifies the registry about an unregistered KvState instance.
NotifyKvStateUnregistered(JobID, JobVertexID, KeyGroupRange, String) - Constructor for class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateUnregistered
Notifies the JobManager about an unregistered InternalKvState instance.
notifyKvStateUnregistered(JobID, JobVertexID, KeyGroupRange, String) - Method in interface org.apache.flink.runtime.query.KvStateRegistryGateway
Notifies the listener about an unregistered KvState instance.
notifyKvStateUnregistered(JobID, JobVertexID, KeyGroupRange, String) - Method in interface org.apache.flink.runtime.query.KvStateRegistryListener
Notifies the listener about an unregistered KvState instance.
notifyKvStateUnregistered(JobID, JobVertexID, KeyGroupRange, String) - Method in class org.apache.flink.runtime.taskexecutor.rpc.RpcKvStateRegistryListener
 
notifyKvStateUnregistered(JobID, JobVertexID, KeyGroupRange, String) - Method in class org.apache.flink.runtime.taskmanager.ActorGatewayKvStateRegistryListener
 
notifyLeaderAddress(String, UUID) - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
notifyLeaderAddress(String, UUID) - Method in class org.apache.flink.runtime.client.JobClientActor
 
notifyLeaderAddress(String, UUID) - Method in interface org.apache.flink.runtime.leaderretrieval.LeaderRetrievalListener
This method is called by the LeaderRetrievalService when a new leader is elected.
notifyLeaderAddress(String, UUID) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
notifyLeaderAddress(String, UUID) - Method in class org.apache.flink.runtime.minicluster.OneTimeLeaderListenerFuture
 
notifyLeaderAddress(String, UUID) - Method in class org.apache.flink.runtime.net.ConnectionUtils.LeaderConnectingAddressListener
 
notifyLeaderAddress(String, UUID) - Method in class org.apache.flink.runtime.taskmanager.TaskManager
 
notifyLeaderAddress(String, UUID) - Method in class org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderConnectionInfoListener
 
notifyLeaderAddress(String, UUID) - Method in class org.apache.flink.runtime.util.LeaderRetrievalUtils.LeaderGatewayListener
 
notifyLeaderAddress(String, UUID) - Method in class org.apache.flink.runtime.webmonitor.JobManagerRetriever
 
notifyLeaderAddress(String, UUID) - Method in class org.apache.flink.yarn.ApplicationClient
 
notifyLeaderAddress(String, UUID) - Static method in class org.apache.flink.yarn.YarnTaskManager
 
notifyNewVertices(List<ExecutionJobVertex>) - Method in class org.apache.flink.runtime.executiongraph.failover.FailoverStrategy
Called whenever new vertices are added to the ExecutionGraph.
notifyNewVertices(List<ExecutionJobVertex>) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartAllStrategy
 
notifyNewVertices(List<ExecutionJobVertex>) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy
 
notifyNewVertices(List<ExecutionJobVertex>) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy
 
notifyNonDetachedClients(Object) - Method in class org.apache.flink.runtime.jobmanager.JobInfo
Notifies all clients which are not of type detached
notifyOfAddedMetric(Metric, String, MetricGroup) - Method in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
 
notifyOfAddedMetric(Metric, String, MetricGroup) - Method in class org.apache.flink.metrics.datadog.DatadogHttpReporter
 
notifyOfAddedMetric(Metric, String, MetricGroup) - Method in class org.apache.flink.metrics.jmx.JMXReporter
 
notifyOfAddedMetric(Metric, String, MetricGroup) - Method in class org.apache.flink.metrics.reporter.AbstractReporter
 
notifyOfAddedMetric(Metric, String, MetricGroup) - Method in interface org.apache.flink.metrics.reporter.MetricReporter
Called when a new Metric was added.
notifyOfAddedMetric(ActorRef, Metric, String, AbstractMetricGroup) - Static method in class org.apache.flink.runtime.metrics.dump.MetricQueryService
Utility method to notify a MetricQueryService of an added metric.
notifyOfAddedView(View) - Method in class org.apache.flink.runtime.metrics.ViewUpdater
Notifies this ViewUpdater of a new metric that should be regularly updated.
notifyOfCompletedCheckpoint(long) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
notifyOfCompletedCheckpoint(long) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
notifyOfCompletedCheckpoint(long) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
Called when the checkpoint with the given ID is completed and acknowledged on the JobManager.
notifyOfCompletedCheckpoint(long) - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
 
notifyOfEndOfSuperstep() - Method in class org.apache.flink.runtime.iterative.concurrent.BlockingBackChannel
Called by iteration tail to signal that all input of a superstep has been processed (unblocks iteration head).
notifyOfRemovedMetric(Metric, String, MetricGroup) - Method in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
 
notifyOfRemovedMetric(Metric, String, MetricGroup) - Method in class org.apache.flink.metrics.datadog.DatadogHttpReporter
 
notifyOfRemovedMetric(Metric, String, MetricGroup) - Method in class org.apache.flink.metrics.jmx.JMXReporter
 
notifyOfRemovedMetric(Metric, String, MetricGroup) - Method in class org.apache.flink.metrics.reporter.AbstractReporter
 
notifyOfRemovedMetric(Metric, String, MetricGroup) - Method in interface org.apache.flink.metrics.reporter.MetricReporter
Called when a Metric was should be removed.
notifyOfRemovedMetric(ActorRef, Metric) - Static method in class org.apache.flink.runtime.metrics.dump.MetricQueryService
Utility method to notify a MetricQueryService of a removed metric.
notifyOfRemovedView(View) - Method in class org.apache.flink.runtime.metrics.ViewUpdater
Notifies this ViewUpdater of a metric that should no longer be regularly updated.
notifyPartitionConsumable(JobID, ResultPartitionID, TaskActions) - Method in interface org.apache.flink.runtime.io.network.partition.ResultPartitionConsumableNotifier
 
notifyPartitionConsumable(JobID, ResultPartitionID, TaskActions) - Method in class org.apache.flink.runtime.taskexecutor.rpc.RpcResultPartitionConsumableNotifier
 
notifyPartitionConsumable(JobID, ResultPartitionID, TaskActions) - Method in class org.apache.flink.runtime.taskmanager.ActorGatewayResultPartitionConsumableNotifier
 
NotifyResourceStarted - Class in org.apache.flink.runtime.clusterframework.messages
Notifies the ResourceManager that a TaskManager has been started in a container with the given resource id.
NotifyResourceStarted(ResourceID) - Constructor for class org.apache.flink.runtime.clusterframework.messages.NotifyResourceStarted
 
notifySlotAvailable(UUID, InstanceID, SlotID, AllocationID) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
Notification from a TaskExecutor that a slot has become available
notifySlotAvailable(UUID, InstanceID, SlotID, AllocationID) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Sent by the TaskExecutor to notify the ResourceManager that a slot has become available.
notifySolutionSetUpdate() - Method in class org.apache.flink.runtime.iterative.concurrent.SolutionSetUpdateBarrier
Releases the waiting thread.
notifySubpartitionConsumed() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
 
notifyTaskExecutionStateChanged(TaskExecutionState) - Method in class org.apache.flink.runtime.taskmanager.ActorGatewayTaskExecutionStateListener
 
notifyTaskExecutionStateChanged(TaskExecutionState) - Method in interface org.apache.flink.runtime.taskmanager.TaskExecutionStateListener
Called whenever the task's execution state changes
notifyTimeout(AllocationID, UUID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
 
notifyTimeout(K, UUID) - Method in interface org.apache.flink.runtime.taskexecutor.slot.TimeoutListener
Notify the listener about the timeout for an event identified by key.
NotifyWhenRegisteredAtJobManager$() - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages.NotifyWhenRegisteredAtJobManager$
 
notifyWorkerFailed(ResourceID, String) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
This method should be called by the framework once it detects that a currently registered worker has failed.
notLeader() - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
 
notNext(String) - Method in class org.apache.flink.cep.pattern.Pattern
Appends a new pattern to the existing one.
notNext(String) - Method in class org.apache.flink.cep.scala.pattern.Pattern
Appends a new pattern to the existing one.
NTILE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
NTILE aggregate function.
NULL() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
NULL() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
Null - Class in org.apache.flink.table.expressions
 
Null(TypeInformation<?>) - Constructor for class org.apache.flink.table.expressions.Null
 
Null$ - Class in org.apache.flink.table.expressions
 
Null$() - Constructor for class org.apache.flink.table.expressions.Null$
 
NULL_VALUE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
 
NULL_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
nullable() - Method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
nullable() - Method in class org.apache.flink.table.plan.schema.GenericRelDataType
 
NullAwareComparator<T> - Class in org.apache.flink.api.java.typeutils.runtime
Null-aware comparator that wraps a comparator which does not support null references.
NullAwareComparator(TypeComparator<T>, boolean) - Constructor for class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
NullByteKeySelector<T> - Class in org.apache.flink.api.java.functions
Used as a dummy KeySelector to allow using keyed operators for non-keyed usecases.
NullByteKeySelector() - Constructor for class org.apache.flink.api.java.functions.NullByteKeySelector
 
nullCheck() - Method in class org.apache.flink.table.codegen.CodeGenerator
 
nullCount() - Method in class org.apache.flink.table.plan.stats.ColumnStats
 
NullFieldException - Exception in org.apache.flink.types
An exception specifying that a required field was not set in a record, i.e.
NullFieldException() - Constructor for exception org.apache.flink.types.NullFieldException
Constructs an NullFieldException with null as its error detail message.
NullFieldException(String) - Constructor for exception org.apache.flink.types.NullFieldException
Constructs an NullFieldException with the specified detail message.
NullFieldException(int) - Constructor for exception org.apache.flink.types.NullFieldException
Constructs an NullFieldException with a default message, referring to given field number as the null field.
NullFieldException(int, Throwable) - Constructor for exception org.apache.flink.types.NullFieldException
Constructs an NullFieldException with a default message, referring to given field number as the null field and a cause (Throwable)
NULLIF - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
NullKeyFieldException - Exception in org.apache.flink.types
An exception specifying that a required key field was not set in a record, i.e.
NullKeyFieldException() - Constructor for exception org.apache.flink.types.NullKeyFieldException
Constructs an NullKeyFieldException with null as its error detail message.
NullKeyFieldException(NullFieldException) - Constructor for exception org.apache.flink.types.NullKeyFieldException
Constructs an NullKeyFieldException with a default message, referring to the field number given in the NullFieldException.
NullKeyFieldException(String) - Constructor for exception org.apache.flink.types.NullKeyFieldException
Constructs an NullKeyFieldException with the specified detail message.
NullKeyFieldException(int) - Constructor for exception org.apache.flink.types.NullKeyFieldException
Constructs an NullKeyFieldException with a default message, referring to given field number as the null key field.
nullLiteral() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
nullLiteral() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
NullMaskUtils - Class in org.apache.flink.api.java.typeutils.runtime
 
NullMaskUtils() - Constructor for class org.apache.flink.api.java.typeutils.runtime.NullMaskUtils
 
NULLS_FIRST - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
NULLS_LAST - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
NullSerializer() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.NullSerializer
 
nullsFirst(RexNode) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
nullsLast(RexNode) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
nullTerm() - Method in class org.apache.flink.table.codegen.GeneratedExpression
 
NullTerminatingSpout - Class in org.apache.flink.storm.util
NullTerminatingSpout in a finite spout (ie, implements FiniteSpout interface) that wraps an infinite spout, and returns true in NullTerminatingSpout.reachedEnd() when the wrapped spout does not emit a tuple in nextTuple() for the first time.
NullTerminatingSpout(IRichSpout) - Constructor for class org.apache.flink.storm.util.NullTerminatingSpout
 
nullValue() - Static method in class org.apache.flink.runtime.state.DoneFuture
 
NullValue - Class in org.apache.flink.types
Null base type for programs that implements the Key interface.
NullValue() - Constructor for class org.apache.flink.types.NullValue
Creates a NullValue object.
NullValueArray - Class in org.apache.flink.graph.types.valuearray
An array of NullValue.
NullValueArray() - Constructor for class org.apache.flink.graph.types.valuearray.NullValueArray
Initializes an expandable array with default capacity.
NullValueArray(int) - Constructor for class org.apache.flink.graph.types.valuearray.NullValueArray
Initializes a fixed-size array with the provided number of bytes.
NullValueArrayComparator - Class in org.apache.flink.graph.types.valuearray
Specialized comparator for NullValueArray based on CopyableValueComparator.
NullValueArrayComparator(boolean) - Constructor for class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
 
NullValueArraySerializer - Class in org.apache.flink.graph.types.valuearray
Specialized serializer for NullValueArray.
NullValueArraySerializer() - Constructor for class org.apache.flink.graph.types.valuearray.NullValueArraySerializer
 
NullValueComparator - Class in org.apache.flink.api.common.typeutils.base
Specialized comparator for NullValue based on CopyableValueComparator.
NullValueSerializer - Class in org.apache.flink.api.common.typeutils.base
 
NullValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
NUM_ARENAS - Static variable in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
NUM_RECORDS_UNKNOWN - Static variable in interface org.apache.flink.api.common.io.statistics.BaseStatistics
Constant indicating that the number of records is unknown;
NUM_THREADS_CLIENT - Static variable in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
NUM_THREADS_SERVER - Static variable in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
NUM_VERTICES - Static variable in class org.apache.flink.graph.examples.data.EuclideanGraphData
 
NUM_VERTICES - Static variable in class org.apache.flink.graph.examples.data.IncrementalSSSPData
 
NUM_VERTICES - Static variable in class org.apache.flink.test.testdata.PageRankData
 
number() - Method in class org.apache.flink.runtime.messages.TaskManagerMessages.ResponseBroadcastVariablesWithReferences
 
number() - Method in class org.apache.flink.runtime.messages.TaskManagerMessages.ResponseNumActiveConnections
 
NUMBER_OF_SUCCESSFUL_CHECKPOINTS_TO_RETAIN - Static variable in interface org.apache.flink.runtime.checkpoint.CheckpointRecoveryFactory
The number of CompletedCheckpoint instances to retain.
numberLiteral() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
numberLiteral() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
numberOfEdges() - Method in class org.apache.flink.graph.Graph
 
numberOfEdges() - Method in class org.apache.flink.graph.scala.Graph
 
NumberOfFullRestartsGauge - Class in org.apache.flink.runtime.executiongraph.metrics
Gauge which returns the number of full restarts.
NumberOfFullRestartsGauge(ExecutionGraph) - Constructor for class org.apache.flink.runtime.executiongraph.metrics.NumberOfFullRestartsGauge
 
numberOfKeyGroups - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
The number of key-groups aka max parallelism
numberOfSlots() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
numberOfSlots() - Method in class org.apache.flink.runtime.messages.RegistrationMessages.RegisterTaskManager
 
numberOfSlots() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
 
numberOfSlots() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
numberOfVertices() - Method in class org.apache.flink.graph.Graph
 
numberOfVertices() - Method in class org.apache.flink.graph.scala.Graph
 
numberOfWorkers() - Method in class org.apache.flink.runtime.clusterframework.messages.SetWorkerPoolSize
 
NumberSequenceIterator - Class in org.apache.flink.util
The NumberSequenceIterator is an iterator that returns a sequence of numbers (as Long)s.
NumberSequenceIterator(long, long) - Constructor for class org.apache.flink.util.NumberSequenceIterator
Creates a new splittable iterator, returning the range [from, to].
numBuckets - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
The number of buckets in the current table.
numBytesIn - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
 
numBytesInLocal - Variable in class org.apache.flink.runtime.executiongraph.IOMetrics
 
numBytesInLocalPerSecond - Variable in class org.apache.flink.runtime.executiongraph.IOMetrics
 
numBytesInRemote - Variable in class org.apache.flink.runtime.executiongraph.IOMetrics
 
numBytesInRemotePerSecond - Variable in class org.apache.flink.runtime.executiongraph.IOMetrics
 
numBytesOut - Variable in class org.apache.flink.runtime.executiongraph.IOMetrics
 
numBytesOutPerSecond - Variable in class org.apache.flink.runtime.executiongraph.IOMetrics
 
numCols() - Method in class org.apache.flink.ml.math.DenseMatrix
 
numCols() - Method in interface org.apache.flink.ml.math.distributed.DistributedMatrix
Returns number of columns in matrix.
numCols() - Method in class org.apache.flink.ml.math.distributed.DistributedRowMatrix
 
numCols() - Method in interface org.apache.flink.ml.math.Matrix
Number of columns
numCols() - Method in class org.apache.flink.ml.math.SparseMatrix
 
numCounters - Variable in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
 
NumericBetweenParametersProvider - Class in org.apache.flink.api.java.io.jdbc.split
This query parameters generator is an helper class to parameterize from/to queries on a numeric column.
NumericBetweenParametersProvider(long, long, long) - Constructor for class org.apache.flink.api.java.io.jdbc.split.NumericBetweenParametersProvider
NumericBetweenParametersProvider constructor.
NumericColumnSummary<T> - Class in org.apache.flink.api.java.summarize
Generic Column Summary for Numeric Types.
NumericColumnSummary(long, long, long, long, T, T, T, Double, Double, Double) - Constructor for class org.apache.flink.api.java.summarize.NumericColumnSummary
 
NumericSummaryAggregator<T extends Number> - Class in org.apache.flink.api.java.summarize.aggregation
Generic aggregator for all numeric types creates a summary of a column of numbers.
NumericSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
 
NumericTypeInfo<T> - Class in org.apache.flink.api.common.typeinfo
Type information for numeric primitive types: int, long, double, byte, short, float, char.
NumericTypeInfo(Class<T>, Class<?>[], TypeSerializer<T>, Class<? extends TypeComparator<T>>) - Constructor for class org.apache.flink.api.common.typeinfo.NumericTypeInfo
 
numericWideningPrecedence() - Method in class org.apache.flink.table.typeutils.TypeCoercion$
 
numericWideningPrecedence() - Static method in class org.apache.flink.table.typeutils.TypeCoercion
 
numEventTimeTimers() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
numEventTimeTimers() - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
 
numEventTimeTimers(N) - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
 
NumFactors$() - Constructor for class org.apache.flink.ml.recommendation.ALS.NumFactors$
 
numGauges - Variable in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
 
numHashFunctions - Variable in class org.apache.flink.runtime.operators.util.BloomFilter
 
numHistograms - Variable in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
 
numJobManagers() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
numLeadingNormalizableKeys - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
numMeters - Variable in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
 
numOfCars() - Method in class org.apache.flink.streaming.scala.examples.windowing.TopSpeedWindowing$
 
numOfCars() - Static method in class org.apache.flink.streaming.scala.examples.windowing.TopSpeedWindowing
 
numOverflowSegments - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
 
numOverflowSegments - Variable in class org.apache.flink.runtime.operators.hash.InMemoryPartition
 
numPendingRecords() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
 
numProcessingTimeTimers() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
numProcessingTimeTimers() - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
 
numProcessingTimeTimers(N) - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
 
numQueryThreads() - Method in class org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
Returns the number of threads for the thread pool that performs the actual state lookup.
numQueuedRunnables() - Method in class org.apache.flink.core.testutils.ManuallyTriggeredDirectExecutor
Gets the number of Runnables currently queued.
numRecordsIn - Variable in class org.apache.flink.runtime.executiongraph.IOMetrics
 
numRecordsIn - Variable in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
numRecordsInPerSecond - Variable in class org.apache.flink.runtime.executiongraph.IOMetrics
 
numRecordsOut - Variable in class org.apache.flink.runtime.executiongraph.IOMetrics
 
numRecordsOut - Variable in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
numRecordsOutPerSecond - Variable in class org.apache.flink.runtime.executiongraph.IOMetrics
 
numRegisteredJobMetricGroups() - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
 
numRegisteredJobMetricGroups() - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
 
numRegisteredTaskManagers() - Method in class org.apache.flink.runtime.clusterframework.messages.GetClusterStatusResponse
 
numRemainingSamples() - Method in class org.apache.flink.runtime.messages.StackTraceSampleMessages.SampleTaskStackTrace
 
numRequestsRemaining - Variable in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
 
numRows() - Method in class org.apache.flink.ml.math.DenseMatrix
 
numRows() - Method in interface org.apache.flink.ml.math.distributed.DistributedMatrix
Returns number of rows in matrix.
numRows() - Method in class org.apache.flink.ml.math.distributed.DistributedRowMatrix
 
numRows() - Method in interface org.apache.flink.ml.math.Matrix
Number of rows
numRows() - Method in class org.apache.flink.ml.math.SparseMatrix
 
numSamples - Variable in class org.apache.flink.api.java.sampling.DistributedRandomSampler
 
numSamples() - Method in class org.apache.flink.runtime.messages.StackTraceSampleMessages.TriggerStackTraceSample
 
numServerThreads() - Method in class org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
Returns the number of threads for the query server NIO event loop.
numSlots() - Method in class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
 
numSlots() - Method in class org.apache.flink.yarn.YarnMessages.ApplicationMasterStatus
 
numSplits - Variable in class org.apache.flink.api.common.io.FileInputFormat
The desired number of splits, as set by the configure() method.
numStateEntries() - Method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
 
numStateEntries() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
Returns the total number of state entries across all keys/namespaces.
numStateEntries() - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
Returns the total number of state entries across all keys/namespaces.
numStateEntries(Object) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
Returns the total number of state entries across all keys for the given namespace.
numTargetKeyGroups - Variable in class org.apache.flink.runtime.io.network.partition.ResultPartition
 
numTaskManagers() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
numTaskManagers - Variable in class org.apache.flink.test.util.AbstractTestBase
 
numTaskManagers() - Method in class org.apache.flink.yarn.YarnMessages.ApplicationMasterStatus
 
numWriteBuffersToCluster - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 

O

OBJECT_ARRAY(TypeInformation<?>) - Method in class org.apache.flink.table.api.Types$
Generates type information for an array consisting of Java object elements.
OBJECT_ARRAY(TypeInformation<?>) - Static method in class org.apache.flink.table.api.Types
Generates type information for an array consisting of Java object elements.
OBJECT_ARRAY() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
OBJECT_ARRAY() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
ObjectArrayTypeInfo<T,C> - Class in org.apache.flink.api.java.typeutils
 
ObjectColumnSummary - Class in org.apache.flink.api.java.summarize
Summary for a column of generic Objects (this is a fallback for unsupported types).
ObjectColumnSummary(long, long) - Constructor for class org.apache.flink.api.java.summarize.ObjectColumnSummary
 
ObjectExplodeTableFunc - Class in org.apache.flink.table.plan.util
 
ObjectExplodeTableFunc() - Constructor for class org.apache.flink.table.plan.util.ObjectExplodeTableFunc
 
ObjectFieldAccessor(Field) - Constructor for class org.apache.flink.table.codegen.CodeGenUtils.ObjectFieldAccessor
 
ObjectFieldAccessor$() - Constructor for class org.apache.flink.table.codegen.CodeGenUtils.ObjectFieldAccessor$
 
ObjectGenericFieldAccessor(String) - Constructor for class org.apache.flink.table.codegen.CodeGenUtils.ObjectGenericFieldAccessor
 
ObjectGenericFieldAccessor$() - Constructor for class org.apache.flink.table.codegen.CodeGenUtils.ObjectGenericFieldAccessor$
 
ObjectMethodAccessor(String) - Constructor for class org.apache.flink.table.codegen.CodeGenUtils.ObjectMethodAccessor
 
ObjectMethodAccessor$() - Constructor for class org.apache.flink.table.codegen.CodeGenUtils.ObjectMethodAccessor$
 
ObjectPrivateFieldAccessor(Field) - Constructor for class org.apache.flink.table.codegen.CodeGenUtils.ObjectPrivateFieldAccessor
 
ObjectPrivateFieldAccessor$() - Constructor for class org.apache.flink.table.codegen.CodeGenUtils.ObjectPrivateFieldAccessor$
 
objectReuseEnabled - Variable in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
objectReuseEnabled - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
Whether to reuse objects during deserialization.
ObjectSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
 
ObjectSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ObjectSummaryAggregator
 
obtainLeft(Either<L, R>, TypeSerializer<L>) - Static method in class org.apache.flink.types.Either
Utility function for EitherSerializer to support object reuse.
obtainRight(Either<L, R>, TypeSerializer<R>) - Static method in class org.apache.flink.types.Either
Utility function for EitherSerializer to support object reuse.
ODD_STREAM - Static variable in class org.apache.flink.storm.split.operators.RandomSpout
 
of(long, TimeUnit) - Static method in class org.apache.flink.api.common.time.Time
Creates a new Time of the given duration and TimeUnit.
of(Class<T>) - Static method in class org.apache.flink.api.common.typeinfo.TypeInformation
Creates a TypeInformation for the type described by the given class.
of(TypeHint<T>) - Static method in class org.apache.flink.api.common.typeinfo.TypeInformation
Creates a TypeInformation for a generic type via a utility "type hint".
of(T0) - Static method in class org.apache.flink.api.java.tuple.Tuple1
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9) - Static method in class org.apache.flink.api.java.tuple.Tuple10
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Static method in class org.apache.flink.api.java.tuple.Tuple11
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Static method in class org.apache.flink.api.java.tuple.Tuple12
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Static method in class org.apache.flink.api.java.tuple.Tuple13
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - Static method in class org.apache.flink.api.java.tuple.Tuple14
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - Static method in class org.apache.flink.api.java.tuple.Tuple15
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15) - Static method in class org.apache.flink.api.java.tuple.Tuple16
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16) - Static method in class org.apache.flink.api.java.tuple.Tuple17
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17) - Static method in class org.apache.flink.api.java.tuple.Tuple18
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18) - Static method in class org.apache.flink.api.java.tuple.Tuple19
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1) - Static method in class org.apache.flink.api.java.tuple.Tuple2
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19) - Static method in class org.apache.flink.api.java.tuple.Tuple20
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20) - Static method in class org.apache.flink.api.java.tuple.Tuple21
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21) - Static method in class org.apache.flink.api.java.tuple.Tuple22
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22) - Static method in class org.apache.flink.api.java.tuple.Tuple23
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22, T23) - Static method in class org.apache.flink.api.java.tuple.Tuple24
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22, T23, T24) - Static method in class org.apache.flink.api.java.tuple.Tuple25
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2) - Static method in class org.apache.flink.api.java.tuple.Tuple3
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3) - Static method in class org.apache.flink.api.java.tuple.Tuple4
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4) - Static method in class org.apache.flink.api.java.tuple.Tuple5
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5) - Static method in class org.apache.flink.api.java.tuple.Tuple6
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6) - Static method in class org.apache.flink.api.java.tuple.Tuple7
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7) - Static method in class org.apache.flink.api.java.tuple.Tuple8
Creates a new tuple and assigns the given values to the tuple's fields.
of(T0, T1, T2, T3, T4, T5, T6, T7, T8) - Static method in class org.apache.flink.api.java.tuple.Tuple9
Creates a new tuple and assigns the given values to the tuple's fields.
of(int, int) - Static method in class org.apache.flink.runtime.state.KeyGroupRange
Factory method that also handles creation of empty key-groups.
of(Time, Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.SlidingAlignedProcessingTimeWindows
Creates a new SlidingAlignedProcessingTimeWindows WindowAssigner that assigns elements to sliding time windows based on the element timestamp.
of(Time, Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
Creates a new SlidingEventTimeWindows WindowAssigner that assigns elements to sliding time windows based on the element timestamp.
of(Time, Time, Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
Creates a new SlidingEventTimeWindows WindowAssigner that assigns elements to time windows based on the element timestamp and offset.
of(Time, Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
Creates a new SlidingProcessingTimeWindows WindowAssigner that assigns elements to sliding time windows based on the element timestamp.
of(Time, Time, Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
Creates a new SlidingProcessingTimeWindows WindowAssigner that assigns elements to time windows based on the element timestamp and offset.
of(Time, Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.SlidingTimeWindows
of(Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.TumblingAlignedProcessingTimeWindows
Creates a new TumblingAlignedProcessingTimeWindows WindowAssigner that assigns elements to time windows based on the element timestamp.
of(Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
Creates a new TumblingEventTimeWindows WindowAssigner that assigns elements to time windows based on the element timestamp.
of(Time, Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
Creates a new TumblingEventTimeWindows WindowAssigner that assigns elements to time windows based on the element timestamp and offset.
of(Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
Creates a new TumblingProcessingTimeWindows WindowAssigner that assigns elements to time windows based on the element timestamp.
of(Time, Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
Creates a new TumblingProcessingTimeWindows WindowAssigner that assigns elements to time windows based on the element timestamp and offset.
of(Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.TumblingTimeWindows
Deprecated.
of(long) - Static method in class org.apache.flink.streaming.api.windowing.evictors.CountEvictor
Creates a CountEvictor that keeps the given number of elements.
of(long, boolean) - Static method in class org.apache.flink.streaming.api.windowing.evictors.CountEvictor
Creates a CountEvictor that keeps the given number of elements in the pane Eviction is done before/after the window function based on the value of doEvictAfter.
of(double, DeltaFunction<T>) - Static method in class org.apache.flink.streaming.api.windowing.evictors.DeltaEvictor
Creates a DeltaEvictor from the given threshold and DeltaFunction.
of(double, DeltaFunction<T>, boolean) - Static method in class org.apache.flink.streaming.api.windowing.evictors.DeltaEvictor
Creates a DeltaEvictor from the given threshold, DeltaFunction.
of(Time) - Static method in class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
Creates a TimeEvictor that keeps the given number of elements.
of(Time, boolean) - Static method in class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
Creates a TimeEvictor that keeps the given number of elements.
of(long, TimeUnit) - Static method in class org.apache.flink.streaming.api.windowing.time.Time
Creates a new Time of the given duration and TimeUnit.
of(Time) - Static method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
Creates a trigger that continuously fires based on the given interval.
of(Time) - Static method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
Creates a trigger that continuously fires based on the given interval.
of(long) - Static method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
Creates a trigger that fires once the number of elements in a pane reaches the given count.
of(double, DeltaFunction<T>, TypeSerializer<T>) - Static method in class org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
Creates a delta trigger from the given threshold and DeltaFunction.
of(Trigger<T, W>) - Static method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
Creates a new purging trigger from the given Trigger.
of(TableStats) - Method in class org.apache.flink.table.plan.stats.FlinkStatistic$
Returns a FlinkStatistic with given table statistics.
of(TableStats) - Static method in class org.apache.flink.table.plan.stats.FlinkStatistic
Returns a FlinkStatistic with given table statistics.
of(StreamQueryConfig, long) - Method in class org.apache.flink.table.runtime.triggers.StateCleaningCountTrigger$
Create a StateCleaningCountTrigger instance.
of(StreamQueryConfig, long) - Static method in class org.apache.flink.table.runtime.triggers.StateCleaningCountTrigger
Create a StateCleaningCountTrigger instance.
of(L) - Static method in class org.apache.flink.types.Either.Left
Creates a left value of Either
of(R) - Static method in class org.apache.flink.types.Either.Right
Creates a right value of Either
of(Object...) - Static method in class org.apache.flink.types.Row
Creates a new Row and assigns the given values to the Row's fields.
offer(E) - Method in class org.apache.flink.runtime.jobmanager.scheduler.LifoSetQueue
 
offer(E) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
offer(T) - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
Adds element to the PriorityQueue in log(size) time if either the PriorityQueue is not full, or not lessThan(element, top()).
offerId() - Method in class org.apache.flink.mesos.scheduler.messages.OfferRescinded
 
offerIds() - Method in class org.apache.flink.mesos.scheduler.messages.AcceptOffers
 
OfferRescinded - Class in org.apache.flink.mesos.scheduler.messages
Message sent by the callback handler to the scheduler actor when an offer is no longer valid (e.g., the slave was lost or another framework used resources in the offer).
OfferRescinded(Protos.OfferID) - Constructor for class org.apache.flink.mesos.scheduler.messages.OfferRescinded
 
offerRescinded(SchedulerDriver, Protos.OfferID) - Method in class org.apache.flink.mesos.scheduler.SchedulerProxy
 
offers() - Method in class org.apache.flink.mesos.scheduler.messages.ResourceOffers
 
offerSlot(AllocatedSlot) - Method in class org.apache.flink.runtime.instance.SlotPool
Slot offering by TaskManager with AllocationID.
offerSlot(AllocatedSlot) - Method in interface org.apache.flink.runtime.instance.SlotPoolGateway
 
offerSlots(Iterable<Tuple2<AllocatedSlot, SlotOffer>>) - Method in class org.apache.flink.runtime.instance.SlotPool
 
offerSlots(Iterable<Tuple2<AllocatedSlot, SlotOffer>>) - Method in interface org.apache.flink.runtime.instance.SlotPoolGateway
 
offerSlots(ResourceID, Iterable<SlotOffer>, UUID) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
offerSlots(ResourceID, Iterable<SlotOffer>, UUID, Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
Offer the given slots to the job manager.
offset() - Method in class org.apache.flink.table.plan.logical.Limit
 
OFFSET_NOT_SET - Static variable in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionStateSentinel
Magic number that defines an unset offset.
OffsetCommitMode - Enum in org.apache.flink.streaming.connectors.kafka.config
The offset commit mode represents the behaviour of how offsets are externally committed back to Kafka brokers / Zookeeper.
OffsetCommitModes - Class in org.apache.flink.streaming.connectors.kafka.config
Utilities for OffsetCommitMode.
OffsetCommitModes() - Constructor for class org.apache.flink.streaming.connectors.kafka.config.OffsetCommitModes
 
OffsetRange(long, long) - Constructor for class org.apache.flink.graph.generator.CirculantGraph.OffsetRange
Construct a range with the given offset and length.
on(Expression) - Method in class org.apache.flink.table.api.SessionWithGap
Specifies the time attribute on which rows are grouped.
on(String) - Method in class org.apache.flink.table.api.SessionWithGap
Specifies the time attribute on which rows are grouped.
on(Expression) - Method in class org.apache.flink.table.api.SlideWithSizeAndSlide
Specifies the time attribute on which rows are grouped.
on(String) - Method in class org.apache.flink.table.api.SlideWithSizeAndSlide
Specifies the time attribute on which rows are grouped.
on(Expression) - Method in class org.apache.flink.table.api.TumbleWithSize
Specifies the time attribute on which rows are grouped.
on(String) - Method in class org.apache.flink.table.api.TumbleWithSize
Specifies the time attribute on which rows are grouped.
onAddedJobGraph(JobID) - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
onAddedJobGraph(JobID) - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore.SubmittedJobGraphListener
Callback for SubmittedJobGraph instances added by a different SubmittedJobGraphStore instance.
onBuffer(Buffer, int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
OnceParser(Function1<Reader<Object>, Parsers.ParseResult<T>>) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
OnCoGroupDataSet<L,R> - Class in org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions
Wraps a co-group data set, allowing to use anonymous partial functions to perform extraction of items in a tuple, case class instance or collection
OnCoGroupDataSet(CoGroupDataSet<L, R>) - Constructor for class org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions.OnCoGroupDataSet
 
onComplete(AcceptFunction<StreamElementQueueEntry<T>>, Executor) - Method in class org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
Register the given complete function to be called once this queue entry has been completed.
onCompleteHandler(StreamElementQueueEntry<?>) - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
Callback for onComplete events for the given stream element queue entry.
OnCompletionActions - Interface in org.apache.flink.runtime.jobmanager
 
OnConnectedStream<IN1,IN2> - Class in org.apache.flink.streaming.api.scala.extensions.impl.acceptPartialFunctions
Wraps a connected data stream, allowing to use anonymous partial functions to perform extraction of items in a tuple, case class instance or collection
OnConnectedStream(ConnectedStreams<IN1, IN2>) - Constructor for class org.apache.flink.streaming.api.scala.extensions.impl.acceptPartialFunctions.OnConnectedStream
 
onConsumedSubpartition() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
Notifies the parent partition about a consumed ResultSubpartitionView.
onContainersAllocated(List<Container>) - Method in class org.apache.flink.yarn.YarnResourceManager
 
onContainersAllocated(List<Container>) - Method in class org.apache.flink.yarn.YarnResourceManagerCallbackHandler
 
onContainersCompleted(List<ContainerStatus>) - Method in class org.apache.flink.yarn.YarnResourceManager
 
onContainersCompleted(List<ContainerStatus>) - Method in class org.apache.flink.yarn.YarnResourceManagerCallbackHandler
 
OnCrossDataSet<L,R> - Class in org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions
Wraps a cross data set, allowing to use anonymous partial functions to perform extraction of items in a tuple, case class instance or collection
OnCrossDataSet(CrossDataSet<L, R>) - Constructor for class org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions.OnCrossDataSet
 
OnDataSet<T> - Class in org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions
Wraps a data set, allowing to use anonymous partial functions to perform extraction of items in a tuple, case class instance or collection
OnDataSet(DataSet<T>) - Constructor for class org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions.OnDataSet
 
OnDataStream<T> - Class in org.apache.flink.streaming.api.scala.extensions.impl.acceptPartialFunctions
Wraps a data stream, allowing to use anonymous partial functions to perform extraction of items in a tuple, case class instance or collection
OnDataStream(DataStream<T>) - Constructor for class org.apache.flink.streaming.api.scala.extensions.impl.acceptPartialFunctions.OnDataStream
 
onDynamicPath - Variable in class org.apache.flink.optimizer.dag.OptimizerNode
 
ONE(Quantifier.ConsumingStrategy) - Static method in class org.apache.flink.cep.pattern.Quantifier
 
one(T1) - Static method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
 
ONE_OR_MORE(Quantifier.ConsumingStrategy) - Static method in class org.apache.flink.cep.pattern.Quantifier
 
OneInByte() - Method in class org.apache.flink.api.scala.typeutils.OptionTypeComparator$
 
OneInByte() - Static method in class org.apache.flink.api.scala.typeutils.OptionTypeComparator
 
OneInputStreamOperator<IN,OUT> - Interface in org.apache.flink.streaming.api.operators
Interface for stream operators with one input.
OneInputStreamTask<IN,OUT> - Class in org.apache.flink.streaming.runtime.tasks
OneInputStreamTask() - Constructor for class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
 
OneInputTransformation<IN,OUT> - Class in org.apache.flink.streaming.api.transformations
This Transformation represents the application of a OneInputStreamOperator to one input StreamTransformation.
OneInputTransformation(StreamTransformation<IN>, String, OneInputStreamOperator<IN, OUT>, TypeInformation<OUT>, int) - Constructor for class org.apache.flink.streaming.api.transformations.OneInputTransformation
Creates a new OneInputTransformation from the given input and operator.
onElement(Object, long, GlobalWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
 
onElement(Object, long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
 
onElement(Object, long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
 
onElement(Object, long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
 
onElement(T, long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
 
onElement(Object, long, TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
 
onElement(Object, long, TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
 
onElement(T, long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
 
onElement(T, long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.Trigger
Called for every element that gets added to a pane.
onElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
onElement(Object, long, GlobalWindow, Trigger.TriggerContext) - Method in class org.apache.flink.table.runtime.triggers.StateCleaningCountTrigger
 
onEmptyBuffer(int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
oneOrMore() - Method in class org.apache.flink.cep.pattern.Pattern
Specifies that this pattern can occur one or more times.
oneOrMore() - Method in class org.apache.flink.cep.scala.pattern.Pattern
Specifies that this pattern can occur
onError(Throwable) - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
onError(Throwable) - Method in class org.apache.flink.yarn.YarnResourceManager
 
onError(Throwable) - Method in class org.apache.flink.yarn.YarnResourceManagerCallbackHandler
 
OneShotLatch - Class in org.apache.flink.core.testutils
Latch for synchronizing parts of code in tests.
OneShotLatch() - Constructor for class org.apache.flink.core.testutils.OneShotLatch
 
OneTimeLeaderListenerFuture - Class in org.apache.flink.runtime.minicluster
A leader listener that exposes a future for the first leader notification.
OneTimeLeaderListenerFuture() - Constructor for class org.apache.flink.runtime.minicluster.OneTimeLeaderListenerFuture
 
onEvent(TaskEvent) - Method in class org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
 
onEvent(TaskEvent) - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepBarrier
barrier will release the waiting thread if an event occurs
onEvent(TaskEvent) - Method in class org.apache.flink.runtime.iterative.task.SyncEventHandler
 
onEvent(T) - Method in interface org.apache.flink.runtime.util.event.EventListener
 
onEventTime(InternalTimer<KEY, VoidNamespace>) - Method in class org.apache.flink.cep.operator.AbstractKeyedCEPPatternOperator
 
onEventTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
 
onEventTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.KeyedProcessOperator
 
onEventTime(InternalTimer<K, N>) - Method in interface org.apache.flink.streaming.api.operators.Triggerable
Invoked when an event-time timer fires.
onEventTime(long, GlobalWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
 
onEventTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
 
onEventTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
 
onEventTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
 
onEventTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
 
onEventTime(long, TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
 
onEventTime(long, TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
 
onEventTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
 
onEventTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.Trigger
Called when an event-time timer that was set using the trigger context fires.
onEventTime(InternalTimer<K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
 
onEventTime(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
onEventTime(InternalTimer<K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
onEventTime(long, GlobalWindow, Trigger.TriggerContext) - Method in class org.apache.flink.table.runtime.triggers.StateCleaningCountTrigger
 
onException(Throwable) - Method in interface org.apache.flink.streaming.connectors.kafka.internals.KafkaCommitCallback
A callback method the user can implement to provide asynchronous handling of commit request failure.
onExecutionFail(Execution, Throwable) - Method in class org.apache.flink.runtime.executiongraph.failover.FailoverRegion
 
onFailedPartitionRequest() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
onFailure(ActionRequest, Throwable, int, RequestIndexer) - Method in interface org.apache.flink.streaming.connectors.elasticsearch.ActionRequestFailureHandler
Handle a failed ActionRequest.
onFailure(ActionRequest, Throwable, int, RequestIndexer) - Method in class org.apache.flink.streaming.connectors.elasticsearch.util.NoOpFailureHandler
 
onFailure(ActionRequest, Throwable, int, RequestIndexer) - Method in class org.apache.flink.streaming.connectors.elasticsearch.util.RetryRejectedExecutionFailureHandler
 
onFatalError(Throwable) - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
Job completion notification triggered by JobManager or self
onFatalError(Throwable) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRunner
 
onFatalError(Throwable) - Method in interface org.apache.flink.runtime.rpc.FatalErrorHandler
 
onFatalError(Throwable) - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
 
onFatalError(Throwable) - Method in class org.apache.flink.yarn.YarnFlinkApplicationMasterRunner
 
onFatalErrorAsync(Throwable) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
Notifies the ResourceManager that a fatal error has occurred and it cannot proceed.
OnGroupedDataSet<T> - Class in org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions
Wraps a grouped data set, allowing to use anonymous partial functions to perform extraction of items in a tuple, case class instance or collection
OnGroupedDataSet(GroupedDataSet<T>) - Constructor for class org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions.OnGroupedDataSet
 
OnHalfUnfinishedKeyPairOperation<L,R,O> - Class in org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions
Wraps an half unfinished key pair operation, allowing to use anonymous partial functions to perform extraction of items in a tuple, case class instance or collection
OnHalfUnfinishedKeyPairOperation(HalfUnfinishedKeyPairOperation<L, R, O>) - Constructor for class org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions.OnHalfUnfinishedKeyPairOperation
 
OnJoinedStream<L,R,K,W extends Window> - Class in org.apache.flink.streaming.api.scala.extensions.impl.acceptPartialFunctions
Wraps a joined data stream, allowing to use anonymous partial functions to perform extraction of items in a tuple, case class instance or collection
OnJoinedStream(JoinedStreams<L, R>.Where<K>.EqualTo.WithWindow<W>) - Constructor for class org.apache.flink.streaming.api.scala.extensions.impl.acceptPartialFunctions.OnJoinedStream
 
OnJoinFunctionAssigner<L,R> - Class in org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions
Wraps a join function assigner, allowing to use anonymous partial functions to perform extraction of items in a tuple, case class instance or collection
OnJoinFunctionAssigner(JoinFunctionAssigner<L, R>) - Constructor for class org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions.OnJoinFunctionAssigner
 
OnKeyedStream<T,K> - Class in org.apache.flink.streaming.api.scala.extensions.impl.acceptPartialFunctions
Wraps a keyed data stream, allowing to use anonymous partial functions to perform extraction of items in a tuple, case class instance or collection
OnKeyedStream(KeyedStream<T, K>) - Constructor for class org.apache.flink.streaming.api.scala.extensions.impl.acceptPartialFunctions.OnKeyedStream
 
onMatch(RelOptRuleCall) - Method in class org.apache.flink.table.plan.rules.common.LogicalWindowAggregateRule
Transform LogicalAggregate with windowing expression to LogicalProject + LogicalWindowAggregate + LogicalProject.
onMatch(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.dataSet.BatchTableSourceScanRule
 
onMatch(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateRule
 
onMatch(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateWithNullValuesRule
 
onMatch(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetCalcRule
 
onMatch(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetCorrelateRule
 
onMatch(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetDistinctRule
 
onMatch(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetIntersectRule
 
onMatch(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetJoinRule
 
onMatch(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetLogicalWindowAggregateRule
 
onMatch(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetMinusRule
 
onMatch(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetScanRule
 
onMatch(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetSingleRowJoinRule
 
onMatch(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetSortRule
 
onMatch(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetUnionRule
 
onMatch(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetValuesRule
 
onMatch(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetWindowAggregateRule
 
onMatch(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamCalcRule
 
onMatch(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamCorrelateRule
 
onMatch(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupAggregateRule
 
onMatch(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupWindowAggregateRule
 
onMatch(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamLogicalWindowAggregateRule
 
onMatch(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamOverAggregateRule
 
onMatch(RelOptRuleCall) - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamRetractionRules.AssignDefaultRetractionRule
 
onMatch(RelOptRuleCall) - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamRetractionRules.SetAccModeRule
Updates the AccMode of a RelNode and its children if necessary.
onMatch(RelOptRuleCall) - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamRetractionRules.SetUpdatesAsRetractionRule
Annotates the children of a parent node with the information that they need to forward update and delete modifications as retraction messages.
onMatch(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamScanRule
 
onMatch(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamUnionRule
 
onMatch(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamValuesRule
 
onMatch(RelOptRuleCall) - Static method in class org.apache.flink.table.plan.rules.datastream.StreamTableSourceScanRule
 
onMatch(RelOptRuleCall) - Method in class org.apache.flink.table.plan.rules.logical.EnumerableToLogicalTableScan
 
onMatch(RelOptRuleCall) - Method in class org.apache.flink.table.plan.rules.logical.LogicalUnnestRule
 
onMatch(RelOptRuleCall) - Method in class org.apache.flink.table.plan.rules.logical.PushFilterIntoTableSourceScanRule
 
onMatch(RelOptRuleCall) - Method in class org.apache.flink.table.plan.rules.logical.PushProjectIntoTableSourceScanRule
 
onMerge(GlobalWindow, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
 
onMerge(W, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
 
onMerge(W, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
 
onMerge(W, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
 
onMerge(TimeWindow, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
 
onMerge(TimeWindow, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
 
onMerge(W, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
 
onMerge(W, Trigger.OnMergeContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.Trigger
Called when several windows have been merged into one window by the WindowAssigner.
onMerge(Collection<W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
onMerge(W, Trigger.OnMergeContext) - Static method in class org.apache.flink.table.runtime.triggers.StateCleaningCountTrigger
 
onNodesUpdated(List<NodeReport>) - Method in class org.apache.flink.yarn.YarnResourceManager
 
onNodesUpdated(List<NodeReport>) - Method in class org.apache.flink.yarn.YarnResourceManagerCallbackHandler
 
onNotification() - Method in interface org.apache.flink.runtime.util.event.NotificationListener
 
onProcessingTime(InternalTimer<KEY, VoidNamespace>) - Method in class org.apache.flink.cep.operator.AbstractKeyedCEPPatternOperator
 
onProcessingTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
 
onProcessingTime(long) - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
 
onProcessingTime(InternalTimer<K, VoidNamespace>) - Method in class org.apache.flink.streaming.api.operators.KeyedProcessOperator
 
onProcessingTime(InternalTimer<K, N>) - Method in interface org.apache.flink.streaming.api.operators.Triggerable
Invoked when a processing-time timer fires.
onProcessingTime(long, GlobalWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows.NeverTrigger
 
onProcessingTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
 
onProcessingTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
 
onProcessingTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
 
onProcessingTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
 
onProcessingTime(long, TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
 
onProcessingTime(long, TimeWindow, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
 
onProcessingTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
 
onProcessingTime(long, W, Trigger.TriggerContext) - Method in class org.apache.flink.streaming.api.windowing.triggers.Trigger
Called when a processing-time timer that was set using the trigger context fires.
onProcessingTime(long) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
 
onProcessingTime(long) - Method in class org.apache.flink.streaming.runtime.operators.ExtractTimestampsOperator
Deprecated.
 
onProcessingTime(long) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndPeriodicWatermarksOperator
 
onProcessingTime(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
Deprecated.
 
onProcessingTime(InternalTimer<K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
 
onProcessingTime(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
onProcessingTime(InternalTimer<K, W>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
onProcessingTime(long) - Method in interface org.apache.flink.streaming.runtime.tasks.ProcessingTimeCallback
This method is invoked with the timestamp for which the trigger was scheduled.
onProcessingTime(long, GlobalWindow, Trigger.TriggerContext) - Method in class org.apache.flink.table.runtime.triggers.StateCleaningCountTrigger
 
onReceive(Object) - Method in class org.apache.flink.runtime.akka.FlinkUntypedActor
This method is called by Akka if a new message has arrived for the actor.
onReceive(Object) - Method in class org.apache.flink.runtime.akka.QuarantineMonitor
 
onReceive(Object) - Method in class org.apache.flink.runtime.metrics.dump.MetricQueryService
 
onReceive(Object) - Method in class org.apache.flink.runtime.process.ProcessReaper
 
onRegister(RelOptPlanner) - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
onRegister(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
onRegister(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
onRegister(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
onRegister(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
onRegister(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
onRegister(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
onRegister(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
onRegister(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
onRegister(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
onRegister(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
onRegister(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
onRegister(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
onRegister(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
onRegister(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
onRegister(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
onRegistrationFailure(Throwable) - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
This method handle the Registration failure
onRegistrationFailure(Throwable) - Method in interface org.apache.flink.runtime.registration.RegistrationConnectionListener
This method is called by the RegisteredRpcConnection when the registration fails.
onRegistrationFailure(Throwable) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorToResourceManagerConnection
 
onRegistrationSuccess(Success) - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
This method handle the Registration Response
onRegistrationSuccess(Success) - Method in interface org.apache.flink.runtime.registration.RegistrationConnectionListener
This method is called by the RegisteredRpcConnection when the registration is success.
onRegistrationSuccess(TaskExecutorRegistrationSuccess) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorToResourceManagerConnection
 
onRemovedJobGraph(JobID) - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
onRemovedJobGraph(JobID) - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore.SubmittedJobGraphListener
Callback for SubmittedJobGraph instances removed by a different SubmittedJobGraphStore instance.
onShutdownRequest() - Method in class org.apache.flink.yarn.YarnResourceManager
 
onShutdownRequest() - Method in class org.apache.flink.yarn.YarnResourceManagerCallbackHandler
 
onSuccess() - Method in interface org.apache.flink.streaming.connectors.kafka.internals.KafkaCommitCallback
A callback method the user can implement to provide asynchronous handling of commit request completion.
onTaskFailure(Execution, Throwable) - Method in class org.apache.flink.runtime.executiongraph.failover.FailoverStrategy
Called by the execution graph when a task failure occurs.
onTaskFailure(Execution, Throwable) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartAllStrategy
 
onTaskFailure(Execution, Throwable) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy
 
onTaskFailure(Execution, Throwable) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy
 
onTermination(PartialFunction<FSM.StopEvent<S, D>, BoxedUnit>) - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
onTermination(PartialFunction<FSM.StopEvent<S, D>, BoxedUnit>) - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
onTermination(PartialFunction<FSM.StopEvent<S, D>, BoxedUnit>) - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
onTermination(PartialFunction<FSM.StopEvent<S, D>, BoxedUnit>) - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
onTimer(long, CoProcessFunction<IN1, IN2, OUT>.OnTimerContext, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction
Called when a timer set using TimerService fires.
onTimer(long, ProcessFunction<I, O>.OnTimerContext, Collector<O>) - Method in class org.apache.flink.streaming.api.functions.ProcessFunction
Called when a timer set using TimerService fires.
onTimer(long, ProcessFunction<CRow, CRow>.OnTimerContext, Collector<CRow>) - Method in class org.apache.flink.table.runtime.aggregate.GroupAggProcessFunction
 
onTimer(long, ProcessFunction<CRow, CRow>.OnTimerContext, Collector<CRow>) - Method in class org.apache.flink.table.runtime.aggregate.ProcTimeBoundedRangeOver
 
onTimer(long, ProcessFunction<CRow, CRow>.OnTimerContext, Collector<CRow>) - Method in class org.apache.flink.table.runtime.aggregate.ProcTimeBoundedRowsOver
 
onTimer(long, ProcessFunction<CRow, CRow>.OnTimerContext, Collector<CRow>) - Method in class org.apache.flink.table.runtime.aggregate.ProcTimeUnboundedOver
 
onTimer(long, ProcessFunction<CRow, CRow>.OnTimerContext, Collector<CRow>) - Method in class org.apache.flink.table.runtime.aggregate.RowTimeBoundedRangeOver
 
onTimer(long, ProcessFunction<CRow, CRow>.OnTimerContext, Collector<CRow>) - Method in class org.apache.flink.table.runtime.aggregate.RowTimeBoundedRowsOver
 
onTimer(long, ProcessFunction<CRow, CRow>.OnTimerContext, Collector<CRow>) - Method in class org.apache.flink.table.runtime.aggregate.RowTimeUnboundedOver
Called when a watermark arrived.
OnTimerContext() - Constructor for class org.apache.flink.streaming.api.functions.co.CoProcessFunction.OnTimerContext
 
OnTimerContext() - Constructor for class org.apache.flink.streaming.api.functions.ProcessFunction.OnTimerContext
 
onTransition(PartialFunction<Tuple2<S, S>, BoxedUnit>) - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
onTransition(PartialFunction<Tuple2<S, S>, BoxedUnit>) - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
onTransition(PartialFunction<Tuple2<S, S>, BoxedUnit>) - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
onTransition(PartialFunction<Tuple2<S, S>, BoxedUnit>) - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
OnUnfinishedKeyPairOperation<L,R,O> - Class in org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions
Wraps an unfinished key pair operation, allowing to use anonymous partial functions to perform extraction of items in a tuple, case class instance or collection
OnUnfinishedKeyPairOperation(UnfinishedKeyPairOperation<L, R, O>) - Constructor for class org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions.OnUnfinishedKeyPairOperation
 
onWatermark(KEY, Watermark) - Method in interface org.apache.flink.streaming.api.operators.OnWatermarkCallback
The action to be triggered upon reception of a watermark.
OnWatermarkCallback<KEY> - Interface in org.apache.flink.streaming.api.operators
A callback registered with the InternalWatermarkCallbackService service.
OnWindowedStream<T,K,W extends Window> - Class in org.apache.flink.streaming.api.scala.extensions.impl.acceptPartialFunctions
Wraps a joined data stream, allowing to use anonymous partial functions to perform extraction of items in a tuple, case class instance or collection
OnWindowedStream(WindowedStream<T, K, W>) - Constructor for class org.apache.flink.streaming.api.scala.extensions.impl.acceptPartialFunctions.OnWindowedStream
 
open(TableInputSplit) - Method in class org.apache.flink.addons.hbase.AbstractTableInputFormat
 
open(Configuration) - Method in class org.apache.flink.api.common.functions.AbstractRichFunction
 
open(Configuration) - Method in interface org.apache.flink.api.common.functions.RichFunction
Initialization method for the function.
open(FileInputSplit) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
 
open(int, int) - Method in class org.apache.flink.api.common.io.BinaryOutputFormat
 
open(FileInputSplit) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
Opens the given input split.
open(FileInputSplit) - Method in class org.apache.flink.api.common.io.FileInputFormat
Opens an input stream to the file defined in the input format.
open(int, int) - Method in class org.apache.flink.api.common.io.FileOutputFormat
 
open(FileInputSplit) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
open(GenericInputSplit) - Method in class org.apache.flink.api.common.io.GenericInputFormat
 
open(T) - Method in interface org.apache.flink.api.common.io.InputFormat
Opens a parallel instance of the input format to work on a split.
open(int, int) - Method in interface org.apache.flink.api.common.io.OutputFormat
Opens a parallel instance of the output format to store the result of its parallel instance.
open(S) - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
 
open(Configuration) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionMapper
 
open(HadoopInputSplit) - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
open(int, int) - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
create the temporary output file for hadoop RecordWriter.
open(HadoopInputSplit) - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
open(int, int) - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
create the temporary output file for hadoop RecordWriter.
open(FileInputSplit) - Method in class org.apache.flink.api.java.io.AvroInputFormat
 
open(int, int) - Method in class org.apache.flink.api.java.io.AvroOutputFormat
 
open(GenericInputSplit) - Method in class org.apache.flink.api.java.io.CollectionInputFormat
 
open(FileInputSplit) - Method in class org.apache.flink.api.java.io.CsvInputFormat
 
open(int, int) - Method in class org.apache.flink.api.java.io.CsvOutputFormat
 
open(int, int) - Method in class org.apache.flink.api.java.io.DiscardingOutputFormat
 
open(InputSplit) - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat
Connects to the source database and executes the query in a parallel fashion if this InputFormat is built using a parameterized query (i.e.
open(int, int) - Method in class org.apache.flink.api.java.io.jdbc.JDBCOutputFormat
Connects to the target database and initializes the prepared statement.
open(int, int) - Method in class org.apache.flink.api.java.io.LocalCollectionOutputFormat
 
open(GenericInputSplit) - Method in class org.apache.flink.api.java.io.ParallelIteratorInputFormat
 
open(FileInputSplit) - Method in class org.apache.flink.api.java.io.PojoCsvInputFormat
 
open(FileInputSplit) - Method in class org.apache.flink.api.java.io.PrimitiveInputFormat
 
open(int, int) - Method in class org.apache.flink.api.java.io.PrintingOutputFormat
 
open(int, int) - Method in class org.apache.flink.api.java.io.TextOutputFormat
 
open(Configuration) - Method in class org.apache.flink.api.java.operators.AggregateOperator.AggregatingUdf
 
open(Configuration) - Method in class org.apache.flink.api.java.operators.translation.RichCombineToGroupCombineWrapper
 
open(Configuration) - Method in class org.apache.flink.api.java.operators.translation.WrappingFunction
 
open(int, int) - Method in class org.apache.flink.api.java.Utils.ChecksumHashCodeHelper
 
open(int, int) - Method in class org.apache.flink.api.java.Utils.CollectHelper
 
open(int, int) - Method in class org.apache.flink.api.java.Utils.CountHelper
 
open(Configuration) - Method in class org.apache.flink.api.scala.operators.ScalaAggregateOperator.AggregatingUdf
 
open(int, int) - Method in class org.apache.flink.api.scala.operators.ScalaCsvOutputFormat
 
open(InputSplit) - Method in class org.apache.flink.batch.connectors.cassandra.CassandraInputFormat
Opens a Session and executes the query.
open(int, int) - Method in class org.apache.flink.batch.connectors.cassandra.CassandraOutputFormat
Opens a Session to Cassandra and initializes the prepared statement.
open() - Method in class org.apache.flink.cep.operator.AbstractKeyedCEPPatternOperator
 
open(FileInputSplit) - Method in class org.apache.flink.contrib.tweetinputformat.io.SimpleTweetInputFormat
 
open(Path, int) - Method in class org.apache.flink.core.fs.FileSystem
Opens an FSDataInputStream at the indicated Path.
open(Path) - Method in class org.apache.flink.core.fs.FileSystem
Opens an FSDataInputStream at the indicated Path.
open(Path, int) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
open(Path) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
open(Path, int) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
open(Path) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
open(MetricConfig) - Method in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
 
open(Configuration) - Method in class org.apache.flink.examples.java.clustering.KMeans.SelectNearestCenter
Reads the centroid values from a broadcast variable into a collection.
open(FileCopyTaskInputSplit) - Method in class org.apache.flink.examples.java.distcp.FileCopyTaskInputFormat
 
open(Configuration) - Method in class org.apache.flink.examples.java.ml.LinearRegression.SubUpdate
Reads the parameters from a broadcast variable into a collection.
open(Configuration) - Method in class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator.EmptyFieldFilter
 
open(Configuration) - Method in class org.apache.flink.examples.scala.clustering.KMeans.SelectNearestCenter
Reads the centroid values from a broadcast variable into a collection.
open(Configuration) - Method in class org.apache.flink.examples.scala.ml.LinearRegression.SubUpdate
 
open(int, int) - Method in class org.apache.flink.graph.AnalyticHelper
 
open(Configuration) - Method in class org.apache.flink.hadoopcompatibility.mapred.HadoopMapFunction
 
open(Configuration) - Method in class org.apache.flink.hadoopcompatibility.mapred.HadoopReduceCombineFunction
 
open(Configuration) - Method in class org.apache.flink.hadoopcompatibility.mapred.HadoopReduceFunction
 
open(HadoopInputSplit) - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
 
open(MetricConfig) - Method in class org.apache.flink.metrics.datadog.DatadogHttpReporter
 
open(MetricConfig) - Method in class org.apache.flink.metrics.jmx.JMXReporter
 
open(MetricConfig) - Method in interface org.apache.flink.metrics.reporter.MetricReporter
Configures this reporter.
open(MetricConfig) - Method in class org.apache.flink.metrics.statsd.StatsDReporter
 
open(Configuration) - Method in class org.apache.flink.python.api.functions.PythonCoGroup
Opens this function.
open(Configuration) - Method in class org.apache.flink.python.api.functions.PythonMapPartition
Opens this function.
open(File) - Method in class org.apache.flink.python.api.streaming.data.PythonReceiver
 
open(File) - Method in class org.apache.flink.python.api.streaming.data.PythonSender
 
open() - Method in class org.apache.flink.python.api.streaming.data.PythonStreamer
Starts the python script.
open(String, String) - Method in class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
 
open - Variable in class org.apache.flink.runtime.checkpoint.AbstractAsyncSnapshotIOCallable
 
open(Path, int) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
 
open(Path) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
 
open(Path, int) - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
 
open(Path) - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
 
open() - Method in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
Initialize the hash table
open() - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable
Initialize the hash table
open() - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable
Initialize the hash table
open(MutableObjectIterator<BT>, MutableObjectIterator<PT>) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
Opens the hash join.
open(MutableObjectIterator<BT>, MutableObjectIterator<PT>, boolean) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
Opens the hash join.
open() - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstHashJoinIterator
 
open() - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondHashJoinIterator
 
open(MutableObjectIterator<BT>, MutableObjectIterator<PT>, boolean) - Method in class org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
 
open() - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildFirstHashJoinIterator
 
open() - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildSecondHashJoinIterator
 
open() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
open() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
open() - Method in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
open() - Method in class org.apache.flink.runtime.operators.sort.NonReusingSortMergeCoGroupIterator
 
open() - Method in class org.apache.flink.runtime.operators.sort.ReusingSortMergeCoGroupIterator
 
open() - Method in interface org.apache.flink.runtime.operators.util.CoGroupTaskIterator
General-purpose open method.
open() - Method in interface org.apache.flink.runtime.operators.util.JoinTaskIterator
General-purpose open method.
open(Map, TopologyContext, SpoutOutputCollector) - Method in class org.apache.flink.storm.split.operators.RandomSpout
 
open(Map, TopologyContext, SpoutOutputCollector) - Method in class org.apache.flink.storm.util.AbstractLineSpout
 
open(Map, TopologyContext, SpoutOutputCollector) - Method in class org.apache.flink.storm.util.FileSpout
 
open(Map, TopologyContext, SpoutOutputCollector) - Method in class org.apache.flink.storm.util.FiniteFileSpout
 
open(Map, TopologyContext, SpoutOutputCollector) - Method in class org.apache.flink.storm.util.NullTerminatingSpout
 
open() - Method in class org.apache.flink.storm.wrappers.BoltWrapper
 
open(Configuration) - Method in class org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
 
open(Configuration) - Method in class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
 
open(Configuration) - Method in class org.apache.flink.streaming.api.functions.sink.SocketClientSink
Initialize the connection with the Socket in the server.
open(Configuration) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
 
open() - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
 
open(Configuration) - Method in class org.apache.flink.streaming.api.functions.source.FromSplittableIteratorFunction
 
open(Configuration) - Method in class org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
 
open(Configuration) - Method in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
 
open(Configuration) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyAllWindowFunction
Deprecated.
 
open(Configuration) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessAllWindowFunction
Deprecated.
 
open(Configuration) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessWindowFunction
Deprecated.
 
open(Configuration) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyWindowFunction
Deprecated.
 
open(Configuration) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
 
open(Configuration) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
 
open() - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
This method is called immediately before any elements are processed, it should contain the operator's initialization logic, e.g.
open() - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
open() - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
open() - Method in class org.apache.flink.streaming.api.operators.co.CoProcessOperator
 
open() - Method in class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
 
open() - Method in class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
 
open() - Method in class org.apache.flink.streaming.api.operators.KeyedProcessOperator
 
open() - Method in class org.apache.flink.streaming.api.operators.ProcessOperator
 
open() - Method in class org.apache.flink.streaming.api.operators.StreamFlatMap
 
open() - Method in class org.apache.flink.streaming.api.operators.StreamGroupedFold
Deprecated.
 
open() - Method in class org.apache.flink.streaming.api.operators.StreamGroupedReduce
 
open() - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
This method is called immediately before any elements are processed, it should contain the operator's initialization logic.
open() - Method in class org.apache.flink.streaming.api.operators.StreamProject
 
open(Configuration) - Method in interface org.apache.flink.streaming.api.scala.function.StatefulFunction
 
open(Configuration) - Method in class org.apache.flink.streaming.api.scala.function.util.ScalaProcessAllWindowFunctionWrapper
 
open(Configuration) - Method in class org.apache.flink.streaming.api.scala.function.util.ScalaProcessWindowFunctionWrapper
 
open() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraCommitter
 
open(Configuration) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraPojoSink
 
open(Configuration) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSinkBase
 
open(Configuration) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraTupleSink
 
open() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraTupleWriteAheadSink
 
open(Configuration) - Method in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase
 
open(FileSystem, Path) - Method in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter
 
open(Configuration) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
 
open(Configuration) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
Deprecated.
 
open(FileSystem, Path) - Method in class org.apache.flink.streaming.connectors.fs.SequenceFileWriter
 
open(FileSystem, Path) - Method in class org.apache.flink.streaming.connectors.fs.StreamWriterBase
 
open(FileSystem, Path) - Method in class org.apache.flink.streaming.connectors.fs.StringWriter
 
open(FileSystem, Path) - Method in interface org.apache.flink.streaming.connectors.fs.Writer
Initializes the Writer for a newly opened bucket file.
open(Configuration) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
 
open(Configuration) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
This method is used for approach (a) (see above)
open(Configuration) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
Initializes the connection to Kafka.
open(int, int) - Method in class org.apache.flink.streaming.connectors.kafka.partitioner.FlinkFixedPartitioner
 
open(int, int) - Method in class org.apache.flink.streaming.connectors.kafka.partitioner.FlinkKafkaDelegatePartitioner
Deprecated.
 
open(int, int) - Method in class org.apache.flink.streaming.connectors.kafka.partitioner.FlinkKafkaPartitioner
Initializer for the partitioner.
open(int, int, int[]) - Method in class org.apache.flink.streaming.connectors.kafka.partitioner.KafkaPartitioner
Deprecated.
Initializer for the Partitioner.
open(Configuration) - Method in class org.apache.flink.streaming.connectors.nifi.NiFiSink
 
open(Configuration) - Method in class org.apache.flink.streaming.connectors.nifi.NiFiSource
 
open(Configuration) - Method in class org.apache.flink.streaming.connectors.rabbitmq.RMQSink
 
open(Configuration) - Method in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
 
open(Configuration) - Method in class org.apache.flink.streaming.connectors.twitter.TwitterSource
 
open(Configuration) - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditsSource
 
open() - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller.SpilledBufferOrEventSequence
Initializes the sequence for reading.
open() - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
Opens/connects to the resource, and possibly creates it beforehand.
open() - Method in class org.apache.flink.streaming.runtime.operators.ExtractTimestampsOperator
Deprecated.
 
open() - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
 
open() - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndPeriodicWatermarksOperator
 
open() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
Deprecated.
 
open() - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
 
open(Configuration) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
 
open(Configuration) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
 
open(Configuration) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
 
open() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
open(FunctionContext) - Method in class org.apache.flink.table.functions.UserDefinedFunction
Setup method for user-defined function.
open(Configuration) - Method in class org.apache.flink.table.runtime.aggregate.DataSetAggFunction
 
open(Configuration) - Method in class org.apache.flink.table.runtime.aggregate.DataSetFinalAggFunction
 
open(Configuration) - Method in class org.apache.flink.table.runtime.aggregate.DataSetPreAggFunction
 
open(Configuration) - Method in class org.apache.flink.table.runtime.aggregate.DataSetSessionWindowAggReduceGroupFunction
 
open(Configuration) - Method in class org.apache.flink.table.runtime.aggregate.DataSetSessionWindowAggregatePreProcessor
 
open(Configuration) - Method in class org.apache.flink.table.runtime.aggregate.DataSetSlideTimeWindowAggReduceGroupFunction
 
open(Configuration) - Method in class org.apache.flink.table.runtime.aggregate.DataSetSlideWindowAggReduceCombineFunction
 
open(Configuration) - Method in class org.apache.flink.table.runtime.aggregate.DataSetSlideWindowAggReduceGroupFunction
 
open(Configuration) - Method in class org.apache.flink.table.runtime.aggregate.DataSetTumbleCountWindowAggReduceGroupFunction
 
open(Configuration) - Method in class org.apache.flink.table.runtime.aggregate.DataSetTumbleTimeWindowAggReduceCombineFunction
 
open(Configuration) - Method in class org.apache.flink.table.runtime.aggregate.DataSetTumbleTimeWindowAggReduceGroupFunction
 
open(Configuration) - Method in class org.apache.flink.table.runtime.aggregate.DataSetWindowAggMapFunction
 
open(Configuration) - Method in class org.apache.flink.table.runtime.aggregate.GroupAggProcessFunction
 
open(Configuration) - Method in class org.apache.flink.table.runtime.aggregate.IncrementalAggregateAllTimeWindowFunction
 
open(Configuration) - Method in class org.apache.flink.table.runtime.aggregate.IncrementalAggregateAllWindowFunction
 
open(Configuration) - Method in class org.apache.flink.table.runtime.aggregate.IncrementalAggregateTimeWindowFunction
 
open(Configuration) - Method in class org.apache.flink.table.runtime.aggregate.IncrementalAggregateWindowFunction
 
open(Configuration) - Method in class org.apache.flink.table.runtime.aggregate.ProcTimeBoundedRangeOver
 
open(Configuration) - Method in class org.apache.flink.table.runtime.aggregate.ProcTimeBoundedRowsOver
 
open(Configuration) - Method in class org.apache.flink.table.runtime.aggregate.ProcTimeUnboundedOver
 
open(Configuration) - Method in class org.apache.flink.table.runtime.aggregate.RowTimeBoundedRangeOver
 
open(Configuration) - Method in class org.apache.flink.table.runtime.aggregate.RowTimeBoundedRowsOver
 
open(Configuration) - Method in class org.apache.flink.table.runtime.aggregate.RowTimeUnboundedOver
 
open(Configuration) - Method in class org.apache.flink.table.runtime.CorrelateFlatMapRunner
 
open(Configuration) - Method in class org.apache.flink.table.runtime.CRowCorrelateProcessRunner
 
open(Configuration) - Method in class org.apache.flink.table.runtime.CRowInputJavaTupleOutputMapRunner
 
open(Configuration) - Method in class org.apache.flink.table.runtime.CRowInputMapRunner
 
open(Configuration) - Method in class org.apache.flink.table.runtime.CRowInputScalaTupleOutputMapRunner
 
open(Configuration) - Method in class org.apache.flink.table.runtime.CRowOutputMapRunner
 
open(Configuration) - Method in class org.apache.flink.table.runtime.CRowProcessRunner
 
open(Configuration) - Method in class org.apache.flink.table.runtime.FlatJoinRunner
 
open(Configuration) - Method in class org.apache.flink.table.runtime.FlatMapRunner
 
open(GenericInputSplit) - Method in class org.apache.flink.table.runtime.io.CRowValuesInputFormat
 
open(GenericInputSplit) - Method in class org.apache.flink.table.runtime.io.ValuesInputFormat
 
open(Configuration) - Method in class org.apache.flink.table.runtime.LimitFilterFunction
 
open(Configuration) - Method in class org.apache.flink.table.runtime.MapRunner
 
open(Configuration) - Method in class org.apache.flink.table.runtime.MapSideJoinRunner
 
OPEN_MUTEX - Static variable in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
 
OPEN_MUTEX - Static variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
 
openBranches - Variable in class org.apache.flink.optimizer.dag.OptimizerNode
 
openChainedTasks(List<ChainedDriver<?, ?>>, AbstractInvokable) - Static method in class org.apache.flink.runtime.operators.BatchTask
Opens all chained tasks, in the order as they are stored in the array.
openDataInputView() - Method in class org.apache.flink.migration.runtime.state.memory.AbstractMigrationRestoreStrategy
Deprecated.
Different state handles require different code to end up with a DataInputView.
openFunction(Function, Configuration) - Static method in class org.apache.flink.api.common.functions.util.FunctionUtils
 
openInputFormat() - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
 
openInputFormat() - Method in class org.apache.flink.api.common.io.RichInputFormat
Opens this InputFormat instance.
openInputFormat() - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat
 
openInputStream() - Method in class org.apache.flink.migration.state.MigrationStreamStateHandle
Deprecated.
 
openInputStream() - Method in class org.apache.flink.runtime.state.filesystem.FileStateHandle
 
openInputStream() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
 
openInputStream() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
 
openInputStream() - Method in class org.apache.flink.runtime.state.MultiStreamStateHandle
 
openInputStream() - Method in class org.apache.flink.runtime.state.OperatorStateHandle
 
openInputStream() - Method in class org.apache.flink.runtime.state.PlaceholderStreamStateHandle
 
openInputStream() - Method in class org.apache.flink.runtime.state.RetrievableStreamStateHandle
 
openInputStream() - Method in interface org.apache.flink.runtime.state.StreamStateHandle
Returns an FSDataInputStream that can be used to read back the data that was previously written to the stream.
openIOHandle() - Method in class org.apache.flink.runtime.checkpoint.AbstractAsyncSnapshotIOCallable
 
openIOHandle() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncIOCallable
Open the IO Handle (e.g.
openTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
 
openTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
openTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
 
openTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
 
openTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
 
openTask() - Method in class org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
 
openTask() - Method in class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
 
openTask() - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
 
openTask() - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
 
openTimeout - Variable in class org.apache.flink.api.common.io.FileInputFormat
Stream opening timeout.
openUserCode(Function, Configuration) - Static method in class org.apache.flink.runtime.operators.BatchTask
Opens the given stub using its RichFunction.open(Configuration) method.
OperatingSystem - Enum in org.apache.flink.util
An enumeration indicating the operating system that the JVM runs on.
operations() - Method in class org.apache.flink.mesos.scheduler.messages.AcceptOffers
 
Operator<OUT> - Class in org.apache.flink.api.common.operators
Abstract base class for all operators.
Operator(OperatorInformation<OUT>, String) - Constructor for class org.apache.flink.api.common.operators.Operator
Creates a new contract with the given name.
Operator<OUT,O extends Operator<OUT,O>> - Class in org.apache.flink.api.java.operators
Base class of all operators in the Java API.
Operator(ExecutionEnvironment, TypeInformation<OUT>) - Constructor for class org.apache.flink.api.java.operators.Operator
 
OperatorActions - Interface in org.apache.flink.streaming.api.operators.async
Interface for StreamOperator actions.
OperatorBackendSerializationProxy - Class in org.apache.flink.runtime.state
Serialization proxy for all meta data in operator state backends.
OperatorBackendSerializationProxy(ClassLoader) - Constructor for class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
 
OperatorBackendSerializationProxy(List<RegisteredOperatorBackendStateMetaInfo.Snapshot<?>>) - Constructor for class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
 
OperatorBackendStateMetaInfoReaderV1(ClassLoader) - Constructor for class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoReaderV1
 
OperatorBackendStateMetaInfoReaderV2(ClassLoader) - Constructor for class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoReaderV2
 
OperatorBackendStateMetaInfoSnapshotReaderWriters - Class in org.apache.flink.runtime.state
Readers and writers for different versions of the RegisteredOperatorBackendStateMetaInfo.Snapshot.
OperatorBackendStateMetaInfoSnapshotReaderWriters() - Constructor for class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters
 
OperatorBackendStateMetaInfoSnapshotReaderWriters.AbstractOperatorBackendStateMetaInfoReader<S> - Class in org.apache.flink.runtime.state
 
OperatorBackendStateMetaInfoSnapshotReaderWriters.AbstractOperatorBackendStateMetaInfoWriter<S> - Class in org.apache.flink.runtime.state
 
OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoReader<S> - Interface in org.apache.flink.runtime.state
 
OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoReaderV1<S> - Class in org.apache.flink.runtime.state
 
OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoReaderV2<S> - Class in org.apache.flink.runtime.state
 
OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoWriter - Interface in org.apache.flink.runtime.state
 
OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoWriterV1<S> - Class in org.apache.flink.runtime.state
 
OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoWriterV2<S> - Class in org.apache.flink.runtime.state
 
OperatorBackendStateMetaInfoWriterV1(RegisteredOperatorBackendStateMetaInfo.Snapshot<S>) - Constructor for class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoWriterV1
 
OperatorBackendStateMetaInfoWriterV2(RegisteredOperatorBackendStateMetaInfo.Snapshot<S>) - Constructor for class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoWriterV2
 
OperatorBackPressureStats - Class in org.apache.flink.runtime.webmonitor
Back pressure statistics of multiple tasks.
OperatorBackPressureStats(int, long, double[]) - Constructor for class org.apache.flink.runtime.webmonitor.OperatorBackPressureStats
 
OperatorChain<OUT,OP extends StreamOperator<OUT>> - Class in org.apache.flink.streaming.runtime.tasks
The OperatorChain contains all operators that are executed as one chain within a single StreamTask.
OperatorChain(StreamTask<OUT, OP>) - Constructor for class org.apache.flink.streaming.runtime.tasks.OperatorChain
 
operatorChain - Variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
The chain of operators executed by this task.
OperatorDescriptorDual - Class in org.apache.flink.optimizer.operators
 
OperatorDescriptorDual() - Constructor for class org.apache.flink.optimizer.operators.OperatorDescriptorDual
 
OperatorDescriptorDual(FieldList, FieldList) - Constructor for class org.apache.flink.optimizer.operators.OperatorDescriptorDual
 
OperatorDescriptorDual.GlobalPropertiesPair - Class in org.apache.flink.optimizer.operators
 
OperatorDescriptorDual.LocalPropertiesPair - Class in org.apache.flink.optimizer.operators
 
OperatorDescriptorSingle - Class in org.apache.flink.optimizer.operators
Abstract base class for Operator descriptions which instantiates the node and sets the driver strategy and the sorting and grouping keys.
OperatorDescriptorSingle() - Constructor for class org.apache.flink.optimizer.operators.OperatorDescriptorSingle
 
OperatorDescriptorSingle(FieldSet) - Constructor for class org.apache.flink.optimizer.operators.OperatorDescriptorSingle
 
OperatorID - Class in org.apache.flink.runtime.jobgraph
A class for statistically unique operator IDs.
OperatorID() - Constructor for class org.apache.flink.runtime.jobgraph.OperatorID
 
OperatorID(byte[]) - Constructor for class org.apache.flink.runtime.jobgraph.OperatorID
 
OperatorID(long, long) - Constructor for class org.apache.flink.runtime.jobgraph.OperatorID
 
operatorId - Variable in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
 
operatorInfo - Variable in class org.apache.flink.api.common.operators.Operator
The return type of the user function.
OperatorInformation<OUT> - Class in org.apache.flink.api.common.operators
A class for holding information about an operator, such as input/output TypeInformation.
OperatorInformation(TypeInformation<OUT>) - Constructor for class org.apache.flink.api.common.operators.OperatorInformation
 
OperatorIOMetricGroup - Class in org.apache.flink.runtime.metrics.groups
Metric group that contains shareable pre-defined IO-related metrics.
OperatorIOMetricGroup(OperatorMetricGroup) - Constructor for class org.apache.flink.runtime.metrics.groups.OperatorIOMetricGroup
 
OperatorMetricGroup - Class in org.apache.flink.runtime.metrics.groups
Special MetricGroup representing an Operator.
OperatorMetricGroup(MetricRegistry, TaskMetricGroup, String) - Constructor for class org.apache.flink.runtime.metrics.groups.OperatorMetricGroup
 
operatorName - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
 
OperatorQueryScopeInfo(String, String, int, String) - Constructor for class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
 
OperatorQueryScopeInfo(String, String, int, String, String) - Constructor for class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
 
OperatorScopeFormat - Class in org.apache.flink.runtime.metrics.scope
The scope format for the OperatorMetricGroup.
OperatorScopeFormat(String, TaskScopeFormat) - Constructor for class org.apache.flink.runtime.metrics.scope.OperatorScopeFormat
 
OperatorSnapshotResult - Class in org.apache.flink.streaming.api.operators
OperatorSnapshotResult() - Constructor for class org.apache.flink.streaming.api.operators.OperatorSnapshotResult
 
OperatorSnapshotResult(RunnableFuture<KeyedStateHandle>, RunnableFuture<KeyedStateHandle>, RunnableFuture<OperatorStateHandle>, RunnableFuture<OperatorStateHandle>) - Constructor for class org.apache.flink.streaming.api.operators.OperatorSnapshotResult
 
OperatorState - Class in org.apache.flink.runtime.checkpoint
Simple container class which contains the raw/managed/legacy operator state and key-group state handles for the sub tasks of an operator.
OperatorState(OperatorID, int, int) - Constructor for class org.apache.flink.runtime.checkpoint.OperatorState
 
OperatorStateBackend - Interface in org.apache.flink.runtime.state
Interface that combines both, the user facing OperatorStateStore interface and the system interface Snapshotable
OperatorStateCheckpointOutputStream - Class in org.apache.flink.runtime.state
Checkpoint output stream that allows to write raw operator state in a partitioned way.
OperatorStateCheckpointOutputStream(CheckpointStreamFactory.CheckpointStateOutputStream) - Constructor for class org.apache.flink.runtime.state.OperatorStateCheckpointOutputStream
 
OperatorStateHandle - Class in org.apache.flink.runtime.state
State handle for partitionable operator state.
OperatorStateHandle(Map<String, OperatorStateHandle.StateMetaInfo>, StreamStateHandle) - Constructor for class org.apache.flink.runtime.state.OperatorStateHandle
 
OperatorStateHandle.Mode - Enum in org.apache.flink.runtime.state
The modes that determine how an OperatorStateHandle is assigned to tasks during restore.
OperatorStateHandle.StateMetaInfo - Class in org.apache.flink.runtime.state
 
OperatorStateHandles - Class in org.apache.flink.streaming.runtime.tasks
This class holds all state handles for one operator.
OperatorStateHandles(int, StreamStateHandle, Collection<KeyedStateHandle>, Collection<KeyedStateHandle>, Collection<OperatorStateHandle>, Collection<OperatorStateHandle>) - Constructor for class org.apache.flink.streaming.runtime.tasks.OperatorStateHandles
 
OperatorStateHandles(TaskStateHandles, int) - Constructor for class org.apache.flink.streaming.runtime.tasks.OperatorStateHandles
 
OperatorStateRepartitioner - Interface in org.apache.flink.runtime.checkpoint
Interface that allows to implement different strategies for repartitioning of operator state as parallelism changes.
OperatorStateStore - Interface in org.apache.flink.api.common.state
This interface contains methods for registering operator state with a managed store.
OperatorSubtaskState - Class in org.apache.flink.runtime.checkpoint
Container for the state of one parallel subtask of an operator.
OperatorSubtaskState(StreamStateHandle, OperatorStateHandle, OperatorStateHandle, KeyedStateHandle, KeyedStateHandle) - Constructor for class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
 
operatorTable() - Method in class org.apache.flink.table.calcite.FlinkPlannerImpl
 
OperatorTranslation - Class in org.apache.flink.api.java.operators
 
OperatorTranslation() - Constructor for class org.apache.flink.api.java.operators.OperatorTranslation
 
opt(Function0<Parsers.Parser<T>>) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
optimalInit() - Method in class org.apache.flink.ml.optimization.LearningRateMethod.Bottou
 
optimalNumOfBits(long, double) - Static method in class org.apache.flink.runtime.operators.util.BloomFilter
Compute optimal bits number with given input entries and expected false positive probability.
optimize(DataSet<LabeledVector>, Option<DataSet<WeightVector>>) - Method in class org.apache.flink.ml.optimization.GradientDescent
Provides a solution for the given optimization problem
optimize(DataSet<LabeledVector>, Option<DataSet<WeightVector>>) - Static method in class org.apache.flink.ml.optimization.IterativeSolver
 
optimize(DataSet<LabeledVector>, Option<DataSet<WeightVector>>) - Method in class org.apache.flink.ml.optimization.Solver
Provides a solution for the given optimization problem
optimize(RelNode) - Method in class org.apache.flink.table.api.BatchTableEnvironment
Generates the optimized RelNode tree from the original relational node tree.
optimize(RelNode, boolean) - Method in class org.apache.flink.table.api.StreamTableEnvironment
Generates the optimized RelNode tree from the original relational node tree.
OptimizedPlan - Class in org.apache.flink.optimizer.plan
The execution plan generated by the Optimizer.
OptimizedPlan(Collection<SourcePlanNode>, Collection<SinkPlanNode>, Collection<PlanNode>, String, Plan) - Constructor for class org.apache.flink.optimizer.plan.OptimizedPlan
Creates a new instance of this optimizer plan container.
optimizer() - Method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
The task placement optimizer.
Optimizer - Class in org.apache.flink.optimizer
The optimizer that takes the user specified program plan and creates an optimized plan that contains exact descriptions about how the physical execution will take place.
Optimizer(Configuration) - Constructor for class org.apache.flink.optimizer.Optimizer
Creates a new optimizer instance.
Optimizer(DataStatistics, Configuration) - Constructor for class org.apache.flink.optimizer.Optimizer
Creates a new optimizer instance that uses the statistics object to determine properties about the input.
Optimizer(CostEstimator, Configuration) - Constructor for class org.apache.flink.optimizer.Optimizer
Creates a new optimizer instance.
Optimizer(DataStatistics, CostEstimator, Configuration) - Constructor for class org.apache.flink.optimizer.Optimizer
Creates a new optimizer instance that uses the statistics object to determine properties about the input.
OptimizerNode - Class in org.apache.flink.optimizer.dag
The OptimizerNode is the base class of all nodes in the optimizer DAG.
OptimizerNode(Operator<?>) - Constructor for class org.apache.flink.optimizer.dag.OptimizerNode
Creates a new optimizer node that represents the given program operator.
OptimizerNode(OptimizerNode) - Constructor for class org.apache.flink.optimizer.dag.OptimizerNode
 
OptimizerNode.UnclosedBranchDescriptor - Class in org.apache.flink.optimizer.dag
Description of an unclosed branch.
optimizerPlanAsJSON(Plan) - Static method in class org.apache.flink.client.LocalExecutor
Creates a JSON representation of the given dataflow's execution plan.
OptimizerPlanEnvironment - Class in org.apache.flink.client.program
 
OptimizerPlanEnvironment(Optimizer) - Constructor for class org.apache.flink.client.program.OptimizerPlanEnvironment
 
OptimizerPlanEnvironment.ProgramAbortException - Error in org.apache.flink.client.program
A special exception used to abort programs when the caller is only interested in the program plan, rather than in the full execution.
OptimizerPostPass - Interface in org.apache.flink.optimizer.postpass
Interface for visitors that process the optimizer's plan.
optimizeWithConvergenceCriterion(DataSet<LabeledVector>, DataSet<WeightVector>, int, RegularizationPenalty, double, double, double, LossFunction, LearningRateMethod.LearningRateMethodTrait) - Method in class org.apache.flink.ml.optimization.GradientDescent
 
optimizeWithoutConvergenceCriterion(DataSet<LabeledVector>, DataSet<WeightVector>, int, RegularizationPenalty, double, double, LossFunction, LearningRateMethod.LearningRateMethodTrait) - Method in class org.apache.flink.ml.optimization.GradientDescent
 
Option - Class in org.apache.flink.api.java.utils
Internal representation of a parameter passed to a user defined function.
Option(String) - Constructor for class org.apache.flink.api.java.utils.Option
 
optional() - Method in class org.apache.flink.cep.pattern.Pattern
Specifies that this pattern is optional for a final match of the pattern sequence to happen.
optional() - Method in class org.apache.flink.cep.pattern.Quantifier
 
optional() - Method in class org.apache.flink.cep.scala.pattern.Pattern
Specifies that this pattern is optional for a final match of the pattern sequence to happen.
OptionalBoolean - Class in org.apache.flink.graph.utils.proxy
A multi-state boolean.
OptionalBoolean(boolean, boolean) - Constructor for class org.apache.flink.graph.utils.proxy.OptionalBoolean
An OptionalBoolean has three possible states: true, false, and "unset".
OptionalBoolean.State - Enum in org.apache.flink.graph.utils.proxy
 
optionalMessage() - Method in class org.apache.flink.runtime.messages.ExecutionGraphMessages.ExecutionStateChanged
 
OptionDescriptor(int, scala.reflect.macros.Context.universe, TypeDescriptors<C>.UDTDescriptor) - Constructor for class org.apache.flink.api.scala.codegen.TypeDescriptors.OptionDescriptor
 
OptionSerializer<A> - Class in org.apache.flink.api.scala.typeutils
Serializer for Option.
OptionSerializer(TypeSerializer<A>) - Constructor for class org.apache.flink.api.scala.typeutils.OptionSerializer
 
OptionSerializer$ - Class in org.apache.flink.api.scala.typeutils
 
OptionSerializer$() - Constructor for class org.apache.flink.api.scala.typeutils.OptionSerializer$
 
OptionSerializer.OptionSerializerConfigSnapshot<A> - Class in org.apache.flink.api.scala.typeutils
We need to keep this to be compatible with snapshots taken in Flink 1.3.0.
OptionSerializer.OptionSerializerConfigSnapshot$ - Class in org.apache.flink.api.scala.typeutils
 
OptionSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.scala.typeutils.OptionSerializer.OptionSerializerConfigSnapshot
 
OptionSerializerConfigSnapshot$() - Constructor for class org.apache.flink.api.scala.typeutils.OptionSerializer.OptionSerializerConfigSnapshot$
 
OptionsFactory - Interface in org.apache.flink.contrib.streaming.state
A factory for DBOptions to be passed to the RocksDBStateBackend.
OptionType - Enum in org.apache.flink.api.java.utils
Types the parameters of managed with RequiredParameters can take.
OptionTypeComparator<A> - Class in org.apache.flink.api.scala.typeutils
Comparator for Option values.
OptionTypeComparator(boolean, TypeComparator<A>) - Constructor for class org.apache.flink.api.scala.typeutils.OptionTypeComparator
 
OptionTypeComparator$ - Class in org.apache.flink.api.scala.typeutils
 
OptionTypeComparator$() - Constructor for class org.apache.flink.api.scala.typeutils.OptionTypeComparator$
 
OptionTypeInfo<A,T extends scala.Option<A>> - Class in org.apache.flink.api.scala.typeutils
TypeInformation for Option.
OptionTypeInfo(TypeInformation<A>) - Constructor for class org.apache.flink.api.scala.typeutils.OptionTypeInfo
 
OR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Logical OR operator.
or(IterativeCondition<F>) - Method in class org.apache.flink.cep.pattern.Pattern
Adds a condition that has to be satisfied by an event in order to be considered a match.
or(IterativeCondition<F>) - Method in class org.apache.flink.cep.scala.pattern.Pattern
Adds a condition that has to be satisfied by an event in order to be considered a match.
or(Function1<F, Object>) - Method in class org.apache.flink.cep.scala.pattern.Pattern
Adds a condition that has to be satisfied by an event in order to be considered a match.
or(Function2<F, Context<F>, Object>) - Method in class org.apache.flink.cep.scala.pattern.Pattern
Adds a condition that has to be satisfied by an event in order to be considered a match.
or(RexNode[]) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
or(Iterable<? extends RexNode>) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
Or - Class in org.apache.flink.table.expressions
 
Or(Expression, Expression) - Constructor for class org.apache.flink.table.expressions.Or
 
Or$ - Class in org.apache.flink.table.expressions
 
Or$() - Constructor for class org.apache.flink.table.expressions.Or$
 
OrCondition<T> - Class in org.apache.flink.cep.pattern.conditions
A condition which combines two conditions with a logical OR and returns true if at least one is true.
OrCondition(IterativeCondition<T>, IterativeCondition<T>) - Constructor for class org.apache.flink.cep.pattern.conditions.OrCondition
 
Order - Enum in org.apache.flink.api.common.operators
Enumeration representing order.
Order() - Constructor for class org.apache.flink.examples.java.relational.TPCHQuery3.Order
 
Order(long, long, String, long) - Constructor for class org.apache.flink.examples.scala.relational.TPCHQuery3.Order
 
order - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
Order(long, String, int) - Constructor for class org.apache.flink.table.examples.scala.StreamSQLExample.Order
 
Order(long, String, int) - Constructor for class org.apache.flink.table.examples.scala.StreamTableExample.Order
 
Order(long, long, String, long) - Constructor for class org.apache.flink.table.examples.scala.TPCHQuery3Table.Order
 
order() - Method in class org.apache.flink.table.plan.logical.Sort
 
Order$() - Constructor for class org.apache.flink.examples.scala.relational.TPCHQuery3.Order$
 
Order$() - Constructor for class org.apache.flink.table.examples.scala.StreamSQLExample.Order$
 
Order$() - Constructor for class org.apache.flink.table.examples.scala.StreamTableExample.Order$
 
Order$() - Constructor for class org.apache.flink.table.examples.scala.TPCHQuery3Table.Order$
 
orderBy(String) - Method in class org.apache.flink.table.api.java.Over$
Specifies the time attribute on which rows are grouped.
orderBy(String) - Static method in class org.apache.flink.table.api.java.Over
Specifies the time attribute on which rows are grouped.
orderBy(String) - Method in class org.apache.flink.table.api.java.PartitionedOver
Specifies the time attribute on which rows are grouped.
orderBy() - Method in class org.apache.flink.table.api.OverWindow
 
orderBy(Expression) - Method in class org.apache.flink.table.api.scala.Over$
Specifies the time attribute on which rows are grouped.
orderBy(Expression) - Static method in class org.apache.flink.table.api.scala.Over
Specifies the time attribute on which rows are grouped.
orderBy() - Method in class org.apache.flink.table.api.scala.OverWindowWithOrderBy
 
orderBy(Expression) - Method in class org.apache.flink.table.api.scala.PartitionedOver
Specifies the time attribute on which rows are grouped.
orderBy(Seq<Expression>) - Method in class org.apache.flink.table.api.Table
Sorts the given Table.
orderBy(String) - Method in class org.apache.flink.table.api.Table
Sorts the given Table.
orderBy() - Method in class org.apache.flink.table.expressions.OverCall
 
orderDate() - Method in class org.apache.flink.examples.scala.relational.TPCHQuery3.Order
 
orderDate() - Method in class org.apache.flink.examples.scala.relational.TPCHQuery3.ShippedItem
 
orderDate() - Method in class org.apache.flink.table.examples.scala.TPCHQuery3Table.Order
 
OrderedStreamElementQueue - Class in org.apache.flink.streaming.api.operators.async.queue
Ordered StreamElementQueue implementation.
OrderedStreamElementQueue(int, Executor, OperatorActions) - Constructor for class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
 
orderedWait(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit, int) - Static method in class org.apache.flink.streaming.api.datastream.AsyncDataStream
Add an AsyncWaitOperator.
orderedWait(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit) - Static method in class org.apache.flink.streaming.api.datastream.AsyncDataStream
Add an AsyncWaitOperator.
orderedWait(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit, int, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.scala.AsyncDataStream$
Apply an asynchronous function on the input data stream.
orderedWait(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.scala.AsyncDataStream$
Apply an asynchronous function on the input data stream.
orderedWait(DataStream<IN>, long, TimeUnit, int, Function2<IN, AsyncCollector<OUT>, BoxedUnit>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.scala.AsyncDataStream$
Apply an asynchronous function on the input data stream.
orderedWait(DataStream<IN>, long, TimeUnit, Function2<IN, AsyncCollector<OUT>, BoxedUnit>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.scala.AsyncDataStream$
Apply an asynchronous function on the input data stream.
orderedWait(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit, int, TypeInformation<OUT>) - Static method in class org.apache.flink.streaming.api.scala.AsyncDataStream
Apply an asynchronous function on the input data stream.
orderedWait(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit, TypeInformation<OUT>) - Static method in class org.apache.flink.streaming.api.scala.AsyncDataStream
Apply an asynchronous function on the input data stream.
orderedWait(DataStream<IN>, long, TimeUnit, int, Function2<IN, AsyncCollector<OUT>, BoxedUnit>, TypeInformation<OUT>) - Static method in class org.apache.flink.streaming.api.scala.AsyncDataStream
Apply an asynchronous function on the input data stream.
orderedWait(DataStream<IN>, long, TimeUnit, Function2<IN, AsyncCollector<OUT>, BoxedUnit>, TypeInformation<OUT>) - Static method in class org.apache.flink.streaming.api.scala.AsyncDataStream
Apply an asynchronous function on the input data stream.
orderId() - Method in class org.apache.flink.examples.scala.relational.TPCHQuery3.Lineitem
 
orderId() - Method in class org.apache.flink.examples.scala.relational.TPCHQuery3.Order
 
orderId() - Method in class org.apache.flink.examples.scala.relational.TPCHQuery3.ShippedItem
 
orderId() - Method in class org.apache.flink.table.examples.scala.TPCHQuery3Table.Order
 
Ordering - Class in org.apache.flink.api.common.operators
This class represents an ordering on a set of fields.
Ordering() - Constructor for class org.apache.flink.api.common.operators.Ordering
Creates an empty ordering.
Ordering(int, Class<? extends Comparable<?>>, Order) - Constructor for class org.apache.flink.api.common.operators.Ordering
 
Ordering - Class in org.apache.flink.table.expressions
 
Ordering() - Constructor for class org.apache.flink.table.expressions.Ordering
 
orderingToString(RelDataType, List<RelFieldCollation>) - Method in interface org.apache.flink.table.plan.nodes.OverAggregate
 
orders - Variable in class org.apache.flink.api.common.operators.Ordering
 
orElse(ValidationResult) - Static method in class org.apache.flink.table.validate.ValidationFailure
 
orElse(ValidationResult) - Method in interface org.apache.flink.table.validate.ValidationResult
Allows constructing a cascade of validation results.
orElse(ValidationResult) - Static method in class org.apache.flink.table.validate.ValidationSuccess
 
OrFilterFunction<T> - Class in org.apache.flink.cep.pattern
Deprecated.
This is only used when migrating from an older Flink version. Use the OrCondition instead.

A filter function which combines two filter functions with a logical or. Thus, the filter function only returns true, iff at least one of the filter functions holds true.

OrFilterFunction(FilterFunction<T>, FilterFunction<T>) - Constructor for class org.apache.flink.cep.pattern.OrFilterFunction
Deprecated.
 
org.apache.calcite.sql.fun - package org.apache.calcite.sql.fun
 
org.apache.calcite.sql.validate - package org.apache.calcite.sql.validate
 
org.apache.calcite.sql2rel - package org.apache.calcite.sql2rel
 
org.apache.flink.addons.hbase - package org.apache.flink.addons.hbase
 
org.apache.flink.annotation - package org.apache.flink.annotation
 
org.apache.flink.api.avro - package org.apache.flink.api.avro
 
org.apache.flink.api.common - package org.apache.flink.api.common
 
org.apache.flink.api.common.accumulators - package org.apache.flink.api.common.accumulators
 
org.apache.flink.api.common.aggregators - package org.apache.flink.api.common.aggregators
 
org.apache.flink.api.common.cache - package org.apache.flink.api.common.cache
 
org.apache.flink.api.common.distributions - package org.apache.flink.api.common.distributions
 
org.apache.flink.api.common.functions - package org.apache.flink.api.common.functions
 
org.apache.flink.api.common.functions.util - package org.apache.flink.api.common.functions.util
 
org.apache.flink.api.common.io - package org.apache.flink.api.common.io
 
org.apache.flink.api.common.io.compression - package org.apache.flink.api.common.io.compression
 
org.apache.flink.api.common.io.statistics - package org.apache.flink.api.common.io.statistics
 
org.apache.flink.api.common.operators - package org.apache.flink.api.common.operators
 
org.apache.flink.api.common.operators.base - package org.apache.flink.api.common.operators.base
 
org.apache.flink.api.common.operators.util - package org.apache.flink.api.common.operators.util
 
org.apache.flink.api.common.restartstrategy - package org.apache.flink.api.common.restartstrategy
 
org.apache.flink.api.common.state - package org.apache.flink.api.common.state
 
org.apache.flink.api.common.time - package org.apache.flink.api.common.time
 
org.apache.flink.api.common.typeinfo - package org.apache.flink.api.common.typeinfo
 
org.apache.flink.api.common.typeutils - package org.apache.flink.api.common.typeutils
 
org.apache.flink.api.common.typeutils.base - package org.apache.flink.api.common.typeutils.base
 
org.apache.flink.api.common.typeutils.base.array - package org.apache.flink.api.common.typeutils.base.array
 
org.apache.flink.api.java - package org.apache.flink.api.java
 
org.apache.flink.api.java.aggregation - package org.apache.flink.api.java.aggregation
 
org.apache.flink.api.java.functions - package org.apache.flink.api.java.functions
 
org.apache.flink.api.java.hadoop.common - package org.apache.flink.api.java.hadoop.common
 
org.apache.flink.api.java.hadoop.mapred - package org.apache.flink.api.java.hadoop.mapred
 
org.apache.flink.api.java.hadoop.mapred.utils - package org.apache.flink.api.java.hadoop.mapred.utils
 
org.apache.flink.api.java.hadoop.mapred.wrapper - package org.apache.flink.api.java.hadoop.mapred.wrapper
 
org.apache.flink.api.java.hadoop.mapreduce - package org.apache.flink.api.java.hadoop.mapreduce
 
org.apache.flink.api.java.hadoop.mapreduce.utils - package org.apache.flink.api.java.hadoop.mapreduce.utils
 
org.apache.flink.api.java.hadoop.mapreduce.wrapper - package org.apache.flink.api.java.hadoop.mapreduce.wrapper
 
org.apache.flink.api.java.io - package org.apache.flink.api.java.io
 
org.apache.flink.api.java.io.jdbc - package org.apache.flink.api.java.io.jdbc
 
org.apache.flink.api.java.io.jdbc.split - package org.apache.flink.api.java.io.jdbc.split
 
org.apache.flink.api.java.operators - package org.apache.flink.api.java.operators
 
org.apache.flink.api.java.operators.join - package org.apache.flink.api.java.operators.join
 
org.apache.flink.api.java.operators.translation - package org.apache.flink.api.java.operators.translation
 
org.apache.flink.api.java.sampling - package org.apache.flink.api.java.sampling
 
org.apache.flink.api.java.sca - package org.apache.flink.api.java.sca
 
org.apache.flink.api.java.summarize - package org.apache.flink.api.java.summarize
 
org.apache.flink.api.java.summarize.aggregation - package org.apache.flink.api.java.summarize.aggregation
 
org.apache.flink.api.java.tuple - package org.apache.flink.api.java.tuple
 
org.apache.flink.api.java.tuple.builder - package org.apache.flink.api.java.tuple.builder
 
org.apache.flink.api.java.typeutils - package org.apache.flink.api.java.typeutils
 
org.apache.flink.api.java.typeutils.runtime - package org.apache.flink.api.java.typeutils.runtime
 
org.apache.flink.api.java.typeutils.runtime.kryo - package org.apache.flink.api.java.typeutils.runtime.kryo
 
org.apache.flink.api.java.utils - package org.apache.flink.api.java.utils
 
org.apache.flink.api.scala - package org.apache.flink.api.scala
 
org.apache.flink.api.scala.codegen - package org.apache.flink.api.scala.codegen
 
org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions - package org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions
 
org.apache.flink.api.scala.hadoop.mapred - package org.apache.flink.api.scala.hadoop.mapred
 
org.apache.flink.api.scala.hadoop.mapreduce - package org.apache.flink.api.scala.hadoop.mapreduce
 
org.apache.flink.api.scala.metrics - package org.apache.flink.api.scala.metrics
 
org.apache.flink.api.scala.operators - package org.apache.flink.api.scala.operators
 
org.apache.flink.api.scala.typeutils - package org.apache.flink.api.scala.typeutils
 
org.apache.flink.batch.connectors.cassandra - package org.apache.flink.batch.connectors.cassandra
 
org.apache.flink.cep - package org.apache.flink.cep
 
org.apache.flink.cep.nfa - package org.apache.flink.cep.nfa
 
org.apache.flink.cep.nfa.compiler - package org.apache.flink.cep.nfa.compiler
 
org.apache.flink.cep.operator - package org.apache.flink.cep.operator
 
org.apache.flink.cep.pattern - package org.apache.flink.cep.pattern
 
org.apache.flink.cep.pattern.conditions - package org.apache.flink.cep.pattern.conditions
 
org.apache.flink.cep.scala - package org.apache.flink.cep.scala
 
org.apache.flink.cep.scala.conditions - package org.apache.flink.cep.scala.conditions
 
org.apache.flink.cep.scala.pattern - package org.apache.flink.cep.scala.pattern
 
org.apache.flink.client - package org.apache.flink.client
 
org.apache.flink.client.cli - package org.apache.flink.client.cli
 
org.apache.flink.client.deployment - package org.apache.flink.client.deployment
 
org.apache.flink.client.program - package org.apache.flink.client.program
 
org.apache.flink.configuration - package org.apache.flink.configuration
 
org.apache.flink.contrib.streaming - package org.apache.flink.contrib.streaming
 
org.apache.flink.contrib.streaming.state - package org.apache.flink.contrib.streaming.state
 
org.apache.flink.contrib.tweetinputformat.io - package org.apache.flink.contrib.tweetinputformat.io
 
org.apache.flink.contrib.tweetinputformat.model.places - package org.apache.flink.contrib.tweetinputformat.model.places
 
org.apache.flink.contrib.tweetinputformat.model.tweet - package org.apache.flink.contrib.tweetinputformat.model.tweet
 
org.apache.flink.contrib.tweetinputformat.model.tweet.entities - package org.apache.flink.contrib.tweetinputformat.model.tweet.entities
 
org.apache.flink.contrib.tweetinputformat.model.User - package org.apache.flink.contrib.tweetinputformat.model.User
 
org.apache.flink.core.fs - package org.apache.flink.core.fs
 
org.apache.flink.core.fs.local - package org.apache.flink.core.fs.local
 
org.apache.flink.core.io - package org.apache.flink.core.io
 
org.apache.flink.core.memory - package org.apache.flink.core.memory
 
org.apache.flink.core.testutils - package org.apache.flink.core.testutils
 
org.apache.flink.dropwizard - package org.apache.flink.dropwizard
 
org.apache.flink.dropwizard.metrics - package org.apache.flink.dropwizard.metrics
 
org.apache.flink.examples.java.clustering - package org.apache.flink.examples.java.clustering
 
org.apache.flink.examples.java.clustering.util - package org.apache.flink.examples.java.clustering.util
 
org.apache.flink.examples.java.distcp - package org.apache.flink.examples.java.distcp
 
org.apache.flink.examples.java.graph - package org.apache.flink.examples.java.graph
 
org.apache.flink.examples.java.graph.util - package org.apache.flink.examples.java.graph.util
 
org.apache.flink.examples.java.misc - package org.apache.flink.examples.java.misc
 
org.apache.flink.examples.java.ml - package org.apache.flink.examples.java.ml
 
org.apache.flink.examples.java.ml.util - package org.apache.flink.examples.java.ml.util
 
org.apache.flink.examples.java.relational - package org.apache.flink.examples.java.relational
 
org.apache.flink.examples.java.relational.util - package org.apache.flink.examples.java.relational.util
 
org.apache.flink.examples.java.wordcount - package org.apache.flink.examples.java.wordcount
 
org.apache.flink.examples.java.wordcount.util - package org.apache.flink.examples.java.wordcount.util
 
org.apache.flink.examples.scala.clustering - package org.apache.flink.examples.scala.clustering
 
org.apache.flink.examples.scala.graph - package org.apache.flink.examples.scala.graph
 
org.apache.flink.examples.scala.misc - package org.apache.flink.examples.scala.misc
 
org.apache.flink.examples.scala.ml - package org.apache.flink.examples.scala.ml
 
org.apache.flink.examples.scala.relational - package org.apache.flink.examples.scala.relational
 
org.apache.flink.examples.scala.wordcount - package org.apache.flink.examples.scala.wordcount
 
org.apache.flink.graph - package org.apache.flink.graph
 
org.apache.flink.graph.asm.dataset - package org.apache.flink.graph.asm.dataset
 
org.apache.flink.graph.asm.degree.annotate - package org.apache.flink.graph.asm.degree.annotate
The degree annotation package provides a collection of edge-centric graph algorithms for counting the vertex degree of directed and undirected graphs.
org.apache.flink.graph.asm.degree.annotate.directed - package org.apache.flink.graph.asm.degree.annotate.directed
 
org.apache.flink.graph.asm.degree.annotate.undirected - package org.apache.flink.graph.asm.degree.annotate.undirected
 
org.apache.flink.graph.asm.degree.filter.undirected - package org.apache.flink.graph.asm.degree.filter.undirected
 
org.apache.flink.graph.asm.result - package org.apache.flink.graph.asm.result
 
org.apache.flink.graph.asm.simple.directed - package org.apache.flink.graph.asm.simple.directed
 
org.apache.flink.graph.asm.simple.undirected - package org.apache.flink.graph.asm.simple.undirected
 
org.apache.flink.graph.asm.translate - package org.apache.flink.graph.asm.translate
 
org.apache.flink.graph.asm.translate.translators - package org.apache.flink.graph.asm.translate.translators
 
org.apache.flink.graph.bipartite - package org.apache.flink.graph.bipartite
 
org.apache.flink.graph.drivers - package org.apache.flink.graph.drivers
 
org.apache.flink.graph.drivers.input - package org.apache.flink.graph.drivers.input
 
org.apache.flink.graph.drivers.output - package org.apache.flink.graph.drivers.output
 
org.apache.flink.graph.drivers.parameter - package org.apache.flink.graph.drivers.parameter
 
org.apache.flink.graph.examples - package org.apache.flink.graph.examples
 
org.apache.flink.graph.examples.data - package org.apache.flink.graph.examples.data
 
org.apache.flink.graph.generator - package org.apache.flink.graph.generator
 
org.apache.flink.graph.generator.random - package org.apache.flink.graph.generator.random
 
org.apache.flink.graph.gsa - package org.apache.flink.graph.gsa
 
org.apache.flink.graph.library - package org.apache.flink.graph.library
 
org.apache.flink.graph.library.clustering.directed - package org.apache.flink.graph.library.clustering.directed
 
org.apache.flink.graph.library.clustering.undirected - package org.apache.flink.graph.library.clustering.undirected
 
org.apache.flink.graph.library.link_analysis - package org.apache.flink.graph.library.link_analysis
 
org.apache.flink.graph.library.metric - package org.apache.flink.graph.library.metric
 
org.apache.flink.graph.library.metric.directed - package org.apache.flink.graph.library.metric.directed
 
org.apache.flink.graph.library.metric.undirected - package org.apache.flink.graph.library.metric.undirected
 
org.apache.flink.graph.library.similarity - package org.apache.flink.graph.library.similarity
 
org.apache.flink.graph.pregel - package org.apache.flink.graph.pregel
 
org.apache.flink.graph.scala - package org.apache.flink.graph.scala
 
org.apache.flink.graph.scala.examples - package org.apache.flink.graph.scala.examples
 
org.apache.flink.graph.scala.utils - package org.apache.flink.graph.scala.utils
 
org.apache.flink.graph.spargel - package org.apache.flink.graph.spargel
 
org.apache.flink.graph.types.valuearray - package org.apache.flink.graph.types.valuearray
 
org.apache.flink.graph.utils - package org.apache.flink.graph.utils
 
org.apache.flink.graph.utils.proxy - package org.apache.flink.graph.utils.proxy
 
org.apache.flink.graph.validation - package org.apache.flink.graph.validation
 
org.apache.flink.hadoopcompatibility - package org.apache.flink.hadoopcompatibility
 
org.apache.flink.hadoopcompatibility.mapred - package org.apache.flink.hadoopcompatibility.mapred
 
org.apache.flink.hadoopcompatibility.mapred.wrapper - package org.apache.flink.hadoopcompatibility.mapred.wrapper
 
org.apache.flink.hadoopcompatibility.scala - package org.apache.flink.hadoopcompatibility.scala
 
org.apache.flink.hcatalog - package org.apache.flink.hcatalog
 
org.apache.flink.hcatalog.java - package org.apache.flink.hcatalog.java
 
org.apache.flink.hcatalog.scala - package org.apache.flink.hcatalog.scala
 
org.apache.flink.mesos - package org.apache.flink.mesos
 
org.apache.flink.mesos.cli - package org.apache.flink.mesos.cli
 
org.apache.flink.mesos.runtime.clusterframework - package org.apache.flink.mesos.runtime.clusterframework
 
org.apache.flink.mesos.runtime.clusterframework.services - package org.apache.flink.mesos.runtime.clusterframework.services
 
org.apache.flink.mesos.runtime.clusterframework.store - package org.apache.flink.mesos.runtime.clusterframework.store
 
org.apache.flink.mesos.scheduler - package org.apache.flink.mesos.scheduler
 
org.apache.flink.mesos.scheduler.messages - package org.apache.flink.mesos.scheduler.messages
 
org.apache.flink.mesos.util - package org.apache.flink.mesos.util
 
org.apache.flink.metrics - package org.apache.flink.metrics
 
org.apache.flink.metrics.datadog - package org.apache.flink.metrics.datadog
 
org.apache.flink.metrics.ganglia - package org.apache.flink.metrics.ganglia
 
org.apache.flink.metrics.graphite - package org.apache.flink.metrics.graphite
 
org.apache.flink.metrics.groups - package org.apache.flink.metrics.groups
 
org.apache.flink.metrics.jmx - package org.apache.flink.metrics.jmx
 
org.apache.flink.metrics.reporter - package org.apache.flink.metrics.reporter
 
org.apache.flink.metrics.statsd - package org.apache.flink.metrics.statsd
 
org.apache.flink.metrics.util - package org.apache.flink.metrics.util
 
org.apache.flink.migration - package org.apache.flink.migration
 
org.apache.flink.migration.api.common.state - package org.apache.flink.migration.api.common.state
 
org.apache.flink.migration.contrib.streaming.state - package org.apache.flink.migration.contrib.streaming.state
 
org.apache.flink.migration.runtime.checkpoint - package org.apache.flink.migration.runtime.checkpoint
 
org.apache.flink.migration.runtime.checkpoint.savepoint - package org.apache.flink.migration.runtime.checkpoint.savepoint
 
org.apache.flink.migration.runtime.state - package org.apache.flink.migration.runtime.state
 
org.apache.flink.migration.runtime.state.filesystem - package org.apache.flink.migration.runtime.state.filesystem
 
org.apache.flink.migration.runtime.state.memory - package org.apache.flink.migration.runtime.state.memory
 
org.apache.flink.migration.state - package org.apache.flink.migration.state
 
org.apache.flink.migration.streaming.api.graph - package org.apache.flink.migration.streaming.api.graph
 
org.apache.flink.migration.streaming.runtime.streamrecord - package org.apache.flink.migration.streaming.runtime.streamrecord
 
org.apache.flink.migration.streaming.runtime.tasks - package org.apache.flink.migration.streaming.runtime.tasks
 
org.apache.flink.migration.util - package org.apache.flink.migration.util
 
org.apache.flink.ml - package org.apache.flink.ml
 
org.apache.flink.ml.classification - package org.apache.flink.ml.classification
 
org.apache.flink.ml.common - package org.apache.flink.ml.common
 
org.apache.flink.ml.math - package org.apache.flink.ml.math
 
org.apache.flink.ml.math.distributed - package org.apache.flink.ml.math.distributed
 
org.apache.flink.ml.metrics.distances - package org.apache.flink.ml.metrics.distances
 
org.apache.flink.ml.nn - package org.apache.flink.ml.nn
 
org.apache.flink.ml.optimization - package org.apache.flink.ml.optimization
 
org.apache.flink.ml.outlier - package org.apache.flink.ml.outlier
 
org.apache.flink.ml.pipeline - package org.apache.flink.ml.pipeline
 
org.apache.flink.ml.preprocessing - package org.apache.flink.ml.preprocessing
 
org.apache.flink.ml.recommendation - package org.apache.flink.ml.recommendation
 
org.apache.flink.ml.regression - package org.apache.flink.ml.regression
 
org.apache.flink.optimizer - package org.apache.flink.optimizer
 
org.apache.flink.optimizer.costs - package org.apache.flink.optimizer.costs
 
org.apache.flink.optimizer.dag - package org.apache.flink.optimizer.dag
 
org.apache.flink.optimizer.dataproperties - package org.apache.flink.optimizer.dataproperties
 
org.apache.flink.optimizer.operators - package org.apache.flink.optimizer.operators
 
org.apache.flink.optimizer.plan - package org.apache.flink.optimizer.plan
 
org.apache.flink.optimizer.plandump - package org.apache.flink.optimizer.plandump
 
org.apache.flink.optimizer.plantranslate - package org.apache.flink.optimizer.plantranslate
 
org.apache.flink.optimizer.postpass - package org.apache.flink.optimizer.postpass
 
org.apache.flink.optimizer.traversals - package org.apache.flink.optimizer.traversals
This package contains the various traversals over the program plan and the optimizer DAG (directed acyclic graph) that are made in the course of the optimization.
org.apache.flink.optimizer.util - package org.apache.flink.optimizer.util
 
org.apache.flink.python.api - package org.apache.flink.python.api
 
org.apache.flink.python.api.functions - package org.apache.flink.python.api.functions
 
org.apache.flink.python.api.functions.util - package org.apache.flink.python.api.functions.util
 
org.apache.flink.python.api.streaming.data - package org.apache.flink.python.api.streaming.data
 
org.apache.flink.python.api.streaming.plan - package org.apache.flink.python.api.streaming.plan
 
org.apache.flink.python.api.streaming.util - package org.apache.flink.python.api.streaming.util
 
org.apache.flink.python.api.types - package org.apache.flink.python.api.types
 
org.apache.flink.python.api.util - package org.apache.flink.python.api.util
 
org.apache.flink.runtime - package org.apache.flink.runtime
 
org.apache.flink.runtime.accumulators - package org.apache.flink.runtime.accumulators
 
org.apache.flink.runtime.akka - package org.apache.flink.runtime.akka
 
org.apache.flink.runtime.akka.serialization - package org.apache.flink.runtime.akka.serialization
 
org.apache.flink.runtime.blob - package org.apache.flink.runtime.blob
 
org.apache.flink.runtime.broadcast - package org.apache.flink.runtime.broadcast
 
org.apache.flink.runtime.checkpoint - package org.apache.flink.runtime.checkpoint
 
org.apache.flink.runtime.checkpoint.decline - package org.apache.flink.runtime.checkpoint.decline
 
org.apache.flink.runtime.checkpoint.hooks - package org.apache.flink.runtime.checkpoint.hooks
 
org.apache.flink.runtime.checkpoint.savepoint - package org.apache.flink.runtime.checkpoint.savepoint
 
org.apache.flink.runtime.client - package org.apache.flink.runtime.client
 
org.apache.flink.runtime.clusterframework - package org.apache.flink.runtime.clusterframework
This package contains the cluster resource management functionality.
org.apache.flink.runtime.clusterframework.messages - package org.apache.flink.runtime.clusterframework.messages
This package contains the actor messages that are sent between the cluster resource framework and the JobManager, as well as the generic messages sent between the cluster resource framework and the client.
org.apache.flink.runtime.clusterframework.overlays - package org.apache.flink.runtime.clusterframework.overlays
 
org.apache.flink.runtime.clusterframework.standalone - package org.apache.flink.runtime.clusterframework.standalone
 
org.apache.flink.runtime.clusterframework.types - package org.apache.flink.runtime.clusterframework.types
 
org.apache.flink.runtime.concurrent - package org.apache.flink.runtime.concurrent
 
org.apache.flink.runtime.concurrent.impl - package org.apache.flink.runtime.concurrent.impl
 
org.apache.flink.runtime.deployment - package org.apache.flink.runtime.deployment
 
org.apache.flink.runtime.event - package org.apache.flink.runtime.event
 
org.apache.flink.runtime.execution - package org.apache.flink.runtime.execution
 
org.apache.flink.runtime.execution.librarycache - package org.apache.flink.runtime.execution.librarycache
 
org.apache.flink.runtime.executiongraph - package org.apache.flink.runtime.executiongraph
 
org.apache.flink.runtime.executiongraph.failover - package org.apache.flink.runtime.executiongraph.failover
 
org.apache.flink.runtime.executiongraph.metrics - package org.apache.flink.runtime.executiongraph.metrics
This package contains classes implementing various metrics for the job execution, based on the Execution Graph.
org.apache.flink.runtime.executiongraph.restart - package org.apache.flink.runtime.executiongraph.restart
 
org.apache.flink.runtime.filecache - package org.apache.flink.runtime.filecache
 
org.apache.flink.runtime.fs.hdfs - package org.apache.flink.runtime.fs.hdfs
 
org.apache.flink.runtime.fs.maprfs - package org.apache.flink.runtime.fs.maprfs
 
org.apache.flink.runtime.heartbeat - package org.apache.flink.runtime.heartbeat
 
org.apache.flink.runtime.highavailability - package org.apache.flink.runtime.highavailability
 
org.apache.flink.runtime.highavailability.nonha - package org.apache.flink.runtime.highavailability.nonha
 
org.apache.flink.runtime.highavailability.nonha.embedded - package org.apache.flink.runtime.highavailability.nonha.embedded
 
org.apache.flink.runtime.highavailability.nonha.leaderelection - package org.apache.flink.runtime.highavailability.nonha.leaderelection
 
org.apache.flink.runtime.highavailability.nonha.standalone - package org.apache.flink.runtime.highavailability.nonha.standalone
 
org.apache.flink.runtime.highavailability.zookeeper - package org.apache.flink.runtime.highavailability.zookeeper
 
org.apache.flink.runtime.history - package org.apache.flink.runtime.history
 
org.apache.flink.runtime.instance - package org.apache.flink.runtime.instance
 
org.apache.flink.runtime.io.async - package org.apache.flink.runtime.io.async
 
org.apache.flink.runtime.io.disk - package org.apache.flink.runtime.io.disk
 
org.apache.flink.runtime.io.disk.iomanager - package org.apache.flink.runtime.io.disk.iomanager
 
org.apache.flink.runtime.io.network - package org.apache.flink.runtime.io.network
 
org.apache.flink.runtime.io.network.api - package org.apache.flink.runtime.io.network.api
 
org.apache.flink.runtime.io.network.api.reader - package org.apache.flink.runtime.io.network.api.reader
 
org.apache.flink.runtime.io.network.api.serialization - package org.apache.flink.runtime.io.network.api.serialization
 
org.apache.flink.runtime.io.network.api.writer - package org.apache.flink.runtime.io.network.api.writer
 
org.apache.flink.runtime.io.network.buffer - package org.apache.flink.runtime.io.network.buffer
 
org.apache.flink.runtime.io.network.netty - package org.apache.flink.runtime.io.network.netty
 
org.apache.flink.runtime.io.network.netty.exception - package org.apache.flink.runtime.io.network.netty.exception
 
org.apache.flink.runtime.io.network.partition - package org.apache.flink.runtime.io.network.partition
 
org.apache.flink.runtime.io.network.partition.consumer - package org.apache.flink.runtime.io.network.partition.consumer
 
org.apache.flink.runtime.iterative.concurrent - package org.apache.flink.runtime.iterative.concurrent
 
org.apache.flink.runtime.iterative.convergence - package org.apache.flink.runtime.iterative.convergence
 
org.apache.flink.runtime.iterative.event - package org.apache.flink.runtime.iterative.event
 
org.apache.flink.runtime.iterative.io - package org.apache.flink.runtime.iterative.io
 
org.apache.flink.runtime.iterative.task - package org.apache.flink.runtime.iterative.task
 
org.apache.flink.runtime.jobgraph - package org.apache.flink.runtime.jobgraph
 
org.apache.flink.runtime.jobgraph.jsonplan - package org.apache.flink.runtime.jobgraph.jsonplan
 
org.apache.flink.runtime.jobgraph.tasks - package org.apache.flink.runtime.jobgraph.tasks
 
org.apache.flink.runtime.jobmanager - package org.apache.flink.runtime.jobmanager
 
org.apache.flink.runtime.jobmanager.scheduler - package org.apache.flink.runtime.jobmanager.scheduler
 
org.apache.flink.runtime.jobmanager.slots - package org.apache.flink.runtime.jobmanager.slots
 
org.apache.flink.runtime.jobmaster - package org.apache.flink.runtime.jobmaster
 
org.apache.flink.runtime.jobmaster.message - package org.apache.flink.runtime.jobmaster.message
 
org.apache.flink.runtime.leaderelection - package org.apache.flink.runtime.leaderelection
 
org.apache.flink.runtime.leaderretrieval - package org.apache.flink.runtime.leaderretrieval
 
org.apache.flink.runtime.memory - package org.apache.flink.runtime.memory
 
org.apache.flink.runtime.messages - package org.apache.flink.runtime.messages
This package contains the messages that are sent between actors, like the JobManager and TaskManager to coordinate the distributed operations.
org.apache.flink.runtime.messages.accumulators - package org.apache.flink.runtime.messages.accumulators
 
org.apache.flink.runtime.messages.checkpoint - package org.apache.flink.runtime.messages.checkpoint
This package contains the messages that are sent between JobManager and TaskManager to coordinate the checkpoint snapshots of the distributed dataflow.
org.apache.flink.runtime.messages.webmonitor - package org.apache.flink.runtime.messages.webmonitor
This package contains the actor messages that are sent between the JobManager and components that are interested in the status of the JobManager.
org.apache.flink.runtime.metrics - package org.apache.flink.runtime.metrics
 
org.apache.flink.runtime.metrics.dump - package org.apache.flink.runtime.metrics.dump
 
org.apache.flink.runtime.metrics.groups - package org.apache.flink.runtime.metrics.groups
 
org.apache.flink.runtime.metrics.scope - package org.apache.flink.runtime.metrics.scope
 
org.apache.flink.runtime.metrics.util - package org.apache.flink.runtime.metrics.util
 
org.apache.flink.runtime.minicluster - package org.apache.flink.runtime.minicluster
 
org.apache.flink.runtime.net - package org.apache.flink.runtime.net
 
org.apache.flink.runtime.operators - package org.apache.flink.runtime.operators
 
org.apache.flink.runtime.operators.chaining - package org.apache.flink.runtime.operators.chaining
 
org.apache.flink.runtime.operators.hash - package org.apache.flink.runtime.operators.hash
 
org.apache.flink.runtime.operators.resettable - package org.apache.flink.runtime.operators.resettable
 
org.apache.flink.runtime.operators.shipping - package org.apache.flink.runtime.operators.shipping
 
org.apache.flink.runtime.operators.sort - package org.apache.flink.runtime.operators.sort
 
org.apache.flink.runtime.operators.udf - package org.apache.flink.runtime.operators.udf
 
org.apache.flink.runtime.operators.util - package org.apache.flink.runtime.operators.util
 
org.apache.flink.runtime.operators.util.metrics - package org.apache.flink.runtime.operators.util.metrics
 
org.apache.flink.runtime.plugable - package org.apache.flink.runtime.plugable
 
org.apache.flink.runtime.process - package org.apache.flink.runtime.process
 
org.apache.flink.runtime.query - package org.apache.flink.runtime.query
This package contains all KvState query related classes.
org.apache.flink.runtime.query.netty - package org.apache.flink.runtime.query.netty
This package contains all Netty-based client/server classes used to query KvState instances.
org.apache.flink.runtime.query.netty.message - package org.apache.flink.runtime.query.netty.message
 
org.apache.flink.runtime.registration - package org.apache.flink.runtime.registration
 
org.apache.flink.runtime.resourcemanager - package org.apache.flink.runtime.resourcemanager
 
org.apache.flink.runtime.resourcemanager.exceptions - package org.apache.flink.runtime.resourcemanager.exceptions
 
org.apache.flink.runtime.resourcemanager.registration - package org.apache.flink.runtime.resourcemanager.registration
 
org.apache.flink.runtime.resourcemanager.slotmanager - package org.apache.flink.runtime.resourcemanager.slotmanager
 
org.apache.flink.runtime.rpc - package org.apache.flink.runtime.rpc
 
org.apache.flink.runtime.rpc.akka - package org.apache.flink.runtime.rpc.akka
 
org.apache.flink.runtime.rpc.akka.exceptions - package org.apache.flink.runtime.rpc.akka.exceptions
 
org.apache.flink.runtime.rpc.akka.messages - package org.apache.flink.runtime.rpc.akka.messages
 
org.apache.flink.runtime.rpc.exceptions - package org.apache.flink.runtime.rpc.exceptions
 
org.apache.flink.runtime.security - package org.apache.flink.runtime.security
 
org.apache.flink.runtime.security.modules - package org.apache.flink.runtime.security.modules
 
org.apache.flink.runtime.state - package org.apache.flink.runtime.state
 
org.apache.flink.runtime.state.filesystem - package org.apache.flink.runtime.state.filesystem
 
org.apache.flink.runtime.state.heap - package org.apache.flink.runtime.state.heap
This package contains the classes for key/value state backends that store the state on the JVM heap as objects.
org.apache.flink.runtime.state.internal - package org.apache.flink.runtime.state.internal
This package holds the classes of the internal state type hierarchy.
org.apache.flink.runtime.state.memory - package org.apache.flink.runtime.state.memory
 
org.apache.flink.runtime.taskexecutor - package org.apache.flink.runtime.taskexecutor
 
org.apache.flink.runtime.taskexecutor.exceptions - package org.apache.flink.runtime.taskexecutor.exceptions
 
org.apache.flink.runtime.taskexecutor.rpc - package org.apache.flink.runtime.taskexecutor.rpc
 
org.apache.flink.runtime.taskexecutor.slot - package org.apache.flink.runtime.taskexecutor.slot
 
org.apache.flink.runtime.taskexecutor.utils - package org.apache.flink.runtime.taskexecutor.utils
 
org.apache.flink.runtime.taskmanager - package org.apache.flink.runtime.taskmanager
 
org.apache.flink.runtime.util - package org.apache.flink.runtime.util
 
org.apache.flink.runtime.util.clock - package org.apache.flink.runtime.util.clock
 
org.apache.flink.runtime.util.event - package org.apache.flink.runtime.util.event
 
org.apache.flink.runtime.webmonitor - package org.apache.flink.runtime.webmonitor
 
org.apache.flink.runtime.webmonitor.files - package org.apache.flink.runtime.webmonitor.files
 
org.apache.flink.runtime.webmonitor.handlers - package org.apache.flink.runtime.webmonitor.handlers
 
org.apache.flink.runtime.webmonitor.handlers.checkpoints - package org.apache.flink.runtime.webmonitor.handlers.checkpoints
 
org.apache.flink.runtime.webmonitor.history - package org.apache.flink.runtime.webmonitor.history
 
org.apache.flink.runtime.webmonitor.metrics - package org.apache.flink.runtime.webmonitor.metrics
 
org.apache.flink.runtime.webmonitor.utils - package org.apache.flink.runtime.webmonitor.utils
 
org.apache.flink.runtime.zookeeper - package org.apache.flink.runtime.zookeeper
 
org.apache.flink.runtime.zookeeper.filesystem - package org.apache.flink.runtime.zookeeper.filesystem
 
org.apache.flink.storm.api - package org.apache.flink.storm.api
 
org.apache.flink.storm.exclamation - package org.apache.flink.storm.exclamation
 
org.apache.flink.storm.exclamation.operators - package org.apache.flink.storm.exclamation.operators
 
org.apache.flink.storm.join - package org.apache.flink.storm.join
 
org.apache.flink.storm.print - package org.apache.flink.storm.print
 
org.apache.flink.storm.split - package org.apache.flink.storm.split
 
org.apache.flink.storm.split.operators - package org.apache.flink.storm.split.operators
 
org.apache.flink.storm.util - package org.apache.flink.storm.util
 
org.apache.flink.storm.wordcount - package org.apache.flink.storm.wordcount
 
org.apache.flink.storm.wordcount.operators - package org.apache.flink.storm.wordcount.operators
 
org.apache.flink.storm.wrappers - package org.apache.flink.storm.wrappers
 
org.apache.flink.streaming.api - package org.apache.flink.streaming.api
 
org.apache.flink.streaming.api.checkpoint - package org.apache.flink.streaming.api.checkpoint
 
org.apache.flink.streaming.api.collector.selector - package org.apache.flink.streaming.api.collector.selector
 
org.apache.flink.streaming.api.datastream - package org.apache.flink.streaming.api.datastream
 
org.apache.flink.streaming.api.environment - package org.apache.flink.streaming.api.environment
 
org.apache.flink.streaming.api.functions - package org.apache.flink.streaming.api.functions
 
org.apache.flink.streaming.api.functions.aggregation - package org.apache.flink.streaming.api.functions.aggregation
 
org.apache.flink.streaming.api.functions.async - package org.apache.flink.streaming.api.functions.async
 
org.apache.flink.streaming.api.functions.async.collector - package org.apache.flink.streaming.api.functions.async.collector
 
org.apache.flink.streaming.api.functions.co - package org.apache.flink.streaming.api.functions.co
 
org.apache.flink.streaming.api.functions.query - package org.apache.flink.streaming.api.functions.query
 
org.apache.flink.streaming.api.functions.sink - package org.apache.flink.streaming.api.functions.sink
 
org.apache.flink.streaming.api.functions.source - package org.apache.flink.streaming.api.functions.source
 
org.apache.flink.streaming.api.functions.timestamps - package org.apache.flink.streaming.api.functions.timestamps
 
org.apache.flink.streaming.api.functions.windowing - package org.apache.flink.streaming.api.functions.windowing
 
org.apache.flink.streaming.api.functions.windowing.delta - package org.apache.flink.streaming.api.functions.windowing.delta
 
org.apache.flink.streaming.api.functions.windowing.delta.extractor - package org.apache.flink.streaming.api.functions.windowing.delta.extractor
 
org.apache.flink.streaming.api.graph - package org.apache.flink.streaming.api.graph
 
org.apache.flink.streaming.api.operators - package org.apache.flink.streaming.api.operators
 
org.apache.flink.streaming.api.operators.async - package org.apache.flink.streaming.api.operators.async
 
org.apache.flink.streaming.api.operators.async.queue - package org.apache.flink.streaming.api.operators.async.queue
 
org.apache.flink.streaming.api.operators.co - package org.apache.flink.streaming.api.operators.co
 
org.apache.flink.streaming.api.scala - package org.apache.flink.streaming.api.scala
 
org.apache.flink.streaming.api.scala.async - package org.apache.flink.streaming.api.scala.async
 
org.apache.flink.streaming.api.scala.extensions.impl.acceptPartialFunctions - package org.apache.flink.streaming.api.scala.extensions.impl.acceptPartialFunctions
 
org.apache.flink.streaming.api.scala.function - package org.apache.flink.streaming.api.scala.function
 
org.apache.flink.streaming.api.scala.function.util - package org.apache.flink.streaming.api.scala.function.util
 
org.apache.flink.streaming.api.transformations - package org.apache.flink.streaming.api.transformations
 
org.apache.flink.streaming.api.watermark - package org.apache.flink.streaming.api.watermark
 
org.apache.flink.streaming.api.windowing.assigners - package org.apache.flink.streaming.api.windowing.assigners
 
org.apache.flink.streaming.api.windowing.evictors - package org.apache.flink.streaming.api.windowing.evictors
 
org.apache.flink.streaming.api.windowing.time - package org.apache.flink.streaming.api.windowing.time
 
org.apache.flink.streaming.api.windowing.triggers - package org.apache.flink.streaming.api.windowing.triggers
 
org.apache.flink.streaming.api.windowing.windows - package org.apache.flink.streaming.api.windowing.windows
 
org.apache.flink.streaming.connectors.cassandra - package org.apache.flink.streaming.connectors.cassandra
 
org.apache.flink.streaming.connectors.elasticsearch - package org.apache.flink.streaming.connectors.elasticsearch
 
org.apache.flink.streaming.connectors.elasticsearch.util - package org.apache.flink.streaming.connectors.elasticsearch.util
 
org.apache.flink.streaming.connectors.elasticsearch2 - package org.apache.flink.streaming.connectors.elasticsearch2
 
org.apache.flink.streaming.connectors.elasticsearch5 - package org.apache.flink.streaming.connectors.elasticsearch5
 
org.apache.flink.streaming.connectors.fs - package org.apache.flink.streaming.connectors.fs
 
org.apache.flink.streaming.connectors.fs.bucketing - package org.apache.flink.streaming.connectors.fs.bucketing
 
org.apache.flink.streaming.connectors.kafka - package org.apache.flink.streaming.connectors.kafka
 
org.apache.flink.streaming.connectors.kafka.config - package org.apache.flink.streaming.connectors.kafka.config
 
org.apache.flink.streaming.connectors.kafka.internal - package org.apache.flink.streaming.connectors.kafka.internal
 
org.apache.flink.streaming.connectors.kafka.internals - package org.apache.flink.streaming.connectors.kafka.internals
 
org.apache.flink.streaming.connectors.kafka.internals.metrics - package org.apache.flink.streaming.connectors.kafka.internals.metrics
 
org.apache.flink.streaming.connectors.kafka.partitioner - package org.apache.flink.streaming.connectors.kafka.partitioner
 
org.apache.flink.streaming.connectors.nifi - package org.apache.flink.streaming.connectors.nifi
 
org.apache.flink.streaming.connectors.rabbitmq - package org.apache.flink.streaming.connectors.rabbitmq
 
org.apache.flink.streaming.connectors.rabbitmq.common - package org.apache.flink.streaming.connectors.rabbitmq.common
 
org.apache.flink.streaming.connectors.twitter - package org.apache.flink.streaming.connectors.twitter
 
org.apache.flink.streaming.connectors.wikiedits - package org.apache.flink.streaming.connectors.wikiedits
 
org.apache.flink.streaming.examples.async - package org.apache.flink.streaming.examples.async
 
org.apache.flink.streaming.examples.iteration - package org.apache.flink.streaming.examples.iteration
 
org.apache.flink.streaming.examples.iteration.util - package org.apache.flink.streaming.examples.iteration.util
 
org.apache.flink.streaming.examples.join - package org.apache.flink.streaming.examples.join
 
org.apache.flink.streaming.examples.kafka - package org.apache.flink.streaming.examples.kafka
 
org.apache.flink.streaming.examples.ml - package org.apache.flink.streaming.examples.ml
 
org.apache.flink.streaming.examples.ml.util - package org.apache.flink.streaming.examples.ml.util
 
org.apache.flink.streaming.examples.sideoutput - package org.apache.flink.streaming.examples.sideoutput
 
org.apache.flink.streaming.examples.socket - package org.apache.flink.streaming.examples.socket
 
org.apache.flink.streaming.examples.twitter - package org.apache.flink.streaming.examples.twitter
 
org.apache.flink.streaming.examples.twitter.util - package org.apache.flink.streaming.examples.twitter.util
 
org.apache.flink.streaming.examples.utils - package org.apache.flink.streaming.examples.utils
 
org.apache.flink.streaming.examples.windowing - package org.apache.flink.streaming.examples.windowing
 
org.apache.flink.streaming.examples.windowing.util - package org.apache.flink.streaming.examples.windowing.util
 
org.apache.flink.streaming.examples.wordcount - package org.apache.flink.streaming.examples.wordcount
 
org.apache.flink.streaming.runtime.io - package org.apache.flink.streaming.runtime.io
 
org.apache.flink.streaming.runtime.operators - package org.apache.flink.streaming.runtime.operators
This package contains the operators that perform the stream transformations.
org.apache.flink.streaming.runtime.operators.windowing - package org.apache.flink.streaming.runtime.operators.windowing
This package contains the operators that implement the various window operations on data streams.
org.apache.flink.streaming.runtime.operators.windowing.functions - package org.apache.flink.streaming.runtime.operators.windowing.functions
 
org.apache.flink.streaming.runtime.partitioner - package org.apache.flink.streaming.runtime.partitioner
 
org.apache.flink.streaming.runtime.streamrecord - package org.apache.flink.streaming.runtime.streamrecord
 
org.apache.flink.streaming.runtime.streamstatus - package org.apache.flink.streaming.runtime.streamstatus
 
org.apache.flink.streaming.runtime.tasks - package org.apache.flink.streaming.runtime.tasks
This package contains classes that realize streaming tasks.
org.apache.flink.streaming.scala.examples.async - package org.apache.flink.streaming.scala.examples.async
 
org.apache.flink.streaming.scala.examples.join - package org.apache.flink.streaming.scala.examples.join
 
org.apache.flink.streaming.scala.examples.socket - package org.apache.flink.streaming.scala.examples.socket
 
org.apache.flink.streaming.scala.examples.windowing - package org.apache.flink.streaming.scala.examples.windowing
 
org.apache.flink.streaming.util - package org.apache.flink.streaming.util
 
org.apache.flink.streaming.util.functions - package org.apache.flink.streaming.util.functions
 
org.apache.flink.streaming.util.keys - package org.apache.flink.streaming.util.keys
 
org.apache.flink.streaming.util.serialization - package org.apache.flink.streaming.util.serialization
 
org.apache.flink.streaming.util.typeutils - package org.apache.flink.streaming.util.typeutils
 
org.apache.flink.table.annotation - package org.apache.flink.table.annotation
 
org.apache.flink.table.api - package org.apache.flink.table.api
 
org.apache.flink.table.api.java - package org.apache.flink.table.api.java
Table API (Java)
A BatchTableEnvironment can be used to create a Table from a DataSet.
org.apache.flink.table.api.scala - package org.apache.flink.table.api.scala
 
org.apache.flink.table.calcite - package org.apache.flink.table.calcite
 
org.apache.flink.table.catalog - package org.apache.flink.table.catalog
 
org.apache.flink.table.codegen - package org.apache.flink.table.codegen
 
org.apache.flink.table.codegen.calls - package org.apache.flink.table.codegen.calls
 
org.apache.flink.table.examples.java - package org.apache.flink.table.examples.java
 
org.apache.flink.table.examples.scala - package org.apache.flink.table.examples.scala
 
org.apache.flink.table.explain - package org.apache.flink.table.explain
 
org.apache.flink.table.expressions - package org.apache.flink.table.expressions
 
org.apache.flink.table.functions - package org.apache.flink.table.functions
 
org.apache.flink.table.functions.aggfunctions - package org.apache.flink.table.functions.aggfunctions
 
org.apache.flink.table.functions.utils - package org.apache.flink.table.functions.utils
 
org.apache.flink.table.plan - package org.apache.flink.table.plan
 
org.apache.flink.table.plan.cost - package org.apache.flink.table.plan.cost
 
org.apache.flink.table.plan.logical - package org.apache.flink.table.plan.logical
 
org.apache.flink.table.plan.logical.rel - package org.apache.flink.table.plan.logical.rel
 
org.apache.flink.table.plan.nodes - package org.apache.flink.table.plan.nodes
 
org.apache.flink.table.plan.nodes.dataset - package org.apache.flink.table.plan.nodes.dataset
 
org.apache.flink.table.plan.nodes.datastream - package org.apache.flink.table.plan.nodes.datastream
 
org.apache.flink.table.plan.nodes.logical - package org.apache.flink.table.plan.nodes.logical
 
org.apache.flink.table.plan.rules - package org.apache.flink.table.plan.rules
 
org.apache.flink.table.plan.rules.common - package org.apache.flink.table.plan.rules.common
 
org.apache.flink.table.plan.rules.dataSet - package org.apache.flink.table.plan.rules.dataSet
 
org.apache.flink.table.plan.rules.datastream - package org.apache.flink.table.plan.rules.datastream
 
org.apache.flink.table.plan.rules.logical - package org.apache.flink.table.plan.rules.logical
 
org.apache.flink.table.plan.schema - package org.apache.flink.table.plan.schema
 
org.apache.flink.table.plan.stats - package org.apache.flink.table.plan.stats
 
org.apache.flink.table.plan.util - package org.apache.flink.table.plan.util
 
org.apache.flink.table.runtime - package org.apache.flink.table.runtime
 
org.apache.flink.table.runtime.aggregate - package org.apache.flink.table.runtime.aggregate
 
org.apache.flink.table.runtime.io - package org.apache.flink.table.runtime.io
 
org.apache.flink.table.runtime.triggers - package org.apache.flink.table.runtime.triggers
 
org.apache.flink.table.runtime.types - package org.apache.flink.table.runtime.types
 
org.apache.flink.table.sinks - package org.apache.flink.table.sinks
 
org.apache.flink.table.sources - package org.apache.flink.table.sources
 
org.apache.flink.table.typeutils - package org.apache.flink.table.typeutils
 
org.apache.flink.table.util - package org.apache.flink.table.util
 
org.apache.flink.table.validate - package org.apache.flink.table.validate
 
org.apache.flink.test.testdata - package org.apache.flink.test.testdata
 
org.apache.flink.test.util - package org.apache.flink.test.util
 
org.apache.flink.testutils.junit - package org.apache.flink.testutils.junit
 
org.apache.flink.types - package org.apache.flink.types
 
org.apache.flink.types.parser - package org.apache.flink.types.parser
 
org.apache.flink.util - package org.apache.flink.util
 
org.apache.flink.yarn - package org.apache.flink.yarn
 
org.apache.flink.yarn.cli - package org.apache.flink.yarn.cli
 
org.apache.flink.yarn.configuration - package org.apache.flink.yarn.configuration
 
org.apache.flink.yarn.highavailability - package org.apache.flink.yarn.highavailability
 
org.apache.flink.yarn.messages - package org.apache.flink.yarn.messages
 
originalConfiguration() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
otherID - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
out - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
out() - Method in class org.apache.flink.table.runtime.CRowWrappingCollector
 
OutBlockInformation(long[], ALS.OutLinks) - Constructor for class org.apache.flink.ml.recommendation.ALS.OutBlockInformation
 
OutBlockInformation$() - Constructor for class org.apache.flink.ml.recommendation.ALS.OutBlockInformation$
 
outChannels - Variable in class org.apache.flink.optimizer.plan.PlanNode
 
outCRow() - Method in class org.apache.flink.table.runtime.CRowWrappingCollector
 
outDegrees() - Method in class org.apache.flink.graph.Graph
Return the out-degree of all vertices in the graph
outDegrees() - Method in class org.apache.flink.graph.scala.Graph
Return the out-degree of all vertices in the graph
outer(Vector) - Method in class org.apache.flink.ml.math.DenseVector
Returns the outer product (a.k.a.
outer(Vector) - Method in class org.apache.flink.ml.math.SparseVector
Returns the outer product (a.k.a.
outer(Vector) - Method in interface org.apache.flink.ml.math.Vector
Returns the outer product of the recipient and the argument
outerJoinIterator - Variable in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
OuterJoinNode - Class in org.apache.flink.optimizer.dag
 
OuterJoinNode(OuterJoinOperatorBase<?, ?, ?, ?>) - Constructor for class org.apache.flink.optimizer.dag.OuterJoinNode
Creates a new two input node for the optimizer plan, representing the given operator.
OuterJoinOperatorBase<IN1,IN2,OUT,FT extends FlatJoinFunction<IN1,IN2,OUT>> - Class in org.apache.flink.api.common.operators.base
 
OuterJoinOperatorBase(UserCodeWrapper<FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String, OuterJoinOperatorBase.OuterJoinType) - Constructor for class org.apache.flink.api.common.operators.base.OuterJoinOperatorBase
 
OuterJoinOperatorBase(FT, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String, OuterJoinOperatorBase.OuterJoinType) - Constructor for class org.apache.flink.api.common.operators.base.OuterJoinOperatorBase
 
OuterJoinOperatorBase(Class<? extends FT>, BinaryOperatorInformation<IN1, IN2, OUT>, int[], int[], String, OuterJoinOperatorBase.OuterJoinType) - Constructor for class org.apache.flink.api.common.operators.base.OuterJoinOperatorBase
 
OuterJoinOperatorBase.OuterJoinType - Enum in org.apache.flink.api.common.operators.base
 
outerProduct(double[], double[], int) - Method in class org.apache.flink.ml.recommendation.ALS$
 
outerProduct(double[], double[], int) - Static method in class org.apache.flink.ml.recommendation.ALS
 
outLinks() - Method in class org.apache.flink.ml.recommendation.ALS.OutBlockInformation
 
OutLinks(BitSet[]) - Constructor for class org.apache.flink.ml.recommendation.ALS.OutLinks
 
OutLinks() - Constructor for class org.apache.flink.ml.recommendation.ALS.OutLinks
 
outPrinter - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
output(OutputFormat<T>) - Method in class org.apache.flink.api.java.DataSet
Emits a DataSet using an OutputFormat.
output(OutputFormat<T>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
output(OutputFormat<T>) - Method in class org.apache.flink.api.scala.DataSet
Emits this DataSet using a custom OutputFormat.
output - Variable in class org.apache.flink.runtime.operators.BatchTask
The collector that forwards the user code's results.
output(OutputTag<X>, X) - Method in class org.apache.flink.streaming.api.functions.ProcessFunction.Context
Emits a record to the side output identified by the OutputTag.
output - Variable in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
Output<T> - Interface in org.apache.flink.streaming.api.operators
A StreamOperator is supplied with an object of this interface that can be used to emit elements and other messages, such as barriers and watermarks, from an operator.
output() - Method in class org.apache.flink.table.plan.logical.Aggregate
 
output() - Method in class org.apache.flink.table.plan.logical.AliasNode
 
output() - Method in class org.apache.flink.table.plan.logical.CatalogNode
 
output() - Method in class org.apache.flink.table.plan.logical.Distinct
 
output() - Method in class org.apache.flink.table.plan.logical.Filter
 
output() - Method in class org.apache.flink.table.plan.logical.Intersect
 
output() - Method in class org.apache.flink.table.plan.logical.Join
 
output() - Method in class org.apache.flink.table.plan.logical.Limit
 
output() - Method in class org.apache.flink.table.plan.logical.LogicalNode
 
output() - Method in class org.apache.flink.table.plan.logical.LogicalRelNode
 
output() - Method in class org.apache.flink.table.plan.logical.LogicalTableFunctionCall
 
output() - Method in class org.apache.flink.table.plan.logical.Minus
 
output() - Method in class org.apache.flink.table.plan.logical.Project
 
output() - Method in class org.apache.flink.table.plan.logical.Sort
 
output() - Method in class org.apache.flink.table.plan.logical.Union
 
output() - Method in class org.apache.flink.table.plan.logical.WindowAggregate
 
output() - Method in class org.apache.flink.table.runtime.aggregate.RowTimeUnboundedOver
 
output() - Method in class org.apache.flink.table.runtime.aggregate.TimeWindowPropertyCollector
 
outputCollector - Variable in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
OutputCollector<T> - Class in org.apache.flink.runtime.operators.shipping
The OutputCollector collects records, and emits them to the RecordWriters.
OutputCollector(List<RecordWriter<SerializationDelegate<T>>>, TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.operators.shipping.OutputCollector
Initializes the output collector with a set of writers.
outputCommitter - Variable in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
 
outputCommitter - Variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
 
OutputDecisionFunction$() - Constructor for class org.apache.flink.ml.classification.SVM.OutputDecisionFunction$
 
OutputEmitter<T> - Class in org.apache.flink.runtime.operators.shipping
The output emitter decides to which of the possibly multiple output channels a record is sent.
OutputEmitter(ShipStrategyType, int) - Constructor for class org.apache.flink.runtime.operators.shipping.OutputEmitter
Creates a new channel selector that uses the given strategy (broadcasting, partitioning, ...) and uses the supplied task index perform a round robin distribution.
OutputEmitter(ShipStrategyType, TypeComparator<T>) - Constructor for class org.apache.flink.runtime.operators.shipping.OutputEmitter
Creates a new channel selector that uses the given strategy (broadcasting, partitioning, ...) and uses the supplied comparator to hash / compare records for partitioning them deterministically.
OutputEmitter(ShipStrategyType, int, TypeComparator<T>, Partitioner<?>, DataDistribution) - Constructor for class org.apache.flink.runtime.operators.shipping.OutputEmitter
 
outputFilePath - Variable in class org.apache.flink.api.common.io.FileOutputFormat
The path of the file to be written.
OutputFormat<IT> - Interface in org.apache.flink.api.common.io
The base interface for outputs that consumes records.
OutputFormatSinkFunction<IN> - Class in org.apache.flink.streaming.api.functions.sink
Simple implementation of the SinkFunction writing tuples in the specified OutputFormat format.
OutputFormatSinkFunction(OutputFormat<IN>) - Constructor for class org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
 
OutputFormatter - Interface in org.apache.flink.storm.util
 
OutputFormatVertex - Class in org.apache.flink.runtime.jobgraph
A task vertex that run an initialization on the master, trying to deserialize an output format and initializing it on master, if necessary.
OutputFormatVertex(String) - Constructor for class org.apache.flink.runtime.jobgraph.OutputFormatVertex
Creates a new task vertex with the specified name.
outputMap - Variable in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
OutputMap() - Constructor for class org.apache.flink.streaming.examples.iteration.IterateExample.OutputMap
 
outputSchema - Variable in class org.apache.flink.hcatalog.HCatInputFormatBase
 
OutputSelector<OUT> - Interface in org.apache.flink.streaming.api.collector.selector
Interface for defining an OutputSelector for a SplitStream using the DataStream.split(org.apache.flink.streaming.api.collector.selector.OutputSelector<T>) call.
outputSelectors - Variable in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
outputStream - Variable in class org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
OutputTag<T> - Class in org.apache.flink.streaming.api.scala
An OutputTag is a typed and named tag to use for tagging side outputs of an operator.
OutputTag(String, TypeInformation<T>) - Constructor for class org.apache.flink.streaming.api.scala.OutputTag
 
OutputTag<T> - Class in org.apache.flink.util
An OutputTag is a typed and named tag to use for tagging side outputs of an operator.
OutputTag(String) - Constructor for class org.apache.flink.util.OutputTag
Creates a new named OutputTag with the given id.
OutputTag(String, TypeInformation<T>) - Constructor for class org.apache.flink.util.OutputTag
Creates a new named OutputTag with the given id and output TypeInformation.
OutputTag$ - Class in org.apache.flink.streaming.api.scala
 
OutputTag$() - Constructor for class org.apache.flink.streaming.api.scala.OutputTag$
 
outputType - Variable in class org.apache.flink.api.common.operators.OperatorInformation
Output type of the operator
outputType - Variable in class org.apache.flink.streaming.api.transformations.StreamTransformation
 
OutputTypeConfigurable<OUT> - Interface in org.apache.flink.streaming.api.operators
Stream operators can implement this interface if they need access to the output type information at StreamGraph generation.
outputView - Variable in class org.apache.flink.api.java.typeutils.runtime.DataOutputViewStream
 
outRecordTerm() - Method in class org.apache.flink.table.codegen.CodeGenerator
 
OVER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The OVER operator, which applies an aggregate functions to a window.
Over - Class in org.apache.flink.table.api.java
Helper object for creating a over window.
Over() - Constructor for class org.apache.flink.table.api.java.Over
 
over(String) - Method in class org.apache.flink.table.api.java.Slide$
Creates a sliding window.
over(String) - Static method in class org.apache.flink.table.api.java.Slide
Creates a sliding window.
over(String) - Method in class org.apache.flink.table.api.java.Tumble$
Creates a tumbling window.
over(String) - Static method in class org.apache.flink.table.api.java.Tumble
Creates a tumbling window.
over(Expression) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
For windowing function to config over window e.g.: table .window(Over partitionBy 'c orderBy 'rowtime preceding 2.rows following CURRENT_ROW as 'w) .select('c, 'a, 'a.count over 'w, 'a.sum over 'w)
Over - Class in org.apache.flink.table.api.scala
Helper object for creating a over window.
Over() - Constructor for class org.apache.flink.table.api.scala.Over
 
over(Expression) - Method in class org.apache.flink.table.api.scala.Slide$
Creates a sliding window.
over(Expression) - Static method in class org.apache.flink.table.api.scala.Slide
Creates a sliding window.
over(Expression) - Method in class org.apache.flink.table.api.scala.Tumble$
Creates a tumbling window.
over(Expression) - Static method in class org.apache.flink.table.api.scala.Tumble
Creates a tumbling window.
OVER() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
over() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
OVER() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
over() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
Over$ - Class in org.apache.flink.table.api.java
Helper object for creating a over window.
Over$() - Constructor for class org.apache.flink.table.api.java.Over$
 
Over$ - Class in org.apache.flink.table.api.scala
Helper object for creating a over window.
Over$() - Constructor for class org.apache.flink.table.api.scala.Over$
 
OverAggregate - Interface in org.apache.flink.table.plan.nodes
 
OverCall - Class in org.apache.flink.table.expressions
Over expression for Calcite over transform.
OverCall(Expression, Seq<Expression>, Expression, Expression, Expression) - Constructor for class org.apache.flink.table.expressions.OverCall
 
OverCall$ - Class in org.apache.flink.table.expressions
 
OverCall$() - Constructor for class org.apache.flink.table.expressions.OverCall$
 
overConstant() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
overConstant() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
overflowSegments - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
 
overflowSegments - Variable in class org.apache.flink.runtime.operators.hash.InMemoryPartition
 
overlap(Vector, double) - Method in class org.apache.flink.ml.nn.QuadTree.Node
Tests if queryPoint is within a radius of the node
OVERLAPS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
overlaps(CirculantGraph.OffsetRange) - Method in class org.apache.flink.graph.generator.CirculantGraph.OffsetRange
Return true if and only if the other range and this range share a common offset ID.
OVERLAY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
overlay(Expression, Expression) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Replaces a substring of string with a string starting at a position (starting at 1).
overlay(Expression, Expression, Expression) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Replaces a substring of string with a string starting at a position (starting at 1).
Overlay - Class in org.apache.flink.table.expressions
Replaces a substring of a string with a replacement string.
Overlay(Expression, Expression, Expression, Expression) - Constructor for class org.apache.flink.table.expressions.Overlay
 
Overlay(Expression, Expression, Expression) - Constructor for class org.apache.flink.table.expressions.Overlay
 
Overlay$ - Class in org.apache.flink.table.expressions
 
Overlay$() - Constructor for class org.apache.flink.table.expressions.Overlay$
 
OverWindow - Class in org.apache.flink.table.api
Over window is similar to the traditional OVER SQL.
OverWindow(Expression, Seq<Expression>, Expression, Expression, Expression) - Constructor for class org.apache.flink.table.api.OverWindow
 
OverWindow$ - Class in org.apache.flink.table.api
 
OverWindow$() - Constructor for class org.apache.flink.table.api.OverWindow$
 
OverWindowedTable - Class in org.apache.flink.table.api
 
OverWindowedTable(Table, OverWindow[]) - Constructor for class org.apache.flink.table.api.OverWindowedTable
 
overWindows() - Method in class org.apache.flink.table.api.OverWindowedTable
 
OverWindowWithOrderBy - Class in org.apache.flink.table.api.java
 
OverWindowWithOrderBy(Expression[], Expression) - Constructor for class org.apache.flink.table.api.java.OverWindowWithOrderBy
 
OverWindowWithOrderBy - Class in org.apache.flink.table.api.scala
 
OverWindowWithOrderBy(Seq<Expression>, Expression) - Constructor for class org.apache.flink.table.api.scala.OverWindowWithOrderBy
 
OverWindowWithOrderBy$ - Class in org.apache.flink.table.api.scala
 
OverWindowWithOrderBy$() - Constructor for class org.apache.flink.table.api.scala.OverWindowWithOrderBy$
 
OverWindowWithPreceding - Class in org.apache.flink.table.api
A partially defined over window.
OverWindowWithPreceding(Seq<Expression>, Expression, Expression) - Constructor for class org.apache.flink.table.api.OverWindowWithPreceding
 
overwriteRecordAt(long, T) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
Deprecated.
Don't use this, overwrites record and causes inconsistency or data loss for overwriting everything but records of the exact same size

P

p() - Method in class org.apache.flink.ml.metrics.distances.MinkowskiDistanceMetric
 
p75 - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
p90 - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
p95 - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
p98 - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
p99 - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
p999 - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
PackagedProgram - Class in org.apache.flink.client.program
This class encapsulates represents a program, packaged in a jar file.
PackagedProgram(File, String...) - Constructor for class org.apache.flink.client.program.PackagedProgram
Creates an instance that wraps the plan defined in the jar file using the given argument.
PackagedProgram(File, List<URL>, String...) - Constructor for class org.apache.flink.client.program.PackagedProgram
Creates an instance that wraps the plan defined in the jar file using the given argument.
PackagedProgram(File, String, String...) - Constructor for class org.apache.flink.client.program.PackagedProgram
Creates an instance that wraps the plan defined in the jar file using the given arguments.
PackagedProgram(File, List<URL>, String, String...) - Constructor for class org.apache.flink.client.program.PackagedProgram
Creates an instance that wraps the plan defined in the jar file using the given arguments.
PACT - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
 
Page(long, double) - Constructor for class org.apache.flink.examples.scala.graph.PageRankBasic.Page
 
Page$() - Constructor for class org.apache.flink.examples.scala.graph.PageRankBasic.Page$
 
pageId() - Method in class org.apache.flink.examples.scala.graph.PageRankBasic.Page
 
PageRank - Class in org.apache.flink.examples.java.graph
A basic implementation of the Page Rank algorithm using a bulk iteration.
PageRank() - Constructor for class org.apache.flink.examples.java.graph.PageRank
 
PageRank<K,VV,EV> - Class in org.apache.flink.graph.drivers
 
PageRank() - Constructor for class org.apache.flink.graph.drivers.PageRank
 
PageRank<K> - Class in org.apache.flink.graph.examples
This is an implementation of a simple PageRank algorithm, using a scatter-gather iteration.
PageRank(double, int) - Constructor for class org.apache.flink.graph.examples.PageRank
Creates an instance of the PageRank algorithm.
PageRank<K,VV,EV> - Class in org.apache.flink.graph.library.link_analysis
PageRank computes a per-vertex score which is the sum of PageRank scores transmitted over in-edges.
PageRank(double, int) - Constructor for class org.apache.flink.graph.library.link_analysis.PageRank
PageRank with a fixed number of iterations.
PageRank(double, double) - Constructor for class org.apache.flink.graph.library.link_analysis.PageRank
PageRank with a convergence threshold.
PageRank(double, int, double) - Constructor for class org.apache.flink.graph.library.link_analysis.PageRank
PageRank with a convergence threshold and a maximum iteration count.
PageRank.BuildOutgoingEdgeList - Class in org.apache.flink.examples.java.graph
A reduce function that takes a sequence of edges and builds the adjacency list for the vertex where the edges originate.
PageRank.Dampener - Class in org.apache.flink.examples.java.graph
The function that applies the page rank dampening formula
PageRank.EpsilonFilter - Class in org.apache.flink.examples.java.graph
Filter that filters vertices where the rank difference is below a threshold.
PageRank.JoinVertexWithEdgesMatch - Class in org.apache.flink.examples.java.graph
Join function that distributes a fraction of a vertex's rank to all neighbors.
PageRank.RankAssigner - Class in org.apache.flink.examples.java.graph
A map function that assigns an initial rank to all pages.
PageRank.RankMessenger<K> - Class in org.apache.flink.graph.examples
Distributes the rank of a vertex among all target vertices according to the transition probability, which is associated with an edge as the edge value.
PageRank.Result<T> - Class in org.apache.flink.graph.library.link_analysis
Wraps the Tuple2 to encapsulate results from the PageRank algorithm.
PageRank.VertexRankUpdater<K> - Class in org.apache.flink.graph.examples
Function that updates the rank of a vertex by summing up the partial ranks from all incoming messages and then applying the dampening formula.
PageRankBasic - Class in org.apache.flink.examples.scala.graph
A basic implementation of the Page Rank algorithm using a bulk iteration.
PageRankBasic() - Constructor for class org.apache.flink.examples.scala.graph.PageRankBasic
 
PageRankBasic$ - Class in org.apache.flink.examples.scala.graph
A basic implementation of the Page Rank algorithm using a bulk iteration.
PageRankBasic$() - Constructor for class org.apache.flink.examples.scala.graph.PageRankBasic$
 
PageRankBasic.AdjacencyList - Class in org.apache.flink.examples.scala.graph
 
PageRankBasic.AdjacencyList$ - Class in org.apache.flink.examples.scala.graph
 
PageRankBasic.Link - Class in org.apache.flink.examples.scala.graph
 
PageRankBasic.Link$ - Class in org.apache.flink.examples.scala.graph
 
PageRankBasic.Page - Class in org.apache.flink.examples.scala.graph
 
PageRankBasic.Page$ - Class in org.apache.flink.examples.scala.graph
 
PageRankData - Class in org.apache.flink.examples.java.graph.util
Provides the default data sets used for the PageRank example program.
PageRankData() - Constructor for class org.apache.flink.examples.java.graph.util.PageRankData
 
PageRankData - Class in org.apache.flink.graph.examples.data
Provides the default data set used for the PageRank test program.
PageRankData - Class in org.apache.flink.test.testdata
 
pairComparator - Variable in class org.apache.flink.runtime.operators.hash.AbstractHashTableProber
 
pairComparator - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
parallelism(int) - Method in class org.apache.flink.api.java.operators.DeltaIteration
Sets the parallelism for the iteration.
parallelism - Variable in class org.apache.flink.api.java.operators.Operator
 
parallelism - Variable in class org.apache.flink.graph.generator.AbstractGraphGenerator
 
parallelism - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
PARALLELISM - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
 
parallelism() - Method in class org.apache.flink.streaming.api.scala.DataStream
Returns the parallelism of this operation.
PARALLELISM_AUTO_MAX - Static variable in class org.apache.flink.api.common.ExecutionConfig
The constant to use for the parallelism, if the system should use the number of currently available slots.
PARALLELISM_DEFAULT - Static variable in class org.apache.flink.api.common.ExecutionConfig
The flag value indicating use of the default parallelism.
PARALLELISM_OPTION - Static variable in class org.apache.flink.client.cli.CliFrontendParser
 
PARALLELISM_UNKNOWN - Static variable in class org.apache.flink.api.common.ExecutionConfig
The flag value indicating an unknown or unset parallelism.
ParallelIteratorInputFormat<T> - Class in org.apache.flink.api.java.io
An input format that generates data in parallel through a SplittableIterator.
ParallelIteratorInputFormat(SplittableIterator<T>) - Constructor for class org.apache.flink.api.java.io.ParallelIteratorInputFormat
 
ParallelSourceFunction<OUT> - Interface in org.apache.flink.streaming.api.functions.source
A stream data source that is executed in parallel.
Parameter<T> - Interface in org.apache.flink.graph.drivers.parameter
Encapsulates the usage and configuration of a command-line parameter.
Parameter<T> - Interface in org.apache.flink.ml.common
Base trait for parameter keys
PARAMETER_JOB_ID - Static variable in class org.apache.flink.runtime.webmonitor.metrics.JobMetricsHandler
 
PARAMETER_VERTEX_ID - Static variable in class org.apache.flink.runtime.webmonitor.metrics.JobVertexMetricsHandler
 
parameterizeChannel(Channel, boolean, ExecutionMode, boolean) - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
 
parameterizeChannel(Channel, boolean, ExecutionMode, boolean) - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
Parametrizes the ship strategy fields of a channel such that the channel produces the desired global properties.
parameterizeChannel(Channel) - Method in class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
Parametrizes the local strategy fields of a channel such that the channel produces the desired local properties.
Parameterized - Interface in org.apache.flink.graph.drivers.parameter
A configurable command-line choice, such as an input or algorithm.
ParameterizedBase - Class in org.apache.flink.graph.drivers.parameter
Base class for a Parameterized which maintains a list of parameters used to print the command-line usage string and configure parameters.
ParameterizedBase() - Constructor for class org.apache.flink.graph.drivers.parameter.ParameterizedBase
 
ParameterlessTypeSerializerConfig - Class in org.apache.flink.api.common.typeutils
A base class for TypeSerializerConfigSnapshots that do not have any parameters.
ParameterlessTypeSerializerConfig() - Constructor for class org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
This empty nullary constructor is required for deserializing the configuration.
ParameterlessTypeSerializerConfig(String) - Constructor for class org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
 
ParameterMap - Class in org.apache.flink.ml.common
Map used to store configuration parameters for algorithms.
ParameterMap(Map<Parameter<?>, Object>) - Constructor for class org.apache.flink.ml.common.ParameterMap
 
ParameterMap() - Constructor for class org.apache.flink.ml.common.ParameterMap
 
ParameterMap$ - Class in org.apache.flink.ml.common
 
ParameterMap$() - Constructor for class org.apache.flink.ml.common.ParameterMap$
 
parameters - Variable in class org.apache.flink.api.common.operators.Operator
 
parameters() - Static method in class org.apache.flink.ml.classification.SVM
 
parameters() - Method in interface org.apache.flink.ml.common.WithParameters
 
parameters() - Static method in class org.apache.flink.ml.nn.KNN
 
parameters() - Static method in class org.apache.flink.ml.optimization.GradientDescent
 
parameters() - Static method in class org.apache.flink.ml.optimization.IterativeSolver
 
parameters() - Static method in class org.apache.flink.ml.optimization.Solver
 
parameters() - Static method in class org.apache.flink.ml.outlier.StochasticOutlierSelection
 
parameters() - Static method in class org.apache.flink.ml.pipeline.ChainedPredictor
 
parameters() - Static method in class org.apache.flink.ml.pipeline.ChainedTransformer
 
parameters() - Static method in class org.apache.flink.ml.preprocessing.MinMaxScaler
 
parameters() - Static method in class org.apache.flink.ml.preprocessing.PolynomialFeatures
 
parameters() - Static method in class org.apache.flink.ml.preprocessing.StandardScaler
 
parameters() - Static method in class org.apache.flink.ml.recommendation.ALS
 
parameters() - Static method in class org.apache.flink.ml.regression.MultipleLinearRegression
 
parameters() - Method in class org.apache.flink.table.expressions.ScalarFunctionCall
 
parameters() - Method in class org.apache.flink.table.expressions.TableFunctionCall
 
parameters() - Method in class org.apache.flink.table.plan.logical.LogicalTableFunctionCall
 
ParameterTool - Class in org.apache.flink.api.java.utils
This class provides simple utility methods for reading and parsing program arguments from different sources
ParameterValuesProvider - Interface in org.apache.flink.api.java.io.jdbc.split
This interface is used by the JDBCInputFormat to compute the list of parallel query to run (i.e.
params() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.FactoryTypeDescriptor
 
Params() - Constructor for class org.apache.flink.examples.java.ml.LinearRegression.Params
 
Params(double, double) - Constructor for class org.apache.flink.examples.java.ml.LinearRegression.Params
 
PARAMS - Static variable in class org.apache.flink.examples.java.ml.util.LinearRegressionData
 
Params(double, double) - Constructor for class org.apache.flink.examples.scala.ml.LinearRegression.Params
 
Params$() - Constructor for class org.apache.flink.examples.scala.ml.LinearRegression.Params$
 
paramsFromGenericOptionsParser(String[]) - Static method in class org.apache.flink.hadoopcompatibility.HadoopUtils
Returns ParameterTool for the arguments parsed by GenericOptionsParser
parent - Variable in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
The parent partition this subpartition belongs to.
parent - Variable in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
The parent group containing this group
parent() - Method in class org.apache.flink.runtime.metrics.groups.JobManagerJobMetricGroup
 
parent() - Method in class org.apache.flink.runtime.metrics.groups.OperatorMetricGroup
 
parent() - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerJobMetricGroup
 
parent() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
parentID - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
parentMetricGroup - Variable in class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
parse(String) - Static method in class org.apache.flink.api.java.typeutils.TypeInfoParser
Generates an instance of TypeInformation by parsing a type information string.
parse(String) - Static method in class org.apache.flink.configuration.MemorySize
Parses the given string as as MemorySize.
parse(String) - Method in class org.apache.flink.table.calcite.FlinkPlannerImpl
 
parse(Parsers.Parser<T>, Reader<Object>) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
parse(Parsers.Parser<T>, CharSequence) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
parse(Parsers.Parser<T>, Reader) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
parseAll(Parsers.Parser<T>, Reader<Object>) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
parseAll(Parsers.Parser<T>, Reader) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
parseAll(Parsers.Parser<T>, CharSequence) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
parseArgs(String[]) - Method in class org.apache.flink.runtime.jobmanager.JobManager$
Loads the configuration, execution mode and the listening address from the provided command line arguments.
parseArgs(String[]) - Static method in class org.apache.flink.runtime.jobmanager.JobManager
Loads the configuration, execution mode and the listening address from the provided command line arguments.
parseArgsAndLoadConfig(String[]) - Method in class org.apache.flink.runtime.taskmanager.TaskManager$
Parse the command line arguments of the TaskManager and loads the configuration.
parseArgsAndLoadConfig(String[]) - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
Parse the command line arguments of the TaskManager and loads the configuration.
parseBytes(String) - Static method in class org.apache.flink.configuration.MemorySize
Parses the given string as bytes.
parseCancelCommand(String[]) - Static method in class org.apache.flink.client.cli.CliFrontendParser
 
parsedValues - Variable in class org.apache.flink.api.java.io.CsvInputFormat
 
parseDynamicProperties(CommandLine) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
Parse the dynamic properties (passed on the command line).
ParseException - Exception in org.apache.flink.api.common.io
Exception indicating that the parsing of input contents has failed because the data does not match the configured parser.
ParseException() - Constructor for exception org.apache.flink.api.common.io.ParseException
 
ParseException(String) - Constructor for exception org.apache.flink.api.common.io.ParseException
 
ParseException(Throwable) - Constructor for exception org.apache.flink.api.common.io.ParseException
 
ParseException(String, Throwable) - Constructor for exception org.apache.flink.api.common.io.ParseException
 
parseExpression(String) - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
parseExpression(String) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
parseExpressionList(String) - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
parseExpressionList(String) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
parseField(byte[], int, int, byte[], BigDecimal) - Method in class org.apache.flink.types.parser.BigDecParser
 
parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.BigDecParser
Static utility to parse a field of type BigDecimal from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.BigDecParser
Static utility to parse a field of type BigDecimal from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, byte[], BigInteger) - Method in class org.apache.flink.types.parser.BigIntParser
 
parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.BigIntParser
Static utility to parse a field of type BigInteger from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.BigIntParser
Static utility to parse a field of type BigInteger from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, byte[], Boolean) - Method in class org.apache.flink.types.parser.BooleanParser
 
parseField(byte[], int, int, byte[], BooleanValue) - Method in class org.apache.flink.types.parser.BooleanValueParser
 
parseField(byte[], int, int, byte[], Byte) - Method in class org.apache.flink.types.parser.ByteParser
 
parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.ByteParser
Static utility to parse a field of type byte from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.ByteParser
Static utility to parse a field of type byte from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, byte[], ByteValue) - Method in class org.apache.flink.types.parser.ByteValueParser
 
parseField(byte[], int, int, byte[], Double) - Method in class org.apache.flink.types.parser.DoubleParser
 
parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.DoubleParser
Static utility to parse a field of type double from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.DoubleParser
Static utility to parse a field of type double from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, byte[], DoubleValue) - Method in class org.apache.flink.types.parser.DoubleValueParser
 
parseField(byte[], int, int, byte[], T) - Method in class org.apache.flink.types.parser.FieldParser
Each parser's logic should be implemented inside this method
parseField(byte[], int, int, byte[], Float) - Method in class org.apache.flink.types.parser.FloatParser
 
parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.FloatParser
Static utility to parse a field of type float from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.FloatParser
Static utility to parse a field of type float from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, byte[], FloatValue) - Method in class org.apache.flink.types.parser.FloatValueParser
 
parseField(byte[], int, int, byte[], Integer) - Method in class org.apache.flink.types.parser.IntParser
 
parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.IntParser
Static utility to parse a field of type int from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.IntParser
Static utility to parse a field of type int from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, byte[], IntValue) - Method in class org.apache.flink.types.parser.IntValueParser
 
parseField(byte[], int, int, byte[], Long) - Method in class org.apache.flink.types.parser.LongParser
 
parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.LongParser
Static utility to parse a field of type long from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.LongParser
Static utility to parse a field of type long from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, byte[], LongValue) - Method in class org.apache.flink.types.parser.LongValueParser
 
parseField(byte[], int, int, byte[], Short) - Method in class org.apache.flink.types.parser.ShortParser
 
parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.ShortParser
Static utility to parse a field of type short from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.ShortParser
Static utility to parse a field of type short from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, byte[], ShortValue) - Method in class org.apache.flink.types.parser.ShortValueParser
 
parseField(byte[], int, int, byte[], Date) - Method in class org.apache.flink.types.parser.SqlDateParser
 
parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.SqlDateParser
Static utility to parse a field of type Date from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.SqlDateParser
Static utility to parse a field of type Date from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, byte[], Time) - Method in class org.apache.flink.types.parser.SqlTimeParser
 
parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.SqlTimeParser
Static utility to parse a field of type Time from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.SqlTimeParser
Static utility to parse a field of type Time from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, byte[], Timestamp) - Method in class org.apache.flink.types.parser.SqlTimestampParser
 
parseField(byte[], int, int) - Static method in class org.apache.flink.types.parser.SqlTimestampParser
Static utility to parse a field of type Timestamp from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, char) - Static method in class org.apache.flink.types.parser.SqlTimestampParser
Static utility to parse a field of type Timestamp from a byte sequence that represents text characters (such as when read from a file stream).
parseField(byte[], int, int, byte[], String) - Method in class org.apache.flink.types.parser.StringParser
 
parseField(byte[], int, int, byte[], StringValue) - Method in class org.apache.flink.types.parser.StringValueParser
 
parseHostPortAddress(String) - Static method in class org.apache.flink.client.ClientUtils
Utility method that converts a string of the form "host:port" into an InetSocketAddress.
parseInfoCommand(String[]) - Static method in class org.apache.flink.client.cli.CliFrontendParser
 
parseJobVertexId(Map<String, String>) - Static method in class org.apache.flink.runtime.webmonitor.handlers.AbstractJobVertexRequestHandler
Returns the job vertex ID parsed from the provided parameters.
parseListCommand(String[]) - Static method in class org.apache.flink.client.cli.CliFrontendParser
 
parseMap(String) - Method in class org.apache.flink.streaming.scala.examples.windowing.TopSpeedWindowing$
 
parseMap(String) - Static method in class org.apache.flink.streaming.scala.examples.windowing.TopSpeedWindowing
 
parseParameters(String[]) - Method in class org.apache.flink.client.CliFrontend
Parses the command line arguments and starts the requested action.
parseQuotedStrings - Variable in class org.apache.flink.api.java.io.CsvReader
 
parseQuotedStrings(char) - Method in class org.apache.flink.api.java.io.CsvReader
Enables quoted String parsing.
parseQuotedStringsEdges(char) - Method in class org.apache.flink.graph.GraphCsvReader
Enables quoted String parsing for Edge Csv Reader.
parseQuotedStringsVertices(char) - Method in class org.apache.flink.graph.GraphCsvReader
Enables quoted String parsing for Vertex Csv Reader.
Parser(Function1<Reader<Object>, Parsers.ParseResult<T>>) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
parser2packrat(Function0<Parsers.Parser<T>>) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
parserConfig() - Method in class org.apache.flink.table.calcite.FlinkPlannerImpl
 
parseRecord(Object[], byte[], int, int) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
parseRecord(Object[], byte[], int, int) - Method in class org.apache.flink.api.java.io.RowCsvInputFormat
 
parseRunCommand(String[]) - Static method in class org.apache.flink.client.cli.CliFrontendParser
 
parseSavepointCommand(String[]) - Static method in class org.apache.flink.client.cli.CliFrontendParser
 
parseStopCommand(String[]) - Static method in class org.apache.flink.client.cli.CliFrontendParser
 
PartialGroupProperties - Class in org.apache.flink.optimizer.operators
 
PartialGroupProperties(FieldSet) - Constructor for class org.apache.flink.optimizer.operators.PartialGroupProperties
 
PartialInputChannelDeploymentDescriptor - Class in org.apache.flink.runtime.deployment
Partial deployment descriptor for a single input channel instance.
PartialInputChannelDeploymentDescriptor(IntermediateDataSetID, ResultPartitionID, TaskManagerLocation, int) - Constructor for class org.apache.flink.runtime.deployment.PartialInputChannelDeploymentDescriptor
 
partialLossFunction() - Method in class org.apache.flink.ml.optimization.GenericLossFunction
 
PartialLossFunction - Interface in org.apache.flink.ml.optimization
Represents loss functions which can be used with the GenericLossFunction.
PartialModelBuilder() - Constructor for class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.PartialModelBuilder
 
PartialOrderPriorityQueue<T> - Class in org.apache.flink.runtime.operators.sort
This class implements a priority-queue, which maintains a partial ordering of its elements such that the least element can always be found in constant time.
PartialOrderPriorityQueue(Comparator<T>, int) - Constructor for class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
 
PartialSolutionPlaceHolder(BulkIterationBase<OT>, OperatorInformation<OT>) - Constructor for class org.apache.flink.api.common.operators.base.BulkIterationBase.PartialSolutionPlaceHolder
 
partition(K, int) - Method in interface org.apache.flink.api.common.functions.Partitioner
Computes the partition for the given key.
partition(Integer, int) - Method in class org.apache.flink.api.java.functions.IdPartitioner
 
partition(T, int) - Method in class org.apache.flink.api.java.io.SplitDataProperties.SourcePartitionerMarker
 
partition(int, int) - Method in class org.apache.flink.ml.common.FlinkMLTools.ModuloKeyPartitioner$
 
partition(int, int) - Method in class org.apache.flink.ml.recommendation.ALS.BlockIDPartitioner
 
partition(T, byte[], byte[], String, int[]) - Method in class org.apache.flink.streaming.connectors.kafka.partitioner.FlinkFixedPartitioner
 
partition(T, byte[], byte[], String, int[]) - Method in class org.apache.flink.streaming.connectors.kafka.partitioner.FlinkKafkaDelegatePartitioner
Deprecated.
 
partition(T, byte[], byte[], String, int[]) - Method in class org.apache.flink.streaming.connectors.kafka.partitioner.FlinkKafkaPartitioner
Determine the id of the partition that the record should be written to.
partition(T, byte[], byte[], int) - Method in class org.apache.flink.streaming.connectors.kafka.partitioner.KafkaPartitioner
Deprecated.
 
partitionBox(Vector, Vector) - Method in class org.apache.flink.ml.nn.QuadTree.Node
Recursive function that partitions a n-dim box by taking the (n-1) dimensional plane through the center of the box keeping the n-th coordinate fixed, then shifting it in the n-th direction up and down and recursively applying partitionBox to the two shifted (n-1) dimensional planes.
partitionBuffers - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
 
partitionBy(String) - Method in class org.apache.flink.table.api.java.Over$
Partitions the elements on some partition keys.
partitionBy(String) - Static method in class org.apache.flink.table.api.java.Over
Partitions the elements on some partition keys.
partitionBy() - Method in class org.apache.flink.table.api.OverWindow
 
partitionBy(Seq<Expression>) - Method in class org.apache.flink.table.api.scala.Over$
Partitions the elements on some partition keys.
partitionBy(Seq<Expression>) - Static method in class org.apache.flink.table.api.scala.Over
Partitions the elements on some partition keys.
partitionBy() - Method in class org.apache.flink.table.api.scala.OverWindowWithOrderBy
 
partitionBy() - Method in class org.apache.flink.table.api.scala.PartitionedOver
 
partitionBy() - Method in class org.apache.flink.table.expressions.OverCall
 
partitionByHash(int...) - Method in class org.apache.flink.api.java.DataSet
Hash-partitions a DataSet on the specified key fields.
partitionByHash(String...) - Method in class org.apache.flink.api.java.DataSet
Hash-partitions a DataSet on the specified key fields.
partitionByHash(KeySelector<T, K>) - Method in class org.apache.flink.api.java.DataSet
Partitions a DataSet using the specified KeySelector.
partitionByHash(Seq<Object>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
partitionByHash(String, Seq<String>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
partitionByHash(Function1<T, K>, TypeInformation<K>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
partitionByHash(Seq<Object>) - Method in class org.apache.flink.api.scala.DataSet
Hash-partitions a DataSet on the specified tuple field positions.
partitionByHash(String, Seq<String>) - Method in class org.apache.flink.api.scala.DataSet
Hash-partitions a DataSet on the specified fields.
partitionByHash(Function1<T, K>, TypeInformation<K>) - Method in class org.apache.flink.api.scala.DataSet
Partitions a DataSet using the specified key selector function.
partitionByRange(int...) - Method in class org.apache.flink.api.java.DataSet
Range-partitions a DataSet on the specified key fields.
partitionByRange(String...) - Method in class org.apache.flink.api.java.DataSet
Range-partitions a DataSet on the specified key fields.
partitionByRange(KeySelector<T, K>) - Method in class org.apache.flink.api.java.DataSet
Range-partitions a DataSet using the specified KeySelector.
partitionByRange(DataSet<T>, DataDistribution, int...) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Range-partitions a DataSet on the specified tuple field positions.
partitionByRange(DataSet<T>, DataDistribution, String...) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Range-partitions a DataSet on the specified fields.
partitionByRange(DataSet<T>, DataDistribution, KeySelector<T, K>) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Range-partitions a DataSet using the specified key selector function.
partitionByRange(Seq<Object>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
partitionByRange(String, Seq<String>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
partitionByRange(Function1<T, K>, TypeInformation<K>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
partitionByRange(Seq<Object>) - Method in class org.apache.flink.api.scala.DataSet
Range-partitions a DataSet on the specified tuple field positions.
partitionByRange(String, Seq<String>) - Method in class org.apache.flink.api.scala.DataSet
Range-partitions a DataSet on the specified fields.
partitionByRange(Function1<T, K>, TypeInformation<K>) - Method in class org.apache.flink.api.scala.DataSet
Range-partitions a DataSet using the specified key selector function.
partitionCustom(Partitioner<K>, int) - Method in class org.apache.flink.api.java.DataSet
Partitions a tuple DataSet on the specified key fields using a custom partitioner.
partitionCustom(Partitioner<K>, String) - Method in class org.apache.flink.api.java.DataSet
Partitions a POJO DataSet on the specified key fields using a custom partitioner.
partitionCustom(Partitioner<K>, KeySelector<T, K>) - Method in class org.apache.flink.api.java.DataSet
Partitions a DataSet on the key returned by the selector, using a custom partitioner.
partitionCustom(Partitioner<K>, int, TypeInformation<K>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
partitionCustom(Partitioner<K>, String, TypeInformation<K>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
partitionCustom(Partitioner<K>, Function1<T, K>, TypeInformation<K>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
partitionCustom(Partitioner<K>, int, TypeInformation<K>) - Method in class org.apache.flink.api.scala.DataSet
Partitions a tuple DataSet on the specified key fields using a custom partitioner.
partitionCustom(Partitioner<K>, String, TypeInformation<K>) - Method in class org.apache.flink.api.scala.DataSet
Partitions a POJO DataSet on the specified key fields using a custom partitioner.
partitionCustom(Partitioner<K>, Function1<T, K>, TypeInformation<K>) - Method in class org.apache.flink.api.scala.DataSet
Partitions a DataSet on the key returned by the selector, using a custom partitioner.
partitionCustom(Partitioner<K>, int) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Partitions a tuple DataStream on the specified key fields using a custom partitioner.
partitionCustom(Partitioner<K>, String) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Partitions a POJO DataStream on the specified key fields using a custom partitioner.
partitionCustom(Partitioner<K>, KeySelector<T, K>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Partitions a DataStream on the key returned by the selector, using a custom partitioner.
partitionCustom(Partitioner<K>, int, TypeInformation<K>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Partitions a tuple DataStream on the specified key fields using a custom partitioner.
partitionCustom(Partitioner<K>, String, TypeInformation<K>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Partitions a POJO DataStream on the specified key fields using a custom partitioner.
partitionCustom(Partitioner<K>, Function1<T, K>, TypeInformation<K>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Partitions a DataStream on the key returned by the selector, using a custom partitioner.
PartitionDescriptor(PartitionOperatorBase.PartitionMethod, FieldSet, Ordering, Partitioner<?>, DataDistribution) - Constructor for class org.apache.flink.optimizer.dag.PartitionNode.PartitionDescriptor
 
PartitionedOver - Class in org.apache.flink.table.api.java
 
PartitionedOver(Expression[]) - Constructor for class org.apache.flink.table.api.java.PartitionedOver
 
PartitionedOver - Class in org.apache.flink.table.api.scala
 
PartitionedOver(Expression[]) - Constructor for class org.apache.flink.table.api.scala.PartitionedOver
 
PartitionedOver$ - Class in org.apache.flink.table.api.scala
 
PartitionedOver$() - Constructor for class org.apache.flink.table.api.scala.PartitionedOver$
 
Partitioner<K> - Interface in org.apache.flink.api.common.functions
Function to implement a custom partition assignment for keys.
partitioner - Variable in class org.apache.flink.streaming.connectors.kafka.KafkaTableSink
 
PartitionException - Exception in org.apache.flink.runtime.taskexecutor.exceptions
Exception indicating a problem with the result partitions on the TaskExecutor side.
PartitionException(String) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.PartitionException
 
PartitionException(String, Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.PartitionException
 
PartitionException(Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.PartitionException
 
partitionId - Variable in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
 
partitionId() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.ScheduleOrUpdateConsumers
 
partitionIndex() - Method in class org.apache.flink.table.runtime.LimitFilterFunction
 
PartitionInfo - Class in org.apache.flink.runtime.executiongraph
Contains information where to find a partition.
PartitionInfo(IntermediateDataSetID, InputChannelDeploymentDescriptor) - Constructor for class org.apache.flink.runtime.executiongraph.PartitionInfo
 
partitionInfo() - Method in class org.apache.flink.runtime.messages.TaskMessages.UpdateTaskSinglePartitionInfo
 
partitionInfos() - Method in class org.apache.flink.runtime.messages.TaskMessages.UpdateTaskMultiplePartitionInfos
 
PartitioningProperty - Enum in org.apache.flink.optimizer.dataproperties
An enumeration of the the different types of distributing data across partitions or parallel workers.
PartitionNode - Class in org.apache.flink.optimizer.dag
The optimizer's internal representation of a Partition operator node.
PartitionNode(PartitionOperatorBase<?>) - Constructor for class org.apache.flink.optimizer.dag.PartitionNode
 
PartitionNode.PartitionDescriptor - Class in org.apache.flink.optimizer.dag
 
PartitionNotFoundException - Exception in org.apache.flink.runtime.io.network.partition
 
PartitionNotFoundException(ResultPartitionID) - Constructor for exception org.apache.flink.runtime.io.network.partition.PartitionNotFoundException
 
partitionNumber - Variable in class org.apache.flink.api.common.io.GenericInputFormat
The partition of this split.
PartitionOperator<T> - Class in org.apache.flink.api.java.operators
This operator represents a partitioning.
PartitionOperator(DataSet<T>, PartitionOperatorBase.PartitionMethod, Keys<T>, String) - Constructor for class org.apache.flink.api.java.operators.PartitionOperator
 
PartitionOperator(DataSet<T>, PartitionOperatorBase.PartitionMethod, Keys<T>, DataDistribution, String) - Constructor for class org.apache.flink.api.java.operators.PartitionOperator
 
PartitionOperator(DataSet<T>, PartitionOperatorBase.PartitionMethod, String) - Constructor for class org.apache.flink.api.java.operators.PartitionOperator
 
PartitionOperator(DataSet<T>, Keys<T>, Partitioner<?>, String) - Constructor for class org.apache.flink.api.java.operators.PartitionOperator
 
PartitionOperator(DataSet<T>, Keys<T>, Partitioner<P>, TypeInformation<P>, String) - Constructor for class org.apache.flink.api.java.operators.PartitionOperator
 
PartitionOperatorBase<IN> - Class in org.apache.flink.api.common.operators.base
 
PartitionOperatorBase(UnaryOperatorInformation<IN, IN>, PartitionOperatorBase.PartitionMethod, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
PartitionOperatorBase(UnaryOperatorInformation<IN, IN>, PartitionOperatorBase.PartitionMethod, String) - Constructor for class org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
PartitionOperatorBase.PartitionMethod - Enum in org.apache.flink.api.common.operators.base
 
PartitionProducerDisposedException - Exception in org.apache.flink.runtime.jobmanager
Exception returned to a TaskManager on JobManagerMessages.RequestPartitionProducerState if the producer of a partition has been disposed.
PartitionProducerDisposedException(ResultPartitionID) - Constructor for exception org.apache.flink.runtime.jobmanager.PartitionProducerDisposedException
 
PartitionProducerStateChecker - Interface in org.apache.flink.runtime.io.network.netty
Intermediate partition state checker to query the JobManager about the state of the producer of a result partition.
PartitionRequestClient - Class in org.apache.flink.runtime.io.network.netty
Partition request client for remote partition requests.
partitionRequestInitialBackoff() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
partitionRequestMaxBackoff() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
partitionsBeingBuilt - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
The partitions that are built by processing the current partition.
PartitionSortedDataSet<T> - Class in org.apache.flink.api.scala
The result of DataSet.sortPartition.
PartitionSortedDataSet(SortPartitionOperator<T>, ClassTag<T>) - Constructor for class org.apache.flink.api.scala.PartitionSortedDataSet
 
partitionToString(RelDataType, int[]) - Method in interface org.apache.flink.table.plan.nodes.OverAggregate
 
PartitionTransformation<T> - Class in org.apache.flink.streaming.api.transformations
This transformation represents a change of partitioning of the input elements.
PartitionTransformation(StreamTransformation<T>, StreamPartitioner<T>) - Constructor for class org.apache.flink.streaming.api.transformations.PartitionTransformation
Creates a new PartitionTransformation from the given input and StreamPartitioner.
PassThroughAllWindowFunction<W extends Window,T> - Class in org.apache.flink.streaming.api.functions.windowing
A AllWindowFunction that just emits each input element.
PassThroughAllWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.PassThroughAllWindowFunction
 
PassThroughWindowFunction<K,W extends Window,T> - Class in org.apache.flink.streaming.api.functions.windowing
A WindowFunction that just emits each input element.
PassThroughWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.PassThroughWindowFunction
 
Path - Class in org.apache.flink.core.fs
Names a file or directory in a FileSystem.
Path() - Constructor for class org.apache.flink.core.fs.Path
Constructs a new (empty) path object (used to reconstruct path object after RPC call).
Path(URI) - Constructor for class org.apache.flink.core.fs.Path
Constructs a path object from a given URI.
Path(String, String) - Constructor for class org.apache.flink.core.fs.Path
Resolve a child path against a parent path.
Path(Path, String) - Constructor for class org.apache.flink.core.fs.Path
Resolve a child path against a parent path.
Path(String, Path) - Constructor for class org.apache.flink.core.fs.Path
Resolve a child path against a parent path.
Path(Path, Path) - Constructor for class org.apache.flink.core.fs.Path
Resolve a child path against a parent path.
Path(String) - Constructor for class org.apache.flink.core.fs.Path
Construct a path from a String.
Path(String, String, String) - Constructor for class org.apache.flink.core.fs.Path
Construct a Path from a scheme, an authority and a path string.
path - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
path() - Method in interface org.apache.flink.runtime.instance.ActorGateway
Returns the path of the remote instance.
path() - Method in class org.apache.flink.runtime.instance.AkkaActorGateway
Returns the ActorPath of the remote instance.
path - Variable in class org.apache.flink.storm.util.FileSpout
 
path - Variable in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
 
path(String) - Method in class org.apache.flink.table.sources.CsvTableSource.Builder
Sets the path to the CSV file.
PATH_HADOOP_CONFIG - Static variable in class org.apache.flink.configuration.ConfigConstants
Path to Hadoop configuration
PathGraph - Class in org.apache.flink.graph.drivers.input
Generate a PathGraph.
PathGraph() - Constructor for class org.apache.flink.graph.drivers.input.PathGraph
 
PathGraph - Class in org.apache.flink.graph.generator
 
PathGraph(ExecutionEnvironment, long) - Constructor for class org.apache.flink.graph.generator.PathGraph
An undirected Graph with n vertices where each vertex vi connects to adjacent vertices vi+1 when i < n-1 and vi-1 when i > 0.
pathToCheckpointId(String) - Static method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
Converts a path to the checkpoint id.
pattern(DataStream<T>, Pattern<T, ?>) - Static method in class org.apache.flink.cep.CEP
Creates a PatternStream from an input data stream and a pattern.
Pattern<T,F extends T> - Class in org.apache.flink.cep.pattern
Base class for a pattern definition.
Pattern(String, Pattern<T, ? extends T>) - Constructor for class org.apache.flink.cep.pattern.Pattern
 
Pattern(String, Pattern<T, ? extends T>, Quantifier.ConsumingStrategy) - Constructor for class org.apache.flink.cep.pattern.Pattern
 
pattern(DataStream<T>, Pattern<T, ?>) - Method in class org.apache.flink.cep.scala.CEP$
Transforms a DataStream into a PatternStream in the Scala API.
pattern(DataStream<T>, Pattern<T, ?>) - Static method in class org.apache.flink.cep.scala.CEP
Transforms a DataStream into a PatternStream in the Scala API.
Pattern<T,F extends T> - Class in org.apache.flink.cep.scala.pattern
Base class for a pattern definition.
Pattern(Pattern<T, F>) - Constructor for class org.apache.flink.cep.scala.pattern.Pattern
 
pattern() - Method in class org.apache.flink.table.expressions.Like
 
pattern() - Method in class org.apache.flink.table.expressions.Similar
 
Pattern$ - Class in org.apache.flink.cep.scala.pattern
 
Pattern$() - Constructor for class org.apache.flink.cep.scala.pattern.Pattern$
 
PATTERN_ALTER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
| operator to create alternate patterns within MATCH_RECOGNIZE.
PATTERN_CONCAT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Operator to concatenate patterns within MATCH_RECOGNIZE.
PATTERN_EXCLUDE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
EXCLUDE operator within MATCH_RECOGNIZE.
PATTERN_PERMUTE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
PERMUTE operator to combine patterns within MATCH_RECOGNIZE.
PATTERN_QUANTIFIER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Operator to quantify patterns within MATCH_RECOGNIZE.
PatternFlatSelectFunction<IN,OUT> - Interface in org.apache.flink.cep
Base interface for a pattern select function which can produce multiple resulting elements.
PatternFlatTimeoutFunction<IN,OUT> - Interface in org.apache.flink.cep
Base interface for a pattern timeout function which can produce multiple resulting elements.
PatternSelectFunction<IN,OUT> - Interface in org.apache.flink.cep
Base interface for a pattern select function.
PatternStream<T> - Class in org.apache.flink.cep
Stream abstraction for CEP pattern detection.
PatternStream<T> - Class in org.apache.flink.cep.scala
Stream abstraction for CEP pattern detection.
PatternStream(PatternStream<T>) - Constructor for class org.apache.flink.cep.scala.PatternStream
 
PatternStream$ - Class in org.apache.flink.cep.scala
 
PatternStream$() - Constructor for class org.apache.flink.cep.scala.PatternStream$
 
PatternTimeoutFunction<IN,OUT> - Interface in org.apache.flink.cep
Base interface for a pattern timeout function.
peek() - Method in class org.apache.flink.runtime.jobmanager.scheduler.LifoSetQueue
 
peek() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
peek() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
Returns the least element of the PriorityQueue in constant time, but does not remove it from the priority queue.
peek() - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
Returns the queue's next element without removing it, if the queue is non-empty.
peek() - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
peek(int) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
peek(int, int) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
peekBlockingly() - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
 
peekBlockingly() - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
Peek at the head of the queue and return the first completed AsyncResult.
peekBlockingly() - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
 
PendingCheckpoint - Class in org.apache.flink.runtime.checkpoint
A pending checkpoint is a checkpoint that has been started, but has not been acknowledged by all tasks that need to acknowledge it.
PendingCheckpoint(JobID, long, long, Map<ExecutionAttemptID, ExecutionVertex>, CheckpointProperties, String, Executor) - Constructor for class org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
PendingCheckpoint.TaskAcknowledgeResult - Enum in org.apache.flink.runtime.checkpoint
pendingCheckpoints - Variable in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
The list with IDs from checkpoints that were triggered, but not yet completed or notified of completion.
PendingCheckpointStats - Class in org.apache.flink.runtime.checkpoint
Statistics for a pending checkpoint that is still in progress.
pendingFiles - Variable in class org.apache.flink.streaming.connectors.fs.RollingSink.BucketState
Deprecated.
Pending files that accumulated since the last checkpoint.
pendingFilesPerCheckpoint - Variable in class org.apache.flink.streaming.connectors.fs.RollingSink.BucketState
Deprecated.
When doing a checkpoint we move the pending files since the last checkpoint to this map with the id of the checkpoint.
pendingRecords - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
Number of unacknowledged records.
pendingRecordsLock - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
Lock for accessing the pending records
PendingSlotRequest - Class in org.apache.flink.runtime.resourcemanager.slotmanager
 
PendingSlotRequest(SlotRequest) - Constructor for class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
PERCENT_RANK - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
PERCENT_RANK window function.
performOperation() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncIOCallable
Implements the actual IO operation on the opened IO handle.
PERIODIC_WATERMARKS - Static variable in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
 
PeriodicOffsetCommitter - Class in org.apache.flink.streaming.connectors.kafka.internals
A thread that periodically writes the current Kafka partition offsets to Zookeeper.
permute(Mapping) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
Perplexity$() - Constructor for class org.apache.flink.ml.outlier.StochasticOutlierSelection.Perplexity$
 
persist(DataSet<T>, String, ClassTag<T>, TypeInformation<T>) - Method in class org.apache.flink.ml.common.FlinkMLTools$
Writes a DataSet to the specified path and returns it as a DataSource for subsequent operations.
persist(DataSet<A>, DataSet<B>, String, String, ClassTag<A>, TypeInformation<A>, ClassTag<B>, TypeInformation<B>) - Method in class org.apache.flink.ml.common.FlinkMLTools$
Writes multiple DataSets to the specified paths and returns them as DataSources for subsequent operations.
persist(DataSet<A>, DataSet<B>, DataSet<C>, String, String, String, ClassTag<A>, TypeInformation<A>, ClassTag<B>, TypeInformation<B>, ClassTag<C>, TypeInformation<C>) - Method in class org.apache.flink.ml.common.FlinkMLTools$
Writes multiple DataSets to the specified paths and returns them as DataSources for subsequent operations.
persist(DataSet<A>, DataSet<B>, DataSet<C>, DataSet<D>, String, String, String, String, ClassTag<A>, TypeInformation<A>, ClassTag<B>, TypeInformation<B>, ClassTag<C>, TypeInformation<C>, ClassTag<D>, TypeInformation<D>) - Method in class org.apache.flink.ml.common.FlinkMLTools$
Writes multiple DataSets to the specified paths and returns them as DataSources for subsequent operations.
persist(DataSet<A>, DataSet<B>, DataSet<C>, DataSet<D>, DataSet<E>, String, String, String, String, String, ClassTag<A>, TypeInformation<A>, ClassTag<B>, TypeInformation<B>, ClassTag<C>, TypeInformation<C>, ClassTag<D>, TypeInformation<D>, ClassTag<E>, TypeInformation<E>) - Method in class org.apache.flink.ml.common.FlinkMLTools$
Writes multiple DataSets to the specified paths and returns them as DataSources for subsequent operations.
persist(DataSet<T>, String, ClassTag<T>, TypeInformation<T>) - Static method in class org.apache.flink.ml.common.FlinkMLTools
Writes a DataSet to the specified path and returns it as a DataSource for subsequent operations.
persist(DataSet<A>, DataSet<B>, String, String, ClassTag<A>, TypeInformation<A>, ClassTag<B>, TypeInformation<B>) - Static method in class org.apache.flink.ml.common.FlinkMLTools
Writes multiple DataSets to the specified paths and returns them as DataSources for subsequent operations.
persist(DataSet<A>, DataSet<B>, DataSet<C>, String, String, String, ClassTag<A>, TypeInformation<A>, ClassTag<B>, TypeInformation<B>, ClassTag<C>, TypeInformation<C>) - Static method in class org.apache.flink.ml.common.FlinkMLTools
Writes multiple DataSets to the specified paths and returns them as DataSources for subsequent operations.
persist(DataSet<A>, DataSet<B>, DataSet<C>, DataSet<D>, String, String, String, String, ClassTag<A>, TypeInformation<A>, ClassTag<B>, TypeInformation<B>, ClassTag<C>, TypeInformation<C>, ClassTag<D>, TypeInformation<D>) - Static method in class org.apache.flink.ml.common.FlinkMLTools
Writes multiple DataSets to the specified paths and returns them as DataSources for subsequent operations.
persist(DataSet<A>, DataSet<B>, DataSet<C>, DataSet<D>, DataSet<E>, String, String, String, String, String, ClassTag<A>, TypeInformation<A>, ClassTag<B>, TypeInformation<B>, ClassTag<C>, TypeInformation<C>, ClassTag<D>, TypeInformation<D>, ClassTag<E>, TypeInformation<E>) - Static method in class org.apache.flink.ml.common.FlinkMLTools
Writes multiple DataSets to the specified paths and returns them as DataSources for subsequent operations.
persist() - Method in class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
Persist the updated mapping to the given state if the mapping changed since initialization.
Person(String, int, int) - Constructor for class org.apache.flink.streaming.scala.examples.join.WindowJoin.Person
 
Person$() - Constructor for class org.apache.flink.streaming.scala.examples.join.WindowJoin.Person$
 
PerWindowStateStore() - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.PerWindowStateStore
 
phrase(Parsers.Parser<T>) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
physicalArity() - Method in class org.apache.flink.table.plan.schema.RowSchema
Returns the arity of the physical record.
physicalFieldNames() - Method in class org.apache.flink.table.plan.schema.RowSchema
Returns the physical fields names with no logical fields (i.e.
physicalFieldTypeInfo() - Method in class org.apache.flink.table.plan.schema.RowSchema
Returns TypeInformation of the row's fields with no logical fields (i.e.
PhysicalTableSourceScan - Class in org.apache.flink.table.plan.nodes
 
PhysicalTableSourceScan(RelOptCluster, RelTraitSet, RelOptTable, TableSource<?>) - Constructor for class org.apache.flink.table.plan.nodes.PhysicalTableSourceScan
 
physicalType() - Method in class org.apache.flink.table.plan.schema.RowSchema
Returns a physical RelDataType with no logical fields (i.e.
physicalTypeInfo() - Method in class org.apache.flink.table.plan.schema.RowSchema
Returns a physical TypeInformation of row with no logical fields (i.e.
PI - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
pi - Class in org.apache.flink.table.api.scala
Returns a value that is closer than any other value to pi.
pi() - Constructor for class org.apache.flink.table.api.scala.pi
 
Pi - Class in org.apache.flink.table.expressions
 
Pi() - Constructor for class org.apache.flink.table.expressions.Pi
 
pi$ - Class in org.apache.flink.table.api.scala
Returns a value that is closer than any other value to pi.
pi$() - Constructor for class org.apache.flink.table.api.scala.pi$
 
Pi$ - Class in org.apache.flink.table.expressions
 
Pi$() - Constructor for class org.apache.flink.table.expressions.Pi$
 
PiEstimation - Class in org.apache.flink.examples.java.misc
Estimates the value of Pi using the Monte Carlo method.
PiEstimation() - Constructor for class org.apache.flink.examples.java.misc.PiEstimation
 
PiEstimation - Class in org.apache.flink.examples.scala.misc
 
PiEstimation() - Constructor for class org.apache.flink.examples.scala.misc.PiEstimation
 
PiEstimation$ - Class in org.apache.flink.examples.scala.misc
 
PiEstimation$() - Constructor for class org.apache.flink.examples.scala.misc.PiEstimation$
 
PiEstimation.Sampler - Class in org.apache.flink.examples.java.misc
Sampler randomly emits points that fall within a square of edge x * y.
PiEstimation.SumReducer - Class in org.apache.flink.examples.java.misc
Simply sums up all long values.
PIPELINED_REGION_RESTART_STRATEGY_NAME - Static variable in class org.apache.flink.runtime.executiongraph.failover.FailoverStrategyLoader
Config name for the RestartPipelinedRegionStrategy
PipelineErrorHandler - Class in org.apache.flink.runtime.webmonitor
This is the last handler in the pipeline.
PipelineErrorHandler(Logger) - Constructor for class org.apache.flink.runtime.webmonitor.PipelineErrorHandler
 
placeAttributesObjectStatePrimitiveHandler(Object) - Method in class org.apache.flink.contrib.tweetinputformat.io.TweetHandler
 
PlaceholderStreamStateHandle - Class in org.apache.flink.runtime.state
A placeholder state handle for shared state that will replaced by an original that was created in a previous checkpoint.
PlaceholderStreamStateHandle() - Constructor for class org.apache.flink.runtime.state.PlaceholderStreamStateHandle
 
placeObjectStatePrimitiveHandler(Object) - Method in class org.apache.flink.contrib.tweetinputformat.io.TweetHandler
 
placePipelineBreakersIfNecessary(DriverStrategy, Channel, Channel) - Method in class org.apache.flink.optimizer.dag.TwoInputNode
 
Places - Class in org.apache.flink.contrib.tweetinputformat.model.places
Places are specific, named locations with corresponding geo Coordinates.
Places() - Constructor for class org.apache.flink.contrib.tweetinputformat.model.places.Places
 
Plan - Class in org.apache.flink.api.common
This class represents Flink programs, in the form of dataflow plans.
Plan(Collection<? extends GenericDataSinkBase<?>>, String) - Constructor for class org.apache.flink.api.common.Plan
Creates a new dataflow plan with the given name, describing the data flow that ends at the given data sinks.
Plan(Collection<? extends GenericDataSinkBase<?>>, String, int) - Constructor for class org.apache.flink.api.common.Plan
Creates a new program plan with the given name and default parallelism, describing the data flow that ends at the given data sinks.
Plan(GenericDataSinkBase<?>, String) - Constructor for class org.apache.flink.api.common.Plan
Creates a new program plan with the given name, containing initially a single data sink.
Plan(GenericDataSinkBase<?>, String, int) - Constructor for class org.apache.flink.api.common.Plan
Creates a new program plan with the given name and default parallelism, containing initially a single data sink.
Plan(Collection<? extends GenericDataSinkBase<?>>) - Constructor for class org.apache.flink.api.common.Plan
Creates a new program plan, describing the data flow that ends at the given data sinks.
Plan(Collection<? extends GenericDataSinkBase<?>>, int) - Constructor for class org.apache.flink.api.common.Plan
Creates a new program plan with the given default parallelism, describing the data flow that ends at the given data sinks.
Plan(GenericDataSinkBase<?>) - Constructor for class org.apache.flink.api.common.Plan
Creates a new program plan with single data sink.
Plan(GenericDataSinkBase<?>, int) - Constructor for class org.apache.flink.api.common.Plan
Creates a new program plan with single data sink and the given default parallelism.
plan(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.drivers.ConnectedComponents
 
plan(Graph<K, VV, EV>) - Method in interface org.apache.flink.graph.drivers.Driver
"Run" algorithms and analytics on the input graph.
plan(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.drivers.EdgeList
 
plan(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.drivers.GraphMetrics
 
plan(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.drivers.SimpleDriver
 
PLAN_ARGUMENTS_KEY - Static variable in class org.apache.flink.python.api.PythonPlanBinder
 
PLAN_TMP_DIR - Static variable in class org.apache.flink.python.api.PythonOptions
The config parameter defining where temporary plan-related files are stored on the client.
PLANBINDER_CONFIG_BCVAR_COUNT - Static variable in class org.apache.flink.python.api.PythonPlanBinder
 
PLANBINDER_CONFIG_BCVAR_NAME_PREFIX - Static variable in class org.apache.flink.python.api.PythonPlanBinder
 
PlanBothUnwrappingCoGroupOperator<I1,I2,OUT,K> - Class in org.apache.flink.api.java.operators.translation
 
PlanBothUnwrappingCoGroupOperator(CoGroupFunction<I1, I2, OUT>, Keys.SelectorFunctionKeys<I1, K>, Keys.SelectorFunctionKeys<I2, K>, String, TypeInformation<OUT>, TypeInformation<Tuple2<K, I1>>, TypeInformation<Tuple2<K, I2>>) - Constructor for class org.apache.flink.api.java.operators.translation.PlanBothUnwrappingCoGroupOperator
 
PlanBothUnwrappingCoGroupOperator.TupleBothUnwrappingCoGrouper<I1,I2,OUT,K> - Class in org.apache.flink.api.java.operators.translation
 
PlanExecutor - Class in org.apache.flink.api.common
A PlanExecutor executes a Flink program's dataflow plan.
PlanExecutor() - Constructor for class org.apache.flink.api.common.PlanExecutor
 
PlanFilterOperator<T> - Class in org.apache.flink.api.java.operators.translation
 
PlanFilterOperator(FilterFunction<T>, String, TypeInformation<T>) - Constructor for class org.apache.flink.api.java.operators.translation.PlanFilterOperator
 
PlanFilterOperator.FlatMapFilter<T> - Class in org.apache.flink.api.java.operators.translation
 
PlanFinalizer - Class in org.apache.flink.optimizer.traversals
This visitor traverses the selected execution plan and finalizes it: The graph of nodes is double-linked (links from child to parent are inserted). If unions join static and dynamic paths, the cache is marked as a memory consumer. Relative memory fractions are assigned to all nodes. All nodes are collected into a set.
PlanFinalizer() - Constructor for class org.apache.flink.optimizer.traversals.PlanFinalizer
Creates a new plan finalizer.
PlanJSONDumpGenerator - Class in org.apache.flink.optimizer.plandump
 
PlanJSONDumpGenerator() - Constructor for class org.apache.flink.optimizer.plandump.PlanJSONDumpGenerator
 
PlanJsonParser - Class in org.apache.flink.table.explain
 
PlanJsonParser() - Constructor for class org.apache.flink.table.explain.PlanJsonParser
 
PlanLeftUnwrappingCoGroupOperator<I1,I2,OUT,K> - Class in org.apache.flink.api.java.operators.translation
 
PlanLeftUnwrappingCoGroupOperator(CoGroupFunction<I1, I2, OUT>, Keys.SelectorFunctionKeys<I1, K>, int[], String, TypeInformation<OUT>, TypeInformation<Tuple2<K, I1>>, TypeInformation<I2>) - Constructor for class org.apache.flink.api.java.operators.translation.PlanLeftUnwrappingCoGroupOperator
 
PlanLeftUnwrappingCoGroupOperator.TupleLeftUnwrappingCoGrouper<I1,I2,OUT,K> - Class in org.apache.flink.api.java.operators.translation
 
PlanNode - Class in org.apache.flink.optimizer.plan
The representation of a data exchange between to operators.
PlanNode(OptimizerNode, String, DriverStrategy) - Constructor for class org.apache.flink.optimizer.plan.PlanNode
 
PlanNode.FeedbackPropertiesMeetRequirementsReport - Enum in org.apache.flink.optimizer.plan
 
PlanNode.SourceAndDamReport - Enum in org.apache.flink.optimizer.plan
 
PlanProjectOperator<T,R extends Tuple> - Class in org.apache.flink.api.java.operators.translation
 
PlanProjectOperator(int[], String, TypeInformation<T>, TypeInformation<R>, ExecutionConfig) - Constructor for class org.apache.flink.api.java.operators.translation.PlanProjectOperator
 
PlanProjectOperator.MapProjector<T extends Tuple,R extends Tuple> - Class in org.apache.flink.api.java.operators.translation
 
PlanRightUnwrappingCoGroupOperator<I1,I2,OUT,K> - Class in org.apache.flink.api.java.operators.translation
 
PlanRightUnwrappingCoGroupOperator(CoGroupFunction<I1, I2, OUT>, int[], Keys.SelectorFunctionKeys<I2, K>, String, TypeInformation<OUT>, TypeInformation<I1>, TypeInformation<Tuple2<K, I2>>) - Constructor for class org.apache.flink.api.java.operators.translation.PlanRightUnwrappingCoGroupOperator
 
PlanRightUnwrappingCoGroupOperator.TupleRightUnwrappingCoGrouper<I1,I2,OUT,K> - Class in org.apache.flink.api.java.operators.translation
 
PlanUnwrappingGroupCombineOperator<IN,OUT,K> - Class in org.apache.flink.api.java.operators.translation
A group combine operator that takes 2-tuples (key-value pairs), and applies the group combine operation only on the unwrapped values.
PlanUnwrappingGroupCombineOperator(GroupCombineFunction<IN, OUT>, Keys.SelectorFunctionKeys<IN, K>, String, TypeInformation<OUT>, TypeInformation<Tuple2<K, IN>>) - Constructor for class org.apache.flink.api.java.operators.translation.PlanUnwrappingGroupCombineOperator
 
PlanUnwrappingGroupCombineOperator.TupleUnwrappingGroupCombiner<IN,OUT,K> - Class in org.apache.flink.api.java.operators.translation
 
PlanUnwrappingReduceGroupOperator<IN,OUT,K> - Class in org.apache.flink.api.java.operators.translation
A reduce operator that takes 2-tuples (key-value pairs), and applies the group reduce operation only on the unwrapped values.
PlanUnwrappingReduceGroupOperator(GroupReduceFunction<IN, OUT>, Keys.SelectorFunctionKeys<IN, K>, String, TypeInformation<OUT>, TypeInformation<Tuple2<K, IN>>, boolean) - Constructor for class org.apache.flink.api.java.operators.translation.PlanUnwrappingReduceGroupOperator
 
PlanUnwrappingReduceGroupOperator.TupleUnwrappingGroupCombinableGroupReducer<IN,OUT,K> - Class in org.apache.flink.api.java.operators.translation
 
PlanUnwrappingReduceGroupOperator.TupleUnwrappingNonCombinableGroupReducer<IN,OUT,K> - Class in org.apache.flink.api.java.operators.translation
 
PlanUnwrappingReduceOperator<T,K> - Class in org.apache.flink.api.java.operators.translation
A reduce operator that takes 2-tuples (key-value pairs), and applies the reduce operation only on the unwrapped values.
PlanUnwrappingReduceOperator(ReduceFunction<T>, Keys.SelectorFunctionKeys<T, K>, String, TypeInformation<T>, TypeInformation<Tuple2<K, T>>) - Constructor for class org.apache.flink.api.java.operators.translation.PlanUnwrappingReduceOperator
 
PlanUnwrappingReduceOperator.ReduceWrapper<T,K> - Class in org.apache.flink.api.java.operators.translation
 
PlanUnwrappingSortedGroupCombineOperator<IN,OUT,K1,K2> - Class in org.apache.flink.api.java.operators.translation
A reduce operator that takes 3-tuples (groupKey, sortKey, value), and applies the sorted partial group reduce operation only on the unwrapped values.
PlanUnwrappingSortedGroupCombineOperator(GroupCombineFunction<IN, OUT>, Keys.SelectorFunctionKeys<IN, K1>, Keys.SelectorFunctionKeys<IN, K2>, String, TypeInformation<OUT>, TypeInformation<Tuple3<K1, K2, IN>>) - Constructor for class org.apache.flink.api.java.operators.translation.PlanUnwrappingSortedGroupCombineOperator
 
PlanUnwrappingSortedGroupCombineOperator.TupleUnwrappingGroupReducer<IN,OUT,K1,K2> - Class in org.apache.flink.api.java.operators.translation
 
PlanUnwrappingSortedReduceGroupOperator<IN,OUT,K1,K2> - Class in org.apache.flink.api.java.operators.translation
A reduce operator that takes 3-tuples (groupKey, sortKey, value), and applies the sorted group reduce operation only on the unwrapped values.
PlanUnwrappingSortedReduceGroupOperator(GroupReduceFunction<IN, OUT>, Keys.SelectorFunctionKeys<IN, K1>, Keys.SelectorFunctionKeys<IN, K2>, String, TypeInformation<OUT>, TypeInformation<Tuple3<K1, K2, IN>>, boolean) - Constructor for class org.apache.flink.api.java.operators.translation.PlanUnwrappingSortedReduceGroupOperator
 
PlanUnwrappingSortedReduceGroupOperator.TupleUnwrappingGroupCombinableGroupReducer<IN,OUT,K1,K2> - Class in org.apache.flink.api.java.operators.translation
 
PlanUnwrappingSortedReduceGroupOperator.TupleUnwrappingNonCombinableGroupReducer<IN,OUT,K1,K2> - Class in org.apache.flink.api.java.operators.translation
 
PLUS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Infix arithmetic plus operator, '+'.
Plus - Class in org.apache.flink.table.expressions
 
Plus(Expression, Expression) - Constructor for class org.apache.flink.table.expressions.Plus
 
plus(RelOptCost) - Method in class org.apache.flink.table.plan.cost.DataSetCost
 
Plus$ - Class in org.apache.flink.table.expressions
 
Plus$() - Constructor for class org.apache.flink.table.expressions.Plus$
 
Point() - Constructor for class org.apache.flink.examples.java.clustering.KMeans.Point
 
Point(double, double) - Constructor for class org.apache.flink.examples.java.clustering.KMeans.Point
 
Point(double, double) - Constructor for class org.apache.flink.examples.scala.clustering.KMeans.Point
 
Point() - Constructor for class org.apache.flink.graph.examples.EuclideanGraphWeighing.Point
 
Point(double, double) - Constructor for class org.apache.flink.graph.examples.EuclideanGraphWeighing.Point
 
Point$() - Constructor for class org.apache.flink.examples.scala.clustering.KMeans.Point$
 
POINTS - Static variable in class org.apache.flink.examples.java.clustering.util.KMeansData
 
PoissonSampler<T> - Class in org.apache.flink.api.java.sampling
A sampler implementation based on the Poisson Distribution.
PoissonSampler(double, long) - Constructor for class org.apache.flink.api.java.sampling.PoissonSampler
Create a poisson sampler which can sample elements with replacement.
PoissonSampler(double) - Constructor for class org.apache.flink.api.java.sampling.PoissonSampler
Create a poisson sampler which can sample elements with replacement.
PojoComparator<T> - Class in org.apache.flink.api.java.typeutils.runtime
 
PojoComparator(Field[], TypeComparator<?>[], TypeSerializer<T>, Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
PojoCsvInputFormat<OUT> - Class in org.apache.flink.api.java.io
 
PojoCsvInputFormat(Path, PojoTypeInfo<OUT>) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
 
PojoCsvInputFormat(Path, PojoTypeInfo<OUT>, String[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
 
PojoCsvInputFormat(Path, String, String, PojoTypeInfo<OUT>) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
 
PojoCsvInputFormat(Path, String, String, PojoTypeInfo<OUT>, String[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
 
PojoCsvInputFormat(Path, PojoTypeInfo<OUT>, int[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
 
PojoCsvInputFormat(Path, PojoTypeInfo<OUT>, String[], int[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
 
PojoCsvInputFormat(Path, String, String, PojoTypeInfo<OUT>, int[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
 
PojoCsvInputFormat(Path, String, String, PojoTypeInfo<OUT>, String[], int[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
 
PojoCsvInputFormat(Path, PojoTypeInfo<OUT>, boolean[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
 
PojoCsvInputFormat(Path, PojoTypeInfo<OUT>, String[], boolean[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
 
PojoCsvInputFormat(Path, String, String, PojoTypeInfo<OUT>, boolean[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
 
PojoCsvInputFormat(Path, String, String, PojoTypeInfo<OUT>, String[], boolean[]) - Constructor for class org.apache.flink.api.java.io.PojoCsvInputFormat
 
PojoDescriptor(int, scala.reflect.macros.Context.universe, Seq<org.apache.flink.api.scala.codegen.TypeDescriptors.FieldDescriptor>) - Constructor for class org.apache.flink.api.scala.codegen.TypeDescriptors.PojoDescriptor
 
PojoExample - Class in org.apache.flink.streaming.examples.wordcount
This example shows an implementation of WordCount without using the Tuple2 type, but a custom class.
PojoExample() - Constructor for class org.apache.flink.streaming.examples.wordcount.PojoExample
 
PojoExample.Tokenizer - Class in org.apache.flink.streaming.examples.wordcount
Implements the string tokenizer that splits sentences into words as a user-defined FlatMapFunction.
PojoExample.Word - Class in org.apache.flink.streaming.examples.wordcount
This is the POJO (Plain Old Java Object) that is being used for all the operations.
PojoField - Class in org.apache.flink.api.java.typeutils
Represent a field definition for PojoTypeInfo type of objects.
PojoField(Field, TypeInformation<?>) - Constructor for class org.apache.flink.api.java.typeutils.PojoField
 
PojoSerializer<T> - Class in org.apache.flink.api.java.typeutils.runtime
 
PojoSerializer(Class<T>, TypeSerializer<?>[], Field[], ExecutionConfig) - Constructor for class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
PojoSerializer(Class<T>, Field[], TypeSerializer<Object>[], LinkedHashMap<Class<?>, Integer>, TypeSerializer<?>[], HashMap<Class<?>, TypeSerializer<?>>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
PojoSerializer.PojoSerializerConfigSnapshot<T> - Class in org.apache.flink.api.java.typeutils.runtime
 
PojoSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
PojoSerializerConfigSnapshot(Class<T>, LinkedHashMap<String, Tuple2<TypeSerializer<?>, TypeSerializerConfigSnapshot>>, LinkedHashMap<Class<?>, Tuple2<TypeSerializer<?>, TypeSerializerConfigSnapshot>>, HashMap<Class<?>, Tuple2<TypeSerializer<?>, TypeSerializerConfigSnapshot>>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
 
PojoSerializerConfigSnapshot(Class<T>, LinkedHashMap<String, Tuple2<TypeSerializer<?>, TypeSerializerConfigSnapshot>>, LinkedHashMap<Class<?>, Tuple2<TypeSerializer<?>, TypeSerializerConfigSnapshot>>, HashMap<Class<?>, Tuple2<TypeSerializer<?>, TypeSerializerConfigSnapshot>>, boolean) - Constructor for class org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
 
pojoType(Class<T>, String...) - Method in class org.apache.flink.api.java.io.CsvReader
Configures the reader to read the CSV data and parse it to the given type.
PojoTypeInfo<T> - Class in org.apache.flink.api.java.typeutils
TypeInformation for "Java Beans"-style types.
PojoTypeInfo(Class<T>, List<PojoField>) - Constructor for class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
PojoTypeInfo.NamedFlatFieldDescriptor - Class in org.apache.flink.api.java.typeutils
 
poll() - Method in class org.apache.flink.runtime.jobmanager.scheduler.LifoSetQueue
 
poll() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
poll() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
Removes and returns the least element of the PriorityQueue in log(size) time.
poll() - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
 
poll() - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
Poll the first completed AsyncResult from the head of this queue.
poll() - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
 
poll() - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
Returns the queue's next element and removes it, the queue is non-empty.
pollBatch() - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
Returns all of the queue's current elements in a list, if the queue is non-empty.
POLLING_INTERVAL() - Method in class org.apache.flink.yarn.ApplicationClient
 
pollingTimer() - Method in class org.apache.flink.yarn.ApplicationClient
 
pollNext() - Method in class org.apache.flink.streaming.connectors.kafka.internal.Handover
Polls the next element from the Handover, possibly blocking until the next element is available.
pollTimeout - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
From Kafka's Javadoc: The time, in milliseconds, spent waiting in poll if data is not available.
PolynomialFeatures - Class in org.apache.flink.ml.preprocessing
Maps a vector into the polynomial feature space.
PolynomialFeatures() - Constructor for class org.apache.flink.ml.preprocessing.PolynomialFeatures
 
PolynomialFeatures$ - Class in org.apache.flink.ml.preprocessing
 
PolynomialFeatures$() - Constructor for class org.apache.flink.ml.preprocessing.PolynomialFeatures$
 
PolynomialFeatures.Degree$ - Class in org.apache.flink.ml.preprocessing
 
populateFlinkSecureConfigurations(Configuration) - Static method in class org.apache.flink.test.util.SecureTestEnvironment
 
port - Variable in class org.apache.flink.api.java.RemoteEnvironment
The port of the JobManager main actor system
port() - Method in class org.apache.flink.api.scala.FlinkILoop
 
port() - Method in class org.apache.flink.api.scala.FlinkShell.Config
 
PORT - Static variable in class org.apache.flink.configuration.JobManagerOptions
The config parameter defining the network port to connect to for communication with the job manager.
port - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
port() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.ResponseWebMonitorPort
 
port() - Method in class org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
Returns the port where the server should listen.
POSITION - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
position - Variable in class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
 
position(Expression) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Returns the position of string in an other string starting at 1.
position() - Method in class org.apache.flink.table.expressions.Overlay
 
Position - Class in org.apache.flink.table.expressions
Returns the position of string needle in string haystack.
Position(Expression, Expression) - Constructor for class org.apache.flink.table.expressions.Position
 
Position$ - Class in org.apache.flink.table.expressions
 
Position$() - Constructor for class org.apache.flink.table.expressions.Position$
 
positioned(Function0<Parsers.Parser<T>>) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.api.CurrentRange
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.api.CurrentRow
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.api.UnboundedRange
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.api.UnboundedRow
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Abs
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Acos
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.AggFunctionCall
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Alias
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.And
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.ArrayCardinality
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.ArrayConstructor
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.ArrayElement
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.ArrayElementAt
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Asc
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Asin
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Atan
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Avg
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Call
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Cast
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Ceil
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.CharLength
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Cos
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Cot
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Count
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.CurrentDate
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.CurrentTime
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.CurrentTimestamp
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Degrees
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Desc
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Div
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.EqualTo
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Exp
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Extract
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Flattening
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Floor
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.GetCompositeField
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.GreaterThan
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.GreaterThanOrEqual
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.If
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.InitCap
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.IsFalse
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.IsNotFalse
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.IsNotNull
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.IsNotTrue
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.IsNull
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.IsTrue
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.LessThan
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.LessThanOrEqual
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Like
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Literal
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Ln
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.LocalTime
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.LocalTimestamp
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Log10
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Lower
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Max
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Min
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Minus
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Mod
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Mul
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Not
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.NotEqualTo
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Null
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Or
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.OverCall
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Overlay
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Pi
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Plus
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Position
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Power
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.ProctimeAttribute
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Quarter
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Radians
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.ResolvedFieldReference
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Round
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.RowtimeAttribute
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.ScalarFunctionCall
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Sign
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Similar
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Sin
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Sqrt
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.StddevPop
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.StddevSamp
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Substring
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Sum
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Sum0
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.SymbolExpression
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.TableFunctionCall
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Tan
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.TemporalCeil
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.TemporalFloor
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.TemporalOverlaps
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Trim
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.UnaryMinus
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.UnresolvedAlias
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.UnresolvedFieldReference
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.UnresolvedOverCall
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.Upper
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.VarPop
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.VarSamp
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.WindowEnd
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.WindowReference
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.expressions.WindowStart
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.plan.logical.Aggregate
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.plan.logical.AliasNode
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.plan.logical.CatalogNode
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.plan.logical.Distinct
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.plan.logical.Filter
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.plan.logical.Intersect
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.plan.logical.Join
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.plan.logical.Limit
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.plan.logical.LogicalRelNode
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.plan.logical.LogicalTableFunctionCall
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.plan.logical.Minus
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.plan.logical.Project
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.plan.logical.Sort
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.plan.logical.Union
 
postOrderTransform(PartialFunction<A, A>) - Static method in class org.apache.flink.table.plan.logical.WindowAggregate
 
postOrderTransform(PartialFunction<A, A>) - Method in class org.apache.flink.table.plan.TreeNode
Do tree transformation in post order.
postPass(OptimizedPlan) - Method in class org.apache.flink.optimizer.postpass.GenericFlatTypePostPass
 
postPass(OptimizedPlan) - Method in class org.apache.flink.optimizer.postpass.JavaApiPostPass
 
postPass(OptimizedPlan) - Method in interface org.apache.flink.optimizer.postpass.OptimizerPostPass
Central post processing function.
postPassHelper - Variable in class org.apache.flink.optimizer.plan.BulkPartialSolutionPlanNode
 
postPassHelper - Variable in class org.apache.flink.optimizer.plan.SingleInputPlanNode
 
postPassHelper - Variable in class org.apache.flink.optimizer.plan.SolutionSetPlanNode
 
postPassHelper - Variable in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
 
postPassHelper - Variable in class org.apache.flink.optimizer.plan.WorksetPlanNode
 
postPassHelper1 - Variable in class org.apache.flink.optimizer.plan.DualInputPlanNode
 
postPassHelper2 - Variable in class org.apache.flink.optimizer.plan.DualInputPlanNode
 
postRestart(Throwable) - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
postRestart(Throwable) - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
postRestart(Throwable) - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
postRestart(Throwable) - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
postRestart(Throwable) - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
postRestart(Throwable) - Static method in class org.apache.flink.mesos.scheduler.Tasks
 
postRestart(Throwable) - Static method in class org.apache.flink.runtime.jobmanager.JobManager
 
postRestart(Throwable) - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
 
postRestart(Throwable) - Static method in class org.apache.flink.yarn.ApplicationClient
 
postRestart(Throwable) - Static method in class org.apache.flink.yarn.YarnTaskManager
 
postStop() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
 
postStop() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
postStop() - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
postStop() - Method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
postStop() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
postStop() - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
postStop() - Static method in class org.apache.flink.mesos.scheduler.Tasks
 
postStop() - Method in class org.apache.flink.runtime.client.JobClientActor
 
postStop() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
 
postStop() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
postStop() - Method in class org.apache.flink.runtime.metrics.dump.MetricQueryService
 
postStop() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
Called after the actor is stopped.
postStop() - Method in class org.apache.flink.yarn.ApplicationClient
 
postStop() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
postSubmit() - Method in class org.apache.flink.streaming.util.StreamingProgramTestBase
 
postSubmit() - Method in class org.apache.flink.test.util.JavaProgramTestBase
 
postSuperstep() - Method in class org.apache.flink.graph.gsa.ApplyFunction
This method is executed once per superstep after the vertex update function has been invoked for each vertex.
postSuperstep() - Method in class org.apache.flink.graph.gsa.GatherFunction
This method is executed once per superstep after the vertex update function has been invoked for each vertex.
postSuperstep() - Method in class org.apache.flink.graph.gsa.SumFunction
This method is executed once per superstep after the vertex update function has been invoked for each vertex.
postSuperstep() - Method in class org.apache.flink.graph.pregel.ComputeFunction
This method is executed once per superstep after the vertex update function has been invoked for each vertex.
postSuperstep() - Method in class org.apache.flink.graph.spargel.GatherFunction
This method is executed once per superstep after the gather function has been invoked for each vertex.
postSuperstep() - Method in class org.apache.flink.graph.spargel.ScatterFunction
This method is executed once per superstep after the scatter function has been invoked for each vertex.
postVisit(PlanNode) - Method in class org.apache.flink.optimizer.plantranslate.JobGraphGenerator
This method implements the post-visit during the depth-first traversal.
postVisit(PlanNode) - Method in class org.apache.flink.optimizer.traversals.BinaryUnionReplacer
 
postVisit(OptimizerNode) - Method in class org.apache.flink.optimizer.traversals.BranchesVisitor
 
postVisit(Operator<?>) - Method in class org.apache.flink.optimizer.traversals.GraphCreatingVisitor
 
postVisit(OptimizerNode) - Method in class org.apache.flink.optimizer.traversals.IdAndEstimatesVisitor
 
postVisit(OptimizerNode) - Method in class org.apache.flink.optimizer.traversals.InterestingPropertyVisitor
 
postVisit(PlanNode) - Method in class org.apache.flink.optimizer.traversals.PlanFinalizer
 
postVisit(PlanNode) - Method in class org.apache.flink.optimizer.traversals.RangePartitionRewriter
 
postVisit(OptimizerNode) - Method in class org.apache.flink.optimizer.traversals.StaticDynamicPathIdentifier
 
postVisit(Operator<?>) - Method in class org.apache.flink.optimizer.traversals.StepFunctionValidator
 
postVisit(OptimizerNode) - Method in class org.apache.flink.optimizer.traversals.UnionParallelismAndForwardEnforcer
 
postVisit(T) - Method in interface org.apache.flink.util.Visitor
 
POWER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Uses SqlOperatorTable.useDouble for its return type since we don't know what the result type will be by just looking at the operand types.
power(Expression) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Calculates the given number raised to the power of the other value.
POWER() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
POWER() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
Power - Class in org.apache.flink.table.expressions
 
Power(Expression, Expression) - Constructor for class org.apache.flink.table.expressions.Power
 
power(double, BigDecimal) - Method in class org.apache.flink.table.functions.utils.MathFunctions$
 
power(double, BigDecimal) - Static method in class org.apache.flink.table.functions.utils.MathFunctions
 
Power$ - Class in org.apache.flink.table.expressions
 
Power$() - Constructor for class org.apache.flink.table.expressions.Power$
 
POWER_DEC() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
POWER_DEC() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
POWER_DEC_DEC() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
POWER_DEC_DEC() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
preAggfunction() - Method in class org.apache.flink.table.runtime.aggregate.DataSetSlideWindowAggReduceCombineFunction
 
preAggfunction() - Method in class org.apache.flink.table.runtime.aggregate.DataSetTumbleTimeWindowAggReduceCombineFunction
 
preceding(String) - Method in class org.apache.flink.table.api.java.OverWindowWithOrderBy
Set the preceding offset (based on time or row-count intervals) for over window.
preceding() - Method in class org.apache.flink.table.api.OverWindow
 
preceding(Expression) - Method in class org.apache.flink.table.api.scala.OverWindowWithOrderBy
Set the preceding offset (based on time or row-count intervals) for over window.
preceding() - Method in class org.apache.flink.table.expressions.OverCall
 
Preconditions - Class in org.apache.flink.util
A collection of static utility methods to validate input.
PREDECESSORS - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
 
PredefinedOptions - Enum in org.apache.flink.contrib.streaming.state
The PredefinedOptions are configuration settings for the RocksDBStateBackend.
predict(DataSet<Testing>, ParameterMap, PredictDataSetOperation<Self, Testing, Prediction>) - Static method in class org.apache.flink.ml.classification.SVM
 
predict(DataSet<Testing>, ParameterMap, PredictDataSetOperation<Self, Testing, Prediction>) - Static method in class org.apache.flink.ml.nn.KNN
 
predict(Vector, WeightVector) - Method in class org.apache.flink.ml.optimization.LinearPrediction$
 
predict(Vector, WeightVector) - Static method in class org.apache.flink.ml.optimization.LinearPrediction
 
predict(Vector, WeightVector) - Method in class org.apache.flink.ml.optimization.PredictionFunction
 
predict(DataSet<Testing>, ParameterMap, PredictDataSetOperation<Self, Testing, Prediction>) - Static method in class org.apache.flink.ml.pipeline.ChainedPredictor
 
predict(Testing, Model) - Method in interface org.apache.flink.ml.pipeline.PredictOperation
Calculates the prediction for a single element given the model of the Predictor.
predict(DataSet<Testing>, ParameterMap, PredictDataSetOperation<Self, Testing, Prediction>) - Method in interface org.apache.flink.ml.pipeline.Predictor
Predict testing data according the learned model.
predict(DataSet<Testing>, ParameterMap, PredictDataSetOperation<Self, Testing, Prediction>) - Static method in class org.apache.flink.ml.recommendation.ALS
 
predict(DataSet<Testing>, ParameterMap, PredictDataSetOperation<Self, Testing, Prediction>) - Static method in class org.apache.flink.ml.regression.MultipleLinearRegression
 
predict(Integer) - Method in class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.Predictor
 
predict$default$2() - Static method in class org.apache.flink.ml.classification.SVM
 
predict$default$2() - Static method in class org.apache.flink.ml.nn.KNN
 
predict$default$2() - Static method in class org.apache.flink.ml.pipeline.ChainedPredictor
 
predict$default$2() - Static method in class org.apache.flink.ml.recommendation.ALS
 
predict$default$2() - Static method in class org.apache.flink.ml.regression.MultipleLinearRegression
 
predictDataSet(Self, ParameterMap, DataSet<Testing>) - Method in interface org.apache.flink.ml.pipeline.PredictDataSetOperation
Calculates the predictions for all elements in the DataSet input
PredictDataSetOperation<Self,Testing,Prediction> - Interface in org.apache.flink.ml.pipeline
Type class for the predict operation of Predictor.
predictionFunction() - Method in class org.apache.flink.ml.optimization.GenericLossFunction
 
PredictionFunction - Class in org.apache.flink.ml.optimization
An abstract class for prediction functions to be used in optimization
PredictionFunction() - Constructor for class org.apache.flink.ml.optimization.PredictionFunction
 
PredictOperation<Instance,Model,Testing,Prediction> - Interface in org.apache.flink.ml.pipeline
Type class for predict operation.
predictor() - Method in class org.apache.flink.ml.pipeline.ChainedPredictor
 
Predictor<Self> - Interface in org.apache.flink.ml.pipeline
Predictor trait for Flink's pipeline operators.
Predictor() - Constructor for class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.Predictor
 
Predictor$ - Class in org.apache.flink.ml.pipeline
 
Predictor$() - Constructor for class org.apache.flink.ml.pipeline.Predictor$
 
predictRating() - Method in class org.apache.flink.ml.recommendation.ALS$
Predict operation which calculates the matrix entry for the given indices
predictRating() - Static method in class org.apache.flink.ml.recommendation.ALS
Predict operation which calculates the matrix entry for the given indices
predictRatingInt() - Method in class org.apache.flink.ml.recommendation.ALS$
 
predictRatingInt() - Static method in class org.apache.flink.ml.recommendation.ALS
 
predictValues(ClassTag<T>, TypeInformation<T>) - Method in class org.apache.flink.ml.nn.KNN$
PredictDataSetOperation which calculates k-nearest neighbors of the given testing data set.
predictValues(ClassTag<T>, TypeInformation<T>) - Static method in class org.apache.flink.ml.nn.KNN
PredictDataSetOperation which calculates k-nearest neighbors of the given testing data set.
predictVectors() - Method in class org.apache.flink.ml.classification.SVM$
Provides the operation that makes the predictions for individual examples.
predictVectors() - Static method in class org.apache.flink.ml.classification.SVM
Provides the operation that makes the predictions for individual examples.
predictVectors() - Method in class org.apache.flink.ml.regression.MultipleLinearRegression$
 
predictVectors() - Static method in class org.apache.flink.ml.regression.MultipleLinearRegression
 
preferredResources - Variable in class org.apache.flink.api.java.operators.Operator
 
preferredResources() - Static method in class org.apache.flink.api.scala.CrossDataSet
 
preferredResources() - Method in class org.apache.flink.api.scala.DataSet
Returns the preferred resources of this operation.
preferredResources() - Method in class org.apache.flink.streaming.api.scala.DataStream
Returns the preferred resources of this operation.
prefixAs() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
prefixAs() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
prefixCast() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
prefixCast() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
prefixCeil() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
prefixCeil() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
prefixed() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
prefixed() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
prefixExtract() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
prefixExtract() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
prefixFlattening() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
prefixFlattening() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
prefixFloor() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
prefixFloor() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
prefixFunctionCall() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
prefixFunctionCall() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
prefixFunctionCallOneArg() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
prefixFunctionCallOneArg() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
prefixGet() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
prefixGet() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
prefixIf() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
prefixIf() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
prefixToDate() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
prefixToDate() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
prefixToTime() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
prefixToTime() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
prefixToTimestamp() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
prefixToTimestamp() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
prefixTrim() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
prefixTrim() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
prefixTrimWithoutArgs() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
prefixTrimWithoutArgs() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
PregelSSSP - Class in org.apache.flink.graph.examples
This example shows how to use Gelly's Vertex-Centric iterations.
PregelSSSP() - Constructor for class org.apache.flink.graph.examples.PregelSSSP
 
PregelSSSP.SSSPCombiner - Class in org.apache.flink.graph.examples
The messages combiner.
PregelSSSP.SSSPComputeFunction - Class in org.apache.flink.graph.examples
The compute function for SSSP
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.api.CurrentRange
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.api.CurrentRow
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.api.UnboundedRange
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.api.UnboundedRow
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Abs
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Acos
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.AggFunctionCall
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Alias
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.And
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.ArrayCardinality
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.ArrayConstructor
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.ArrayElement
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.ArrayElementAt
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Asc
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Asin
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Atan
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Avg
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Call
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Cast
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Ceil
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.CharLength
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Cos
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Cot
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Count
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.CurrentDate
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.CurrentTime
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.CurrentTimestamp
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Degrees
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Desc
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Div
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.EqualTo
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Exp
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Extract
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Flattening
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Floor
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.GetCompositeField
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.GreaterThan
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.GreaterThanOrEqual
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.If
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.InitCap
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.IsFalse
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.IsNotFalse
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.IsNotNull
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.IsNotTrue
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.IsNull
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.IsTrue
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.LessThan
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.LessThanOrEqual
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Like
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Literal
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Ln
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.LocalTime
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.LocalTimestamp
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Log10
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Lower
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Max
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Min
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Minus
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Mod
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Mul
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Not
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.NotEqualTo
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Null
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Or
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.OverCall
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Overlay
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Pi
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Plus
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Position
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Power
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.ProctimeAttribute
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Quarter
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Radians
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.ResolvedFieldReference
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Round
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.RowtimeAttribute
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.ScalarFunctionCall
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Sign
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Similar
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Sin
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Sqrt
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.StddevPop
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.StddevSamp
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Substring
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Sum
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Sum0
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.SymbolExpression
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.TableFunctionCall
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Tan
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.TemporalCeil
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.TemporalFloor
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.TemporalOverlaps
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Trim
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.UnaryMinus
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.UnresolvedAlias
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.UnresolvedFieldReference
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.UnresolvedOverCall
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.Upper
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.VarPop
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.VarSamp
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.WindowEnd
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.WindowReference
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.expressions.WindowStart
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.plan.logical.Aggregate
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.plan.logical.AliasNode
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.plan.logical.CatalogNode
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.plan.logical.Distinct
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.plan.logical.Filter
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.plan.logical.Intersect
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.plan.logical.Join
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.plan.logical.Limit
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.plan.logical.LogicalRelNode
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.plan.logical.LogicalTableFunctionCall
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.plan.logical.Minus
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.plan.logical.Project
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.plan.logical.Sort
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.plan.logical.Union
 
preOrderVisit(Function1<A, BoxedUnit>) - Static method in class org.apache.flink.table.plan.logical.WindowAggregate
 
preOrderVisit(Function1<A, BoxedUnit>) - Method in class org.apache.flink.table.plan.TreeNode
Runs the given function first on the node and then recursively on all its children.
prepare() - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
 
prepare() - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
prepare() - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
 
prepare() - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
 
prepare() - Method in class org.apache.flink.runtime.operators.AllReduceDriver
 
prepare() - Method in class org.apache.flink.runtime.operators.CoGroupDriver
 
prepare() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
 
prepare() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
 
prepare() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
 
prepare() - Method in class org.apache.flink.runtime.operators.CrossDriver
 
prepare() - Method in interface org.apache.flink.runtime.operators.Driver
This method is called before the user code is opened.
prepare() - Method in class org.apache.flink.runtime.operators.FlatMapDriver
 
prepare() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
 
prepare() - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
 
prepare() - Method in class org.apache.flink.runtime.operators.JoinDriver
 
prepare() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
 
prepare() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
 
prepare() - Method in class org.apache.flink.runtime.operators.MapDriver
 
prepare() - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
 
prepare() - Method in class org.apache.flink.runtime.operators.NoOpDriver
 
prepare() - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
 
prepare() - Method in class org.apache.flink.runtime.operators.ReduceDriver
 
prepare() - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
 
prepare(Map, TopologyContext, OutputCollector) - Method in class org.apache.flink.storm.exclamation.operators.ExclamationBolt
 
prepare(Map, TopologyContext, OutputCollector) - Method in class org.apache.flink.storm.split.operators.VerifyAndEnrichBolt
 
prepare(Map, TopologyContext, OutputCollector) - Method in class org.apache.flink.storm.util.AbstractBoltSink
 
prepare(Map, TopologyContext, OutputCollector) - Method in class org.apache.flink.storm.wordcount.operators.BoltCounter
 
prepare(Map, TopologyContext, OutputCollector) - Method in class org.apache.flink.storm.wordcount.operators.BoltCounterByName
 
prepare(Map, TopologyContext, OutputCollector) - Method in class org.apache.flink.storm.wordcount.operators.BoltTokenizer
 
prepare(Map, TopologyContext, OutputCollector) - Method in class org.apache.flink.storm.wordcount.operators.BoltTokenizerByName
 
prepare(TemporaryFolder) - Static method in class org.apache.flink.test.util.SecureTestEnvironment
 
prepareAndCommitOffsets(Map<KafkaTopicPartition, Long>) - Method in class org.apache.flink.streaming.connectors.kafka.internals.ZookeeperOffsetHandler
Commits offsets for Kafka partitions to ZooKeeper.
prepareNextPartition() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
prepareNextPartition() - Method in class org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
 
preparePlanMode() - Method in class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
 
prepareProbePhase(IOManager, FileIOChannel.Enumerator, LinkedBlockingQueue<MemorySegment>) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
 
prepareSimple(Map<?, ?>, TopologyContext) - Method in class org.apache.flink.storm.util.AbstractBoltSink
 
prepareSimple(Map, TopologyContext) - Method in class org.apache.flink.storm.util.BoltFileSink
 
prepareSimple(Map, TopologyContext) - Method in class org.apache.flink.storm.util.BoltPrintSink
 
preRestart(Throwable, Option<Object>) - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
preRestart(Throwable, Option<Object>) - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
preRestart(Throwable, Option<Object>) - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
preRestart(Throwable, Option<Object>) - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
preRestart(Throwable, Option<Object>) - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
preRestart(Throwable, Option<Object>) - Static method in class org.apache.flink.mesos.scheduler.Tasks
 
preRestart(Throwable, Option<Object>) - Static method in class org.apache.flink.runtime.jobmanager.JobManager
 
preRestart(Throwable, Option<Object>) - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
 
preRestart(Throwable, Option<Object>) - Static method in class org.apache.flink.yarn.ApplicationClient
 
preRestart(Throwable, Option<Object>) - Static method in class org.apache.flink.yarn.YarnTaskManager
 
preStart() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
preStart() - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
preStart() - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
preStart() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
preStart() - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
preStart() - Static method in class org.apache.flink.mesos.scheduler.Tasks
 
preStart() - Method in class org.apache.flink.runtime.akka.QuarantineMonitor
 
preStart() - Method in class org.apache.flink.runtime.client.JobClientActor
 
preStart() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
 
preStart() - Method in class org.apache.flink.runtime.jobmanager.JobManager
Run when the job manager is started.
preStart() - Method in class org.apache.flink.runtime.jobmanager.MemoryArchivist
 
preStart() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
Called prior to the actor receiving any messages.
preStart() - Method in class org.apache.flink.yarn.ApplicationClient
 
preStart() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
preSubmit() - Method in class org.apache.flink.streaming.util.StreamingProgramTestBase
 
preSubmit() - Method in class org.apache.flink.test.util.JavaProgramTestBase
 
preSuperstep() - Method in class org.apache.flink.graph.gsa.ApplyFunction
This method is executed once per superstep before the vertex update function is invoked for each vertex.
preSuperstep() - Method in class org.apache.flink.graph.gsa.GatherFunction
This method is executed once per superstep before the vertex update function is invoked for each vertex.
preSuperstep() - Method in class org.apache.flink.graph.gsa.SumFunction
This method is executed once per superstep before the vertex update function is invoked for each vertex.
preSuperstep() - Method in class org.apache.flink.graph.pregel.ComputeFunction
This method is executed once per superstep before the vertex update function is invoked for each vertex.
preSuperstep() - Method in class org.apache.flink.graph.spargel.GatherFunction
This method is executed once per superstep before the gather function is invoked for each vertex.
preSuperstep() - Method in class org.apache.flink.graph.spargel.ScatterFunction
This method is executed once per superstep before the scatter function is invoked for each vertex.
PREV - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
PREV function to be used within MATCH_RECOGNIZE.
preValidateCall(SqlValidator, SqlValidatorScope, SqlCall) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
preValidateCall(SqlValidator, SqlValidatorScope, SqlCall) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
preValidateCall(SqlValidator, SqlValidatorScope, SqlCall) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
preValidateCall(SqlValidator, SqlValidatorScope, SqlCall) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
PreviewPlanEnvironment - Class in org.apache.flink.client.program
Environment to extract the pre-optimized plan.
PreviewPlanEnvironment() - Constructor for class org.apache.flink.client.program.PreviewPlanEnvironment
 
previousPanes - Variable in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
The previous time panes, ordered by time (early to late).
preVisit(PlanNode) - Method in class org.apache.flink.optimizer.plantranslate.JobGraphGenerator
This methods implements the pre-visiting during a depth-first traversal.
preVisit(PlanNode) - Method in class org.apache.flink.optimizer.traversals.BinaryUnionReplacer
 
preVisit(OptimizerNode) - Method in class org.apache.flink.optimizer.traversals.BranchesVisitor
 
preVisit(Operator<?>) - Method in class org.apache.flink.optimizer.traversals.GraphCreatingVisitor
 
preVisit(OptimizerNode) - Method in class org.apache.flink.optimizer.traversals.IdAndEstimatesVisitor
 
preVisit(OptimizerNode) - Method in class org.apache.flink.optimizer.traversals.InterestingPropertyVisitor
 
preVisit(PlanNode) - Method in class org.apache.flink.optimizer.traversals.PlanFinalizer
 
preVisit(PlanNode) - Method in class org.apache.flink.optimizer.traversals.RangePartitionRewriter
 
preVisit(OptimizerNode) - Method in class org.apache.flink.optimizer.traversals.StaticDynamicPathIdentifier
 
preVisit(Operator<?>) - Method in class org.apache.flink.optimizer.traversals.StepFunctionValidator
 
preVisit(OptimizerNode) - Method in class org.apache.flink.optimizer.traversals.UnionParallelismAndForwardEnforcer
 
preVisit(T) - Method in interface org.apache.flink.util.Visitor
 
primitive(Object) - Method in class org.apache.flink.contrib.tweetinputformat.io.TweetHandler
 
PRIMITIVE_ARRAY(TypeInformation<?>) - Method in class org.apache.flink.table.api.Types$
Generates type information for an array consisting of Java primitive elements.
PRIMITIVE_ARRAY(TypeInformation<?>) - Static method in class org.apache.flink.table.api.Types
Generates type information for an array consisting of Java primitive elements.
PRIMITIVE_ARRAY() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
PRIMITIVE_ARRAY() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
PrimitiveArrayComparator<T,C extends BasicTypeComparator> - Class in org.apache.flink.api.common.typeutils.base.array
 
PrimitiveArrayComparator(boolean, C) - Constructor for class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
PrimitiveArrayTypeInfo<T> - Class in org.apache.flink.api.common.typeinfo
A TypeInformation for arrays of primitive types (int, long, double, ...).
primitiveDefaultValue(TypeInformation<?>) - Method in class org.apache.flink.table.codegen.CodeGenUtils$
 
primitiveDefaultValue(TypeInformation<?>) - Static method in class org.apache.flink.table.codegen.CodeGenUtils
 
PrimitiveDescriptor(int, scala.reflect.macros.Context.universe, scala.reflect.macros.Context.universe, scala.reflect.macros.Context.universe) - Constructor for class org.apache.flink.api.scala.codegen.TypeDescriptors.PrimitiveDescriptor
 
PrimitiveInputFormat<OT> - Class in org.apache.flink.api.java.io
An input format that reads single field primitive data from a given file.
PrimitiveInputFormat(Path, Class<OT>) - Constructor for class org.apache.flink.api.java.io.PrimitiveInputFormat
 
PrimitiveInputFormat(Path, String, Class<OT>) - Constructor for class org.apache.flink.api.java.io.PrimitiveInputFormat
 
primitives() - Method in interface org.apache.flink.api.scala.codegen.TypeAnalyzer
 
primitiveTypeTermForTypeInfo(TypeInformation<?>) - Method in class org.apache.flink.table.codegen.CodeGenUtils$
 
primitiveTypeTermForTypeInfo(TypeInformation<?>) - Static method in class org.apache.flink.table.codegen.CodeGenUtils
 
print() - Method in class org.apache.flink.api.java.DataSet
Prints the elements in a DataSet to the standard output stream System.out of the JVM that calls the print() method.
print(String) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
print() - Static method in class org.apache.flink.api.scala.CrossDataSet
 
print(String) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
print() - Method in class org.apache.flink.api.scala.DataSet
Prints the elements in a DataSet to the standard output stream System.out of the JVM that calls the print() method.
print(String) - Method in class org.apache.flink.api.scala.DataSet
Deprecated.
print(String) - Method in class org.apache.flink.graph.drivers.ClusteringCoefficient
 
print(String) - Method in class org.apache.flink.graph.drivers.ConnectedComponents
 
print(String) - Method in class org.apache.flink.graph.drivers.EdgeList
 
print(String) - Method in class org.apache.flink.graph.drivers.GraphMetrics
 
Print - Interface in org.apache.flink.graph.drivers.output
Print algorithm output.
print(String) - Method in interface org.apache.flink.graph.drivers.output.Print
Print execution results.
print(String) - Method in class org.apache.flink.graph.drivers.SimpleDriver
Print execution results.
print(String) - Method in class org.apache.flink.graph.drivers.TriangleListing
 
print() - Method in class org.apache.flink.streaming.api.datastream.DataStream
Writes a DataStream to the standard output stream (stdout).
print() - Method in class org.apache.flink.streaming.api.scala.DataStream
Writes a DataStream to the standard output stream (stdout).
PrintableResult - Interface in org.apache.flink.graph.asm.result
Base interface for GraphAlgorithm results.
printHelp() - Static method in class org.apache.flink.client.cli.CliFrontendParser
Prints the help for the client.
printHelpForCancel() - Static method in class org.apache.flink.client.cli.CliFrontendParser
 
printHelpForInfo() - Static method in class org.apache.flink.client.cli.CliFrontendParser
 
printHelpForList() - Static method in class org.apache.flink.client.cli.CliFrontendParser
 
printHelpForRun() - Static method in class org.apache.flink.client.cli.CliFrontendParser
 
printHelpForSavepoint() - Static method in class org.apache.flink.client.cli.CliFrontendParser
 
printHelpForStop() - Static method in class org.apache.flink.client.cli.CliFrontendParser
 
PrintingOutputFormat<T> - Class in org.apache.flink.api.java.io
 
PrintingOutputFormat() - Constructor for class org.apache.flink.api.java.io.PrintingOutputFormat
Instantiates a printing output format that prints to standard out.
PrintingOutputFormat(boolean) - Constructor for class org.apache.flink.api.java.io.PrintingOutputFormat
Instantiates a printing output format that prints to standard out.
PrintingOutputFormat(String, boolean) - Constructor for class org.apache.flink.api.java.io.PrintingOutputFormat
Instantiates a printing output format that prints to standard out with a prefixed message.
printOnTaskManager(String) - Method in class org.apache.flink.api.java.DataSet
Writes a DataSet to the standard output streams (stdout) of the TaskManagers that execute the program (or more specifically, the data sink operators).
printOnTaskManager(String) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
printOnTaskManager(String) - Method in class org.apache.flink.api.scala.DataSet
Writes a DataSet to the standard output streams (stdout) of the TaskManagers that execute the program (or more specifically, the data sink operators).
PrintSampleStream - Class in org.apache.flink.storm.print
Prints incoming tweets.
PrintSampleStream() - Constructor for class org.apache.flink.storm.print.PrintSampleStream
 
printSchema() - Method in class org.apache.flink.table.api.Table
Prints the schema of this table to the console in a tree format.
PrintSinkFunction<IN> - Class in org.apache.flink.streaming.api.functions.sink
Implementation of the SinkFunction writing every tuple to the standard output or standard error stream.
PrintSinkFunction() - Constructor for class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
Instantiates a print sink function that prints to standard out.
PrintSinkFunction(boolean) - Constructor for class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
Instantiates a print sink function that prints to standard out.
printStackTrace(PrintStream) - Method in exception org.apache.flink.runtime.util.SerializedThrowable
 
printStackTrace(PrintWriter) - Method in exception org.apache.flink.runtime.util.SerializedThrowable
 
printStackTrace() - Static method in exception org.apache.flink.table.api.AmbiguousTableSourceConverterException
 
printStackTrace(PrintStream) - Static method in exception org.apache.flink.table.api.AmbiguousTableSourceConverterException
 
printStackTrace(PrintWriter) - Static method in exception org.apache.flink.table.api.AmbiguousTableSourceConverterException
 
printStackTrace() - Static method in exception org.apache.flink.table.api.CatalogAlreadyExistException
 
printStackTrace(PrintStream) - Static method in exception org.apache.flink.table.api.CatalogAlreadyExistException
 
printStackTrace(PrintWriter) - Static method in exception org.apache.flink.table.api.CatalogAlreadyExistException
 
printStackTrace() - Static method in exception org.apache.flink.table.api.CatalogNotExistException
 
printStackTrace(PrintStream) - Static method in exception org.apache.flink.table.api.CatalogNotExistException
 
printStackTrace(PrintWriter) - Static method in exception org.apache.flink.table.api.CatalogNotExistException
 
printStackTrace() - Static method in exception org.apache.flink.table.api.ExpressionParserException
 
printStackTrace(PrintStream) - Static method in exception org.apache.flink.table.api.ExpressionParserException
 
printStackTrace(PrintWriter) - Static method in exception org.apache.flink.table.api.ExpressionParserException
 
printStackTrace() - Static method in exception org.apache.flink.table.api.ExternalCatalogAlreadyExistException
 
printStackTrace(PrintStream) - Static method in exception org.apache.flink.table.api.ExternalCatalogAlreadyExistException
 
printStackTrace(PrintWriter) - Static method in exception org.apache.flink.table.api.ExternalCatalogAlreadyExistException
 
printStackTrace() - Static method in exception org.apache.flink.table.api.ExternalCatalogNotExistException
 
printStackTrace(PrintStream) - Static method in exception org.apache.flink.table.api.ExternalCatalogNotExistException
 
printStackTrace(PrintWriter) - Static method in exception org.apache.flink.table.api.ExternalCatalogNotExistException
 
printStackTrace() - Static method in exception org.apache.flink.table.api.NoMatchedTableSourceConverterException
 
printStackTrace(PrintStream) - Static method in exception org.apache.flink.table.api.NoMatchedTableSourceConverterException
 
printStackTrace(PrintWriter) - Static method in exception org.apache.flink.table.api.NoMatchedTableSourceConverterException
 
printStackTrace() - Static method in exception org.apache.flink.table.api.SqlParserException
 
printStackTrace(PrintStream) - Static method in exception org.apache.flink.table.api.SqlParserException
 
printStackTrace(PrintWriter) - Static method in exception org.apache.flink.table.api.SqlParserException
 
printStackTrace() - Static method in exception org.apache.flink.table.api.TableAlreadyExistException
 
printStackTrace(PrintStream) - Static method in exception org.apache.flink.table.api.TableAlreadyExistException
 
printStackTrace(PrintWriter) - Static method in exception org.apache.flink.table.api.TableAlreadyExistException
 
printStackTrace() - Static method in exception org.apache.flink.table.api.TableException
 
printStackTrace(PrintStream) - Static method in exception org.apache.flink.table.api.TableException
 
printStackTrace(PrintWriter) - Static method in exception org.apache.flink.table.api.TableException
 
printStackTrace() - Static method in exception org.apache.flink.table.api.TableNotExistException
 
printStackTrace(PrintStream) - Static method in exception org.apache.flink.table.api.TableNotExistException
 
printStackTrace(PrintWriter) - Static method in exception org.apache.flink.table.api.TableNotExistException
 
printStackTrace() - Static method in exception org.apache.flink.table.api.UnresolvedException
 
printStackTrace(PrintStream) - Static method in exception org.apache.flink.table.api.UnresolvedException
 
printStackTrace(PrintWriter) - Static method in exception org.apache.flink.table.api.UnresolvedException
 
printStackTrace() - Static method in exception org.apache.flink.table.api.ValidationException
 
printStackTrace(PrintStream) - Static method in exception org.apache.flink.table.api.ValidationException
 
printStackTrace(PrintWriter) - Static method in exception org.apache.flink.table.api.ValidationException
 
printToErr() - Method in class org.apache.flink.api.java.DataSet
Prints the elements in a DataSet to the standard error stream System.err of the JVM that calls the print() method.
printToErr(String) - Method in class org.apache.flink.api.java.DataSet
Deprecated.
printToErr() - Static method in class org.apache.flink.api.scala.CrossDataSet
 
printToErr(String) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
printToErr() - Method in class org.apache.flink.api.scala.DataSet
Prints the elements in a DataSet to the standard error stream System.err of the JVM that calls the print() method.
printToErr(String) - Method in class org.apache.flink.api.scala.DataSet
Deprecated.
printToErr() - Method in class org.apache.flink.streaming.api.datastream.DataStream
Writes a DataStream to the standard output stream (stderr).
printToErr() - Method in class org.apache.flink.streaming.api.scala.DataStream
Writes a DataStream to the standard output stream (stderr).
printToLogger(Logger) - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
printTree() - Method in class org.apache.flink.ml.nn.QuadTree
Prints tree for testing/debugging
printWelcome() - Method in class org.apache.flink.api.scala.FlinkILoop
custom welcome message
privateDuplicate(TupleComparatorBase<T>) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
probeIterator - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
Iterator over the elements from the probe side.
Prober(TypeComparator<PT>, TypePairComparator<PT, BT>) - Constructor for class org.apache.flink.api.common.operators.util.JoinHashMap.Prober
 
probeSideBuffer - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
 
probeSideChannel - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
 
probeSideRecordCounter - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
 
probeSideSerializer - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
The utilities to serialize the probe side data types.
probeSideSerializer - Variable in class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstHashJoinIterator
 
probeSideSerializer - Variable in class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondHashJoinIterator
 
probeSideSerializer - Variable in class org.apache.flink.runtime.operators.hash.ReusingBuildFirstHashJoinIterator
 
probeSideSerializer - Variable in class org.apache.flink.runtime.operators.hash.ReusingBuildSecondHashJoinIterator
 
probeTypeComparator - Variable in class org.apache.flink.runtime.operators.hash.AbstractHashTableProber
 
PROCEDURE_CALL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
process(T, long) - Method in class org.apache.flink.cep.nfa.NFA
Processes the next input event.
process(ProcessAllWindowFunction<T, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
process(ProcessAllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
process(CoProcessFunction<IN1, IN2, R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
Applies the given CoProcessFunction on the connected input streams, thereby creating a transformed output stream.
process(CoProcessFunction<IN1, IN2, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
Applies the given CoProcessFunction on the connected input streams, thereby creating a transformed output stream.
process(ProcessFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Applies the given ProcessFunction on the input stream, thereby creating a transformed output stream.
process(ProcessFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Applies the given ProcessFunction on the input stream, thereby creating a transformed output stream.
process(ProcessFunction<T, R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Applies the given ProcessFunction on the input stream, thereby creating a transformed output stream.
process(ProcessFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Applies the given ProcessFunction on the input stream, thereby creating a transformed output stream.
process(ProcessWindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
process(ProcessWindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
process(ProcessAllWindowFunction<T, R, W>.Context, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessAllWindowFunction
Deprecated.
 
process(K, ProcessWindowFunction<T, R, K, W>.Context, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessWindowFunction
Deprecated.
 
process(ProcessAllWindowFunction<IN, OUT, W>.Context, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction
Evaluates the window and outputs none or several elements.
process(KEY, ProcessWindowFunction<IN, OUT, KEY, W>.Context, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction
Evaluates the window and outputs none or several elements.
process(ProcessAllWindowFunction<T, R, W>.Context, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
 
process(K, ProcessWindowFunction<T, R, K, W>.Context, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
 
process(ProcessAllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Applies the given window function to each window.
process(CoProcessFunction<IN1, IN2, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.ConnectedStreams
Applies the given CoProcessFunction on the connected input streams, thereby creating a transformed output stream.
process(ProcessFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Applies the given ProcessFunction on the input stream, thereby creating a transformed output stream.
process(ProcessAllWindowFunction<IN, OUT, W>.Context, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.api.scala.function.ProcessAllWindowFunction
Evaluates the window and outputs none or several elements.
process(KEY, ProcessWindowFunction<IN, OUT, KEY, W>.Context, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.api.scala.function.ProcessWindowFunction
Evaluates the window and outputs none or several elements.
process(ProcessAllWindowFunction<IN, OUT, W>.Context, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.api.scala.function.util.ScalaProcessAllWindowFunctionWrapper
 
process(KEY, ProcessWindowFunction<IN, OUT, KEY, W>.Context, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.api.scala.function.util.ScalaProcessWindowFunctionWrapper
 
process(ProcessFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.KeyedStream
Applies the given ProcessFunction on the input stream, thereby creating a transformed output stream.
process(ProcessWindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Applies the given window function to each window.
process(T, RuntimeContext, RequestIndexer) - Method in interface org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkFunction
Process the incoming element to produce multiple ActionsRequests.
process(T, RuntimeContext, RequestIndexer) - Method in interface org.apache.flink.streaming.connectors.elasticsearch2.ElasticsearchSinkFunction
Deprecated.
 
process(Byte, W, InternalWindowFunction.InternalWindowContext, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessAllWindowFunction
 
process(K, W, InternalWindowFunction.InternalWindowContext, Iterable<T>, Collector<R>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalAggregateProcessWindowFunction
 
process(Byte, W, InternalWindowFunction.InternalWindowContext, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableAllWindowFunction
 
process(Byte, W, InternalWindowFunction.InternalWindowContext, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessAllWindowFunction
 
process(KEY, W, InternalWindowFunction.InternalWindowContext, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableProcessWindowFunction
 
process(KEY, W, InternalWindowFunction.InternalWindowContext, Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalIterableWindowFunction
 
process(Byte, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueAllWindowFunction
 
process(Byte, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessAllWindowFunction
 
process(KEY, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueProcessWindowFunction
 
process(KEY, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalSingleValueWindowFunction
 
process(KEY, W, InternalWindowFunction.InternalWindowContext, IN, Collector<OUT>) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction
Evaluates the window and outputs none or several elements.
ProcessAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
Base abstract class for functions that are evaluated over non-keyed windows using a context for retrieving extra information.
ProcessAllWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction
 
ProcessAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.api.scala.function
Base abstract class for functions that are evaluated over keyed (grouped) windows using a context for retrieving extra information.
ProcessAllWindowFunction() - Constructor for class org.apache.flink.streaming.api.scala.function.ProcessAllWindowFunction
 
ProcessAllWindowFunction.Context - Class in org.apache.flink.streaming.api.functions.windowing
The context holding window metadata.
ProcessAllWindowFunction.Context - Class in org.apache.flink.streaming.api.scala.function
The context holding window metadata
processContext - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
processElement(StreamRecord<IN>) - Method in class org.apache.flink.cep.operator.AbstractKeyedCEPPatternOperator
 
processElement(StreamRecord<IN>) - Method in class org.apache.flink.storm.wrappers.BoltWrapper
 
processElement(StreamRecord<StormTuple<IN>>) - Method in class org.apache.flink.storm.wrappers.MergedInputsBoltWrapper
 
processElement(I, ProcessFunction<I, O>.Context, Collector<O>) - Method in class org.apache.flink.streaming.api.functions.ProcessFunction
Process one element from the input stream.
processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.functions.query.QueryableAppendingStateOperator
 
processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.functions.query.QueryableValueStateOperator
 
processElement(StreamRecord<TimestampedFileInputSplit>) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
 
processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.KeyedProcessOperator
 
processElement(StreamRecord<IN>) - Method in interface org.apache.flink.streaming.api.operators.OneInputStreamOperator
Processes one element that arrived at this operator.
processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.ProcessOperator
 
processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamFilter
 
processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamFlatMap
 
processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamGroupedFold
Deprecated.
 
processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamGroupedReduce
 
processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamMap
 
processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamProject
 
processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.api.operators.StreamSink
 
processElement(StreamRecord<T>) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
Process method for using the sink with timestamp support.
processElement(String, ProcessFunction<String, Tuple2<String, Integer>>.Context, Collector<Tuple2<String, Integer>>) - Method in class org.apache.flink.streaming.examples.sideoutput.SideOutputExample.Tokenizer
 
processElement(StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.operators.ExtractTimestampsOperator
Deprecated.
 
processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
 
processElement(StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndPeriodicWatermarksOperator
 
processElement(StreamRecord<T>) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndPunctuatedWatermarksOperator
 
processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
Deprecated.
 
processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.EvictingWindowOperator
 
processElement(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
processElement(CRow, ProcessFunction<CRow, CRow>.Context, Collector<CRow>) - Method in class org.apache.flink.table.runtime.aggregate.GroupAggProcessFunction
 
processElement(CRow, ProcessFunction<CRow, CRow>.Context, Collector<CRow>) - Method in class org.apache.flink.table.runtime.aggregate.ProcTimeBoundedRangeOver
 
processElement(CRow, ProcessFunction<CRow, CRow>.Context, Collector<CRow>) - Method in class org.apache.flink.table.runtime.aggregate.ProcTimeBoundedRowsOver
 
processElement(CRow, ProcessFunction<CRow, CRow>.Context, Collector<CRow>) - Method in class org.apache.flink.table.runtime.aggregate.ProcTimeUnboundedOver
 
processElement(CRow, ProcessFunction<CRow, CRow>.Context, Collector<CRow>) - Method in class org.apache.flink.table.runtime.aggregate.RowTimeBoundedRangeOver
 
processElement(CRow, ProcessFunction<CRow, CRow>.Context, Collector<CRow>) - Method in class org.apache.flink.table.runtime.aggregate.RowTimeBoundedRowsOver
 
processElement(CRow, ProcessFunction<CRow, CRow>.Context, Collector<CRow>) - Method in class org.apache.flink.table.runtime.aggregate.RowTimeUnboundedOver
Puts an element from the input stream into state if it is not late.
processElement(CRow, ProcessFunction<CRow, CRow>.Context, Collector<CRow>) - Method in class org.apache.flink.table.runtime.CRowCorrelateProcessRunner
 
processElement(CRow, ProcessFunction<CRow, CRow>.Context, Collector<CRow>) - Method in class org.apache.flink.table.runtime.CRowProcessRunner
 
processElement1(IN1, CoProcessFunction<IN1, IN2, OUT>.Context, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction
This method is called for each element in the first of the connected streams.
processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.CoProcessOperator
 
processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
 
processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.CoStreamMap
 
processElement1(StreamRecord<IN1>) - Method in class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
 
processElement1(StreamRecord<IN1>) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
Processes one element that arrived on the first input of this two-input operator.
processElement2(IN2, CoProcessFunction<IN1, IN2, OUT>.Context, Collector<OUT>) - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction
This method is called for each element in the second of the connected streams.
processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.CoProcessOperator
 
processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.CoStreamFlatMap
 
processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.CoStreamMap
 
processElement2(StreamRecord<IN2>) - Method in class org.apache.flink.streaming.api.operators.co.KeyedCoProcessOperator
 
processElement2(StreamRecord<IN2>) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
Processes one element that arrived on the second input of this two-input operator.
processElementsWithSameTimestamp(List<Row>, Row, Collector<CRow>) - Method in class org.apache.flink.table.runtime.aggregate.RowTimeUnboundedOver
Process the same timestamp datas, the mechanism is different between rows and range window.
processElementsWithSameTimestamp(List<Row>, Row, Collector<CRow>) - Method in class org.apache.flink.table.runtime.aggregate.RowTimeUnboundedRangeOver
 
processElementsWithSameTimestamp(List<Row>, Row, Collector<CRow>) - Method in class org.apache.flink.table.runtime.aggregate.RowTimeUnboundedRowsOver
 
processEvent(NFA<IN>, IN, long) - Method in class org.apache.flink.cep.operator.AbstractKeyedCEPPatternOperator
Process the given event by giving it to the NFA and outputting the produced set of matched event sequences.
processEvent(NFA<IN>, IN, long) - Method in class org.apache.flink.cep.operator.KeyedCEPPatternOperator
 
processEvent(NFA<IN>, IN, long) - Method in class org.apache.flink.cep.operator.TimeoutKeyedCEPPatternOperator
 
processEvent(FSM.Event<D>, Object) - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
processEvent(FSM.Event<D>, Object) - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
processEvent(FSM.Event<D>, Object) - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
processEvent(FSM.Event<D>, Object) - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
processExitCode() - Method in enum org.apache.flink.runtime.clusterframework.ApplicationStatus
Gets the process exit code associated with this status
ProcessFunction<I,O> - Class in org.apache.flink.streaming.api.functions
A function that processes elements of a stream.
ProcessFunction() - Constructor for class org.apache.flink.streaming.api.functions.ProcessFunction
 
ProcessFunction.Context - Class in org.apache.flink.streaming.api.functions
ProcessFunction.OnTimerContext - Class in org.apache.flink.streaming.api.functions
Information available in an invocation of ProcessFunction.onTimer(long, OnTimerContext, Collector).
ProcessFunctionWithCleanupState<IN,OUT> - Class in org.apache.flink.table.runtime.aggregate
 
ProcessFunctionWithCleanupState(StreamQueryConfig) - Constructor for class org.apache.flink.table.runtime.aggregate.ProcessFunctionWithCleanupState
 
Processing - Enum in org.apache.flink.runtime.rpc.akka.messages
Controls the processing behaviour of the AkkaRpcActor
ProcessingTimeCallback - Interface in org.apache.flink.streaming.runtime.tasks
Interface for processing-time callbacks that can be registered at a ProcessingTimeService.
ProcessingTimeService - Class in org.apache.flink.streaming.runtime.tasks
Defines the current processing time and handles all related actions, such as register timers for tasks to be executed in the future.
ProcessingTimeService() - Constructor for class org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
 
ProcessingTimeSessionWindows - Class in org.apache.flink.streaming.api.windowing.assigners
A WindowAssigner that windows elements into sessions based on the current processing time.
ProcessingTimeSessionWindows(long) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
 
ProcessingTimeTrigger - Class in org.apache.flink.streaming.api.windowing.triggers
A Trigger that fires once the current system time passes the end of the window to which a pane belongs.
processInput() - Method in class org.apache.flink.streaming.runtime.io.StreamInputProcessor
 
processInput() - Method in class org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor
 
processLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
processLatencyMarker(LatencyMarker) - Method in interface org.apache.flink.streaming.api.operators.OneInputStreamOperator
 
processLatencyMarker1(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
processLatencyMarker1(LatencyMarker) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
Processes a LatencyMarker that arrived on the first input of this two-input operator.
processLatencyMarker2(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
processLatencyMarker2(LatencyMarker) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
Processes a LatencyMarker that arrived on the second input of this two-input operator.
ProcessOperator<IN,OUT> - Class in org.apache.flink.streaming.api.operators
ProcessOperator(ProcessFunction<IN, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.ProcessOperator
 
processProbeIter() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
ProcessReaper - Class in org.apache.flink.runtime.process
Utility actors that monitors other actors and kills the JVM upon actor termination.
ProcessReaper(ActorRef, Logger, int) - Constructor for class org.apache.flink.runtime.process.ProcessReaper
 
ProcessShutDownThread - Class in org.apache.flink.runtime.util
JVM shut down thread awaiting actor system shut down for a certain amount of time before exiting the JVM.
ProcessShutDownThread(Logger, ActorSystem, Duration) - Constructor for class org.apache.flink.runtime.util.ProcessShutDownThread
Creates a shut down thread.
processUnmatchedBuildIter() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
 
processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
 
processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.co.CoProcessOperator
 
processWatermark(Watermark) - Method in interface org.apache.flink.streaming.api.operators.OneInputStreamOperator
Processes a Watermark.
processWatermark(Watermark) - Method in class org.apache.flink.streaming.api.operators.ProcessOperator
 
processWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.operators.ExtractTimestampsOperator
Deprecated.
 
processWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndPeriodicWatermarksOperator
Override the base implementation to completely ignore watermarks propagated from upstream (we rely only on the AssignerWithPeriodicWatermarks to emit watermarks from here).
processWatermark(Watermark) - Method in class org.apache.flink.streaming.runtime.operators.TimestampsAndPunctuatedWatermarksOperator
Override the base implementation to completely ignore watermarks propagated from upstream (we rely only on the AssignerWithPunctuatedWatermarks to emit watermarks from here).
processWatermark1(Watermark) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
processWatermark1(Watermark) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
Processes a Watermark that arrived on the first input of this two-input operator.
processWatermark2(Watermark) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
processWatermark2(Watermark) - Method in interface org.apache.flink.streaming.api.operators.TwoInputStreamOperator
Processes a Watermark that arrived on the second input of this two-input operator.
ProcessWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
Base abstract class for functions that are evaluated over keyed (grouped) windows using a context for retrieving extra information.
ProcessWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction
 
ProcessWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.api.scala.function
Base abstract class for functions that are evaluated over keyed (grouped) windows using a context for retrieving extra information.
ProcessWindowFunction() - Constructor for class org.apache.flink.streaming.api.scala.function.ProcessWindowFunction
 
ProcessWindowFunction.Context - Class in org.apache.flink.streaming.api.functions.windowing
The context holding window metadata.
ProcessWindowFunction.Context - Class in org.apache.flink.streaming.api.scala.function
The context holding window metadata
proctime() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Declares a field as the proctime attribute for indicating, accessing, and working in Flink's processing time.
PROCTIME() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
proctime() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
PROCTIME() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
proctime() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
proctime() - Method in class org.apache.flink.table.plan.schema.DataStreamTable
 
PROCTIME_INDICATOR() - Method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo$
 
PROCTIME_INDICATOR() - Static method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
 
ProctimeAttribute - Class in org.apache.flink.table.expressions
 
ProctimeAttribute(Expression) - Constructor for class org.apache.flink.table.expressions.ProctimeAttribute
 
ProctimeAttribute$ - Class in org.apache.flink.table.expressions
 
ProctimeAttribute$() - Constructor for class org.apache.flink.table.expressions.ProctimeAttribute$
 
ProcTimeBoundedRangeOver - Class in org.apache.flink.table.runtime.aggregate
Process Function used for the aggregate in bounded proc-time OVER window DataStream
ProcTimeBoundedRangeOver(GeneratedAggregationsFunction, long, RowTypeInfo, TypeInformation<CRow>, StreamQueryConfig) - Constructor for class org.apache.flink.table.runtime.aggregate.ProcTimeBoundedRangeOver
 
ProcTimeBoundedRowsOver - Class in org.apache.flink.table.runtime.aggregate
Process Function for ROW clause processing-time bounded OVER window
ProcTimeBoundedRowsOver(GeneratedAggregationsFunction, long, RowTypeInfo, TypeInformation<CRow>, StreamQueryConfig) - Constructor for class org.apache.flink.table.runtime.aggregate.ProcTimeBoundedRowsOver
 
ProcTimeUnboundedOver - Class in org.apache.flink.table.runtime.aggregate
Process Function for processing-time unbounded OVER window
ProcTimeUnboundedOver(GeneratedAggregationsFunction, RowTypeInfo, StreamQueryConfig) - Constructor for class org.apache.flink.table.runtime.aggregate.ProcTimeUnboundedOver
 
produce(ConsumerRecords<byte[], byte[]>) - Method in class org.apache.flink.streaming.connectors.kafka.internal.Handover
Hands over an element from the producer.
producer - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
KafkaProducer instance
producerConfig - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
User defined properties for the Producer.
ProducerFailedException - Exception in org.apache.flink.runtime.io.network.partition
Network-stack level Exception to notify remote receiver about a failed partition producer.
ProducerFailedException(Throwable) - Constructor for exception org.apache.flink.runtime.io.network.partition.ProducerFailedException
The cause of the producer failure.
producesRetractions(RelNode) - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamRetractionRules.SetAccModeRule
Checks if a RelNode produces retraction messages.
producesUpdates() - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupAggregate
 
producesUpdates() - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
producesUpdates() - Method in interface org.apache.flink.table.plan.nodes.datastream.DataStreamRel
Whether the DataStreamRel produces update and delete changes.
producesUpdates(RelNode) - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamRetractionRules.SetAccModeRule
Checks if a RelNode produces update and delete changes.
product() - Method in class org.apache.flink.table.examples.scala.StreamSQLExample.Order
 
product() - Method in class org.apache.flink.table.examples.scala.StreamTableExample.Order
 
product() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
product() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
ProductAccessor(int) - Constructor for class org.apache.flink.table.codegen.CodeGenUtils.ProductAccessor
 
ProductAccessor$() - Constructor for class org.apache.flink.table.codegen.CodeGenUtils.ProductAccessor$
 
productArity() - Static method in class org.apache.flink.mesos.runtime.clusterframework.RegisteredMesosWorkerNode
 
productArity() - Static method in class org.apache.flink.ml.common.Block
 
productArity() - Static method in class org.apache.flink.ml.common.LabeledVector
 
productArity() - Static method in class org.apache.flink.ml.common.WeightVector
 
productArity() - Static method in class org.apache.flink.ml.math.DenseMatrix
 
productArity() - Static method in class org.apache.flink.ml.math.DenseVector
 
productArity() - Static method in class org.apache.flink.ml.math.distributed.IndexedRow
 
productArity() - Static method in class org.apache.flink.ml.math.SparseVector
 
productArity() - Static method in class org.apache.flink.ml.optimization.GenericLossFunction
 
productArity() - Static method in class org.apache.flink.ml.pipeline.ChainedPredictor
 
productArity() - Static method in class org.apache.flink.ml.pipeline.ChainedTransformer
 
productArity() - Static method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsErroneous
 
productArity() - Static method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsFound
 
productArity() - Static method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsNotFound
 
productArity() - Static method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultStringsFound
 
productArity() - Static method in class org.apache.flink.runtime.messages.accumulators.RequestAccumulatorResults
 
productArity() - Static method in class org.apache.flink.runtime.messages.accumulators.RequestAccumulatorResultsStringified
 
productArity() - Static method in exception org.apache.flink.table.api.AmbiguousTableSourceConverterException
 
productArity() - Static method in exception org.apache.flink.table.api.CatalogAlreadyExistException
 
productArity() - Static method in exception org.apache.flink.table.api.CatalogNotExistException
 
productArity() - Static method in class org.apache.flink.table.api.CurrentRange
 
productArity() - Static method in class org.apache.flink.table.api.CurrentRow
 
productArity() - Static method in exception org.apache.flink.table.api.ExpressionParserException
 
productArity() - Static method in exception org.apache.flink.table.api.ExternalCatalogAlreadyExistException
 
productArity() - Static method in exception org.apache.flink.table.api.ExternalCatalogNotExistException
 
productArity() - Static method in exception org.apache.flink.table.api.NoMatchedTableSourceConverterException
 
productArity() - Static method in class org.apache.flink.table.api.OverWindow
 
productArity() - Static method in class org.apache.flink.table.api.scala.OverWindowWithOrderBy
 
productArity() - Static method in class org.apache.flink.table.api.scala.PartitionedOver
 
productArity() - Static method in exception org.apache.flink.table.api.SqlParserException
 
productArity() - Static method in exception org.apache.flink.table.api.TableAlreadyExistException
 
productArity() - Static method in exception org.apache.flink.table.api.TableException
 
productArity() - Static method in exception org.apache.flink.table.api.TableNotExistException
 
productArity() - Static method in class org.apache.flink.table.api.UnboundedRange
 
productArity() - Static method in class org.apache.flink.table.api.UnboundedRow
 
productArity() - Static method in exception org.apache.flink.table.api.UnresolvedException
 
productArity() - Static method in exception org.apache.flink.table.api.ValidationException
 
productArity() - Static method in class org.apache.flink.table.catalog.ExternalCatalogTable
 
productArity() - Static method in class org.apache.flink.table.codegen.GeneratedAggregationsFunction
 
productArity() - Static method in class org.apache.flink.table.codegen.GeneratedCollector
 
productArity() - Static method in class org.apache.flink.table.codegen.GeneratedExpression
 
productArity() - Static method in class org.apache.flink.table.codegen.GeneratedFunction
 
productArity() - Static method in class org.apache.flink.table.codegen.GeneratedInput
 
productArity() - Static method in class org.apache.flink.table.expressions.Abs
 
productArity() - Static method in class org.apache.flink.table.expressions.Acos
 
productArity() - Static method in class org.apache.flink.table.expressions.AggFunctionCall
 
productArity() - Static method in class org.apache.flink.table.expressions.Alias
 
productArity() - Static method in class org.apache.flink.table.expressions.And
 
productArity() - Static method in class org.apache.flink.table.expressions.ArrayCardinality
 
productArity() - Static method in class org.apache.flink.table.expressions.ArrayConstructor
 
productArity() - Static method in class org.apache.flink.table.expressions.ArrayElement
 
productArity() - Static method in class org.apache.flink.table.expressions.ArrayElementAt
 
productArity() - Static method in class org.apache.flink.table.expressions.Asc
 
productArity() - Static method in class org.apache.flink.table.expressions.Asin
 
productArity() - Static method in class org.apache.flink.table.expressions.Atan
 
productArity() - Static method in class org.apache.flink.table.expressions.Avg
 
productArity() - Static method in class org.apache.flink.table.expressions.Call
 
productArity() - Static method in class org.apache.flink.table.expressions.Cast
 
productArity() - Static method in class org.apache.flink.table.expressions.Ceil
 
productArity() - Static method in class org.apache.flink.table.expressions.CharLength
 
productArity() - Static method in class org.apache.flink.table.expressions.Cos
 
productArity() - Static method in class org.apache.flink.table.expressions.Cot
 
productArity() - Static method in class org.apache.flink.table.expressions.Count
 
productArity() - Static method in class org.apache.flink.table.expressions.CurrentDate
 
productArity() - Static method in class org.apache.flink.table.expressions.CurrentTime
 
productArity() - Static method in class org.apache.flink.table.expressions.CurrentTimestamp
 
productArity() - Static method in class org.apache.flink.table.expressions.Degrees
 
productArity() - Static method in class org.apache.flink.table.expressions.Desc
 
productArity() - Static method in class org.apache.flink.table.expressions.Div
 
productArity() - Static method in class org.apache.flink.table.expressions.EqualTo
 
productArity() - Static method in class org.apache.flink.table.expressions.Exp
 
productArity() - Static method in class org.apache.flink.table.expressions.Extract
 
productArity() - Static method in class org.apache.flink.table.expressions.Flattening
 
productArity() - Static method in class org.apache.flink.table.expressions.Floor
 
productArity() - Static method in class org.apache.flink.table.expressions.GetCompositeField
 
productArity() - Static method in class org.apache.flink.table.expressions.GreaterThan
 
productArity() - Static method in class org.apache.flink.table.expressions.GreaterThanOrEqual
 
productArity() - Static method in class org.apache.flink.table.expressions.If
 
productArity() - Static method in class org.apache.flink.table.expressions.InitCap
 
productArity() - Static method in class org.apache.flink.table.expressions.IsFalse
 
productArity() - Static method in class org.apache.flink.table.expressions.IsNotFalse
 
productArity() - Static method in class org.apache.flink.table.expressions.IsNotNull
 
productArity() - Static method in class org.apache.flink.table.expressions.IsNotTrue
 
productArity() - Static method in class org.apache.flink.table.expressions.IsNull
 
productArity() - Static method in class org.apache.flink.table.expressions.IsTrue
 
productArity() - Static method in class org.apache.flink.table.expressions.LessThan
 
productArity() - Static method in class org.apache.flink.table.expressions.LessThanOrEqual
 
productArity() - Static method in class org.apache.flink.table.expressions.Like
 
productArity() - Static method in class org.apache.flink.table.expressions.Literal
 
productArity() - Static method in class org.apache.flink.table.expressions.Ln
 
productArity() - Static method in class org.apache.flink.table.expressions.LocalTime
 
productArity() - Static method in class org.apache.flink.table.expressions.LocalTimestamp
 
productArity() - Static method in class org.apache.flink.table.expressions.Log10
 
productArity() - Static method in class org.apache.flink.table.expressions.Lower
 
productArity() - Static method in class org.apache.flink.table.expressions.Max
 
productArity() - Static method in class org.apache.flink.table.expressions.Min
 
productArity() - Static method in class org.apache.flink.table.expressions.Minus
 
productArity() - Static method in class org.apache.flink.table.expressions.Mod
 
productArity() - Static method in class org.apache.flink.table.expressions.Mul
 
productArity() - Static method in class org.apache.flink.table.expressions.Not
 
productArity() - Static method in class org.apache.flink.table.expressions.NotEqualTo
 
productArity() - Static method in class org.apache.flink.table.expressions.Null
 
productArity() - Static method in class org.apache.flink.table.expressions.Or
 
productArity() - Static method in class org.apache.flink.table.expressions.OverCall
 
productArity() - Static method in class org.apache.flink.table.expressions.Overlay
 
productArity() - Static method in class org.apache.flink.table.expressions.Pi
 
productArity() - Static method in class org.apache.flink.table.expressions.Plus
 
productArity() - Static method in class org.apache.flink.table.expressions.Position
 
productArity() - Static method in class org.apache.flink.table.expressions.Power
 
productArity() - Static method in class org.apache.flink.table.expressions.ProctimeAttribute
 
productArity() - Static method in class org.apache.flink.table.expressions.Quarter
 
productArity() - Static method in class org.apache.flink.table.expressions.Radians
 
productArity() - Static method in class org.apache.flink.table.expressions.ResolvedFieldReference
 
productArity() - Static method in class org.apache.flink.table.expressions.Round
 
productArity() - Static method in class org.apache.flink.table.expressions.RowtimeAttribute
 
productArity() - Static method in class org.apache.flink.table.expressions.ScalarFunctionCall
 
productArity() - Static method in class org.apache.flink.table.expressions.Sign
 
productArity() - Static method in class org.apache.flink.table.expressions.Similar
 
productArity() - Static method in class org.apache.flink.table.expressions.Sin
 
productArity() - Static method in class org.apache.flink.table.expressions.Sqrt
 
productArity() - Static method in class org.apache.flink.table.expressions.StddevPop
 
productArity() - Static method in class org.apache.flink.table.expressions.StddevSamp
 
productArity() - Static method in class org.apache.flink.table.expressions.Substring
 
productArity() - Static method in class org.apache.flink.table.expressions.Sum
 
productArity() - Static method in class org.apache.flink.table.expressions.Sum0
 
productArity() - Static method in class org.apache.flink.table.expressions.SymbolExpression
 
productArity() - Static method in class org.apache.flink.table.expressions.TableFunctionCall
 
productArity() - Static method in class org.apache.flink.table.expressions.Tan
 
productArity() - Static method in class org.apache.flink.table.expressions.TemporalCeil
 
productArity() - Static method in class org.apache.flink.table.expressions.TemporalFloor
 
productArity() - Static method in class org.apache.flink.table.expressions.TemporalOverlaps
 
productArity() - Static method in class org.apache.flink.table.expressions.Trim
 
productArity() - Static method in class org.apache.flink.table.expressions.UDAGGExpression
 
productArity() - Static method in class org.apache.flink.table.expressions.UnaryMinus
 
productArity() - Static method in class org.apache.flink.table.expressions.UnresolvedAlias
 
productArity() - Static method in class org.apache.flink.table.expressions.UnresolvedFieldReference
 
productArity() - Static method in class org.apache.flink.table.expressions.UnresolvedOverCall
 
productArity() - Static method in class org.apache.flink.table.expressions.Upper
 
productArity() - Static method in class org.apache.flink.table.expressions.VarPop
 
productArity() - Static method in class org.apache.flink.table.expressions.VarSamp
 
productArity() - Static method in class org.apache.flink.table.expressions.WindowEnd
 
productArity() - Static method in class org.apache.flink.table.expressions.WindowReference
 
productArity() - Static method in class org.apache.flink.table.expressions.WindowStart
 
productArity() - Static method in class org.apache.flink.table.plan.logical.Aggregate
 
productArity() - Static method in class org.apache.flink.table.plan.logical.AliasNode
 
productArity() - Static method in class org.apache.flink.table.plan.logical.CatalogNode
 
productArity() - Static method in class org.apache.flink.table.plan.logical.Distinct
 
productArity() - Static method in class org.apache.flink.table.plan.logical.Filter
 
productArity() - Static method in class org.apache.flink.table.plan.logical.Intersect
 
productArity() - Static method in class org.apache.flink.table.plan.logical.Join
 
productArity() - Static method in class org.apache.flink.table.plan.logical.Limit
 
productArity() - Static method in class org.apache.flink.table.plan.logical.LogicalRelNode
 
productArity() - Static method in class org.apache.flink.table.plan.logical.LogicalTableFunctionCall
 
productArity() - Static method in class org.apache.flink.table.plan.logical.Minus
 
productArity() - Static method in class org.apache.flink.table.plan.logical.Project
 
productArity() - Static method in class org.apache.flink.table.plan.logical.SessionGroupWindow
 
productArity() - Static method in class org.apache.flink.table.plan.logical.SlidingGroupWindow
 
productArity() - Static method in class org.apache.flink.table.plan.logical.Sort
 
productArity() - Static method in class org.apache.flink.table.plan.logical.TumblingGroupWindow
 
productArity() - Static method in class org.apache.flink.table.plan.logical.Union
 
productArity() - Static method in class org.apache.flink.table.plan.logical.WindowAggregate
 
productArity() - Static method in class org.apache.flink.table.plan.stats.ColumnStats
 
productArity() - Static method in class org.apache.flink.table.plan.stats.TableStats
 
productArity() - Static method in class org.apache.flink.table.validate.ValidationFailure
 
productElement(int) - Static method in class org.apache.flink.mesos.runtime.clusterframework.RegisteredMesosWorkerNode
 
productElement(int) - Static method in class org.apache.flink.ml.common.Block
 
productElement(int) - Static method in class org.apache.flink.ml.common.LabeledVector
 
productElement(int) - Static method in class org.apache.flink.ml.common.WeightVector
 
productElement(int) - Static method in class org.apache.flink.ml.math.DenseMatrix
 
productElement(int) - Static method in class org.apache.flink.ml.math.DenseVector
 
productElement(int) - Static method in class org.apache.flink.ml.math.distributed.IndexedRow
 
productElement(int) - Static method in class org.apache.flink.ml.math.SparseVector
 
productElement(int) - Static method in class org.apache.flink.ml.optimization.GenericLossFunction
 
productElement(int) - Static method in class org.apache.flink.ml.pipeline.ChainedPredictor
 
productElement(int) - Static method in class org.apache.flink.ml.pipeline.ChainedTransformer
 
productElement(int) - Static method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsErroneous
 
productElement(int) - Static method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsFound
 
productElement(int) - Static method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsNotFound
 
productElement(int) - Static method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultStringsFound
 
productElement(int) - Static method in class org.apache.flink.runtime.messages.accumulators.RequestAccumulatorResults
 
productElement(int) - Static method in class org.apache.flink.runtime.messages.accumulators.RequestAccumulatorResultsStringified
 
productElement(int) - Static method in exception org.apache.flink.table.api.AmbiguousTableSourceConverterException
 
productElement(int) - Static method in exception org.apache.flink.table.api.CatalogAlreadyExistException
 
productElement(int) - Static method in exception org.apache.flink.table.api.CatalogNotExistException
 
productElement(int) - Static method in class org.apache.flink.table.api.CurrentRange
 
productElement(int) - Static method in class org.apache.flink.table.api.CurrentRow
 
productElement(int) - Static method in exception org.apache.flink.table.api.ExpressionParserException
 
productElement(int) - Static method in exception org.apache.flink.table.api.ExternalCatalogAlreadyExistException
 
productElement(int) - Static method in exception org.apache.flink.table.api.ExternalCatalogNotExistException
 
productElement(int) - Static method in exception org.apache.flink.table.api.NoMatchedTableSourceConverterException
 
productElement(int) - Static method in class org.apache.flink.table.api.OverWindow
 
productElement(int) - Static method in class org.apache.flink.table.api.scala.OverWindowWithOrderBy
 
productElement(int) - Static method in class org.apache.flink.table.api.scala.PartitionedOver
 
productElement(int) - Static method in exception org.apache.flink.table.api.SqlParserException
 
productElement(int) - Static method in exception org.apache.flink.table.api.TableAlreadyExistException
 
productElement(int) - Static method in exception org.apache.flink.table.api.TableException
 
productElement(int) - Static method in exception org.apache.flink.table.api.TableNotExistException
 
productElement(int) - Static method in class org.apache.flink.table.api.UnboundedRange
 
productElement(int) - Static method in class org.apache.flink.table.api.UnboundedRow
 
productElement(int) - Static method in exception org.apache.flink.table.api.UnresolvedException
 
productElement(int) - Static method in exception org.apache.flink.table.api.ValidationException
 
productElement(int) - Static method in class org.apache.flink.table.catalog.ExternalCatalogTable
 
productElement(int) - Static method in class org.apache.flink.table.codegen.GeneratedAggregationsFunction
 
productElement(int) - Static method in class org.apache.flink.table.codegen.GeneratedCollector
 
productElement(int) - Static method in class org.apache.flink.table.codegen.GeneratedExpression
 
productElement(int) - Static method in class org.apache.flink.table.codegen.GeneratedFunction
 
productElement(int) - Static method in class org.apache.flink.table.codegen.GeneratedInput
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Abs
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Acos
 
productElement(int) - Static method in class org.apache.flink.table.expressions.AggFunctionCall
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Alias
 
productElement(int) - Static method in class org.apache.flink.table.expressions.And
 
productElement(int) - Static method in class org.apache.flink.table.expressions.ArrayCardinality
 
productElement(int) - Static method in class org.apache.flink.table.expressions.ArrayConstructor
 
productElement(int) - Static method in class org.apache.flink.table.expressions.ArrayElement
 
productElement(int) - Static method in class org.apache.flink.table.expressions.ArrayElementAt
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Asc
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Asin
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Atan
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Avg
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Call
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Cast
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Ceil
 
productElement(int) - Static method in class org.apache.flink.table.expressions.CharLength
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Cos
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Cot
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Count
 
productElement(int) - Static method in class org.apache.flink.table.expressions.CurrentDate
 
productElement(int) - Static method in class org.apache.flink.table.expressions.CurrentTime
 
productElement(int) - Static method in class org.apache.flink.table.expressions.CurrentTimestamp
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Degrees
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Desc
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Div
 
productElement(int) - Static method in class org.apache.flink.table.expressions.EqualTo
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Exp
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Extract
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Flattening
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Floor
 
productElement(int) - Static method in class org.apache.flink.table.expressions.GetCompositeField
 
productElement(int) - Static method in class org.apache.flink.table.expressions.GreaterThan
 
productElement(int) - Static method in class org.apache.flink.table.expressions.GreaterThanOrEqual
 
productElement(int) - Static method in class org.apache.flink.table.expressions.If
 
productElement(int) - Static method in class org.apache.flink.table.expressions.InitCap
 
productElement(int) - Static method in class org.apache.flink.table.expressions.IsFalse
 
productElement(int) - Static method in class org.apache.flink.table.expressions.IsNotFalse
 
productElement(int) - Static method in class org.apache.flink.table.expressions.IsNotNull
 
productElement(int) - Static method in class org.apache.flink.table.expressions.IsNotTrue
 
productElement(int) - Static method in class org.apache.flink.table.expressions.IsNull
 
productElement(int) - Static method in class org.apache.flink.table.expressions.IsTrue
 
productElement(int) - Static method in class org.apache.flink.table.expressions.LessThan
 
productElement(int) - Static method in class org.apache.flink.table.expressions.LessThanOrEqual
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Like
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Literal
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Ln
 
productElement(int) - Static method in class org.apache.flink.table.expressions.LocalTime
 
productElement(int) - Static method in class org.apache.flink.table.expressions.LocalTimestamp
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Log10
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Lower
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Max
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Min
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Minus
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Mod
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Mul
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Not
 
productElement(int) - Static method in class org.apache.flink.table.expressions.NotEqualTo
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Null
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Or
 
productElement(int) - Static method in class org.apache.flink.table.expressions.OverCall
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Overlay
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Pi
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Plus
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Position
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Power
 
productElement(int) - Static method in class org.apache.flink.table.expressions.ProctimeAttribute
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Quarter
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Radians
 
productElement(int) - Static method in class org.apache.flink.table.expressions.ResolvedFieldReference
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Round
 
productElement(int) - Static method in class org.apache.flink.table.expressions.RowtimeAttribute
 
productElement(int) - Static method in class org.apache.flink.table.expressions.ScalarFunctionCall
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Sign
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Similar
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Sin
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Sqrt
 
productElement(int) - Static method in class org.apache.flink.table.expressions.StddevPop
 
productElement(int) - Static method in class org.apache.flink.table.expressions.StddevSamp
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Substring
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Sum
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Sum0
 
productElement(int) - Static method in class org.apache.flink.table.expressions.SymbolExpression
 
productElement(int) - Static method in class org.apache.flink.table.expressions.TableFunctionCall
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Tan
 
productElement(int) - Static method in class org.apache.flink.table.expressions.TemporalCeil
 
productElement(int) - Static method in class org.apache.flink.table.expressions.TemporalFloor
 
productElement(int) - Static method in class org.apache.flink.table.expressions.TemporalOverlaps
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Trim
 
productElement(int) - Static method in class org.apache.flink.table.expressions.UDAGGExpression
 
productElement(int) - Static method in class org.apache.flink.table.expressions.UnaryMinus
 
productElement(int) - Static method in class org.apache.flink.table.expressions.UnresolvedAlias
 
productElement(int) - Static method in class org.apache.flink.table.expressions.UnresolvedFieldReference
 
productElement(int) - Static method in class org.apache.flink.table.expressions.UnresolvedOverCall
 
productElement(int) - Static method in class org.apache.flink.table.expressions.Upper
 
productElement(int) - Static method in class org.apache.flink.table.expressions.VarPop
 
productElement(int) - Static method in class org.apache.flink.table.expressions.VarSamp
 
productElement(int) - Static method in class org.apache.flink.table.expressions.WindowEnd
 
productElement(int) - Static method in class org.apache.flink.table.expressions.WindowReference
 
productElement(int) - Static method in class org.apache.flink.table.expressions.WindowStart
 
productElement(int) - Static method in class org.apache.flink.table.plan.logical.Aggregate
 
productElement(int) - Static method in class org.apache.flink.table.plan.logical.AliasNode
 
productElement(int) - Static method in class org.apache.flink.table.plan.logical.CatalogNode
 
productElement(int) - Static method in class org.apache.flink.table.plan.logical.Distinct
 
productElement(int) - Static method in class org.apache.flink.table.plan.logical.Filter
 
productElement(int) - Static method in class org.apache.flink.table.plan.logical.Intersect
 
productElement(int) - Static method in class org.apache.flink.table.plan.logical.Join
 
productElement(int) - Static method in class org.apache.flink.table.plan.logical.Limit
 
productElement(int) - Static method in class org.apache.flink.table.plan.logical.LogicalRelNode
 
productElement(int) - Static method in class org.apache.flink.table.plan.logical.LogicalTableFunctionCall
 
productElement(int) - Static method in class org.apache.flink.table.plan.logical.Minus
 
productElement(int) - Static method in class org.apache.flink.table.plan.logical.Project
 
productElement(int) - Static method in class org.apache.flink.table.plan.logical.SessionGroupWindow
 
productElement(int) - Static method in class org.apache.flink.table.plan.logical.SlidingGroupWindow
 
productElement(int) - Static method in class org.apache.flink.table.plan.logical.Sort
 
productElement(int) - Static method in class org.apache.flink.table.plan.logical.TumblingGroupWindow
 
productElement(int) - Static method in class org.apache.flink.table.plan.logical.Union
 
productElement(int) - Static method in class org.apache.flink.table.plan.logical.WindowAggregate
 
productElement(int) - Static method in class org.apache.flink.table.plan.stats.ColumnStats
 
productElement(int) - Static method in class org.apache.flink.table.plan.stats.TableStats
 
productElement(int) - Static method in class org.apache.flink.table.validate.ValidationFailure
 
productIterator() - Static method in class org.apache.flink.mesos.runtime.clusterframework.RegisteredMesosWorkerNode
 
productIterator() - Static method in class org.apache.flink.ml.common.Block
 
productIterator() - Static method in class org.apache.flink.ml.common.LabeledVector
 
productIterator() - Static method in class org.apache.flink.ml.common.WeightVector
 
productIterator() - Static method in class org.apache.flink.ml.math.DenseMatrix
 
productIterator() - Static method in class org.apache.flink.ml.math.DenseVector
 
productIterator() - Static method in class org.apache.flink.ml.math.distributed.IndexedRow
 
productIterator() - Static method in class org.apache.flink.ml.math.SparseVector
 
productIterator() - Static method in class org.apache.flink.ml.optimization.GenericLossFunction
 
productIterator() - Static method in class org.apache.flink.ml.pipeline.ChainedPredictor
 
productIterator() - Static method in class org.apache.flink.ml.pipeline.ChainedTransformer
 
productIterator() - Static method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsErroneous
 
productIterator() - Static method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsFound
 
productIterator() - Static method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsNotFound
 
productIterator() - Static method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultStringsFound
 
productIterator() - Static method in class org.apache.flink.runtime.messages.accumulators.RequestAccumulatorResults
 
productIterator() - Static method in class org.apache.flink.runtime.messages.accumulators.RequestAccumulatorResultsStringified
 
productIterator() - Static method in exception org.apache.flink.table.api.AmbiguousTableSourceConverterException
 
productIterator() - Static method in exception org.apache.flink.table.api.CatalogAlreadyExistException
 
productIterator() - Static method in exception org.apache.flink.table.api.CatalogNotExistException
 
productIterator() - Static method in class org.apache.flink.table.api.CurrentRange
 
productIterator() - Static method in class org.apache.flink.table.api.CurrentRow
 
productIterator() - Static method in exception org.apache.flink.table.api.ExpressionParserException
 
productIterator() - Static method in exception org.apache.flink.table.api.ExternalCatalogAlreadyExistException
 
productIterator() - Static method in exception org.apache.flink.table.api.ExternalCatalogNotExistException
 
productIterator() - Static method in exception org.apache.flink.table.api.NoMatchedTableSourceConverterException
 
productIterator() - Static method in class org.apache.flink.table.api.OverWindow
 
productIterator() - Static method in class org.apache.flink.table.api.scala.OverWindowWithOrderBy
 
productIterator() - Static method in class org.apache.flink.table.api.scala.PartitionedOver
 
productIterator() - Static method in exception org.apache.flink.table.api.SqlParserException
 
productIterator() - Static method in exception org.apache.flink.table.api.TableAlreadyExistException
 
productIterator() - Static method in exception org.apache.flink.table.api.TableException
 
productIterator() - Static method in exception org.apache.flink.table.api.TableNotExistException
 
productIterator() - Static method in class org.apache.flink.table.api.UnboundedRange
 
productIterator() - Static method in class org.apache.flink.table.api.UnboundedRow
 
productIterator() - Static method in exception org.apache.flink.table.api.UnresolvedException
 
productIterator() - Static method in exception org.apache.flink.table.api.ValidationException
 
productIterator() - Static method in class org.apache.flink.table.catalog.ExternalCatalogTable
 
productIterator() - Static method in class org.apache.flink.table.codegen.GeneratedAggregationsFunction
 
productIterator() - Static method in class org.apache.flink.table.codegen.GeneratedCollector
 
productIterator() - Static method in class org.apache.flink.table.codegen.GeneratedExpression
 
productIterator() - Static method in class org.apache.flink.table.codegen.GeneratedFunction
 
productIterator() - Static method in class org.apache.flink.table.codegen.GeneratedInput
 
productIterator() - Static method in class org.apache.flink.table.expressions.Abs
 
productIterator() - Static method in class org.apache.flink.table.expressions.Acos
 
productIterator() - Static method in class org.apache.flink.table.expressions.AggFunctionCall
 
productIterator() - Static method in class org.apache.flink.table.expressions.Alias
 
productIterator() - Static method in class org.apache.flink.table.expressions.And
 
productIterator() - Static method in class org.apache.flink.table.expressions.ArrayCardinality
 
productIterator() - Static method in class org.apache.flink.table.expressions.ArrayConstructor
 
productIterator() - Static method in class org.apache.flink.table.expressions.ArrayElement
 
productIterator() - Static method in class org.apache.flink.table.expressions.ArrayElementAt
 
productIterator() - Static method in class org.apache.flink.table.expressions.Asc
 
productIterator() - Static method in class org.apache.flink.table.expressions.Asin
 
productIterator() - Static method in class org.apache.flink.table.expressions.Atan
 
productIterator() - Static method in class org.apache.flink.table.expressions.Avg
 
productIterator() - Static method in class org.apache.flink.table.expressions.Call
 
productIterator() - Static method in class org.apache.flink.table.expressions.Cast
 
productIterator() - Static method in class org.apache.flink.table.expressions.Ceil
 
productIterator() - Static method in class org.apache.flink.table.expressions.CharLength
 
productIterator() - Static method in class org.apache.flink.table.expressions.Cos
 
productIterator() - Static method in class org.apache.flink.table.expressions.Cot
 
productIterator() - Static method in class org.apache.flink.table.expressions.Count
 
productIterator() - Static method in class org.apache.flink.table.expressions.CurrentDate
 
productIterator() - Static method in class org.apache.flink.table.expressions.CurrentTime
 
productIterator() - Static method in class org.apache.flink.table.expressions.CurrentTimestamp
 
productIterator() - Static method in class org.apache.flink.table.expressions.Degrees
 
productIterator() - Static method in class org.apache.flink.table.expressions.Desc
 
productIterator() - Static method in class org.apache.flink.table.expressions.Div
 
productIterator() - Static method in class org.apache.flink.table.expressions.EqualTo
 
productIterator() - Static method in class org.apache.flink.table.expressions.Exp
 
productIterator() - Static method in class org.apache.flink.table.expressions.Extract
 
productIterator() - Static method in class org.apache.flink.table.expressions.Flattening
 
productIterator() - Static method in class org.apache.flink.table.expressions.Floor
 
productIterator() - Static method in class org.apache.flink.table.expressions.GetCompositeField
 
productIterator() - Static method in class org.apache.flink.table.expressions.GreaterThan
 
productIterator() - Static method in class org.apache.flink.table.expressions.GreaterThanOrEqual
 
productIterator() - Static method in class org.apache.flink.table.expressions.If
 
productIterator() - Static method in class org.apache.flink.table.expressions.InitCap
 
productIterator() - Static method in class org.apache.flink.table.expressions.IsFalse
 
productIterator() - Static method in class org.apache.flink.table.expressions.IsNotFalse
 
productIterator() - Static method in class org.apache.flink.table.expressions.IsNotNull
 
productIterator() - Static method in class org.apache.flink.table.expressions.IsNotTrue
 
productIterator() - Static method in class org.apache.flink.table.expressions.IsNull
 
productIterator() - Static method in class org.apache.flink.table.expressions.IsTrue
 
productIterator() - Static method in class org.apache.flink.table.expressions.LessThan
 
productIterator() - Static method in class org.apache.flink.table.expressions.LessThanOrEqual
 
productIterator() - Static method in class org.apache.flink.table.expressions.Like
 
productIterator() - Static method in class org.apache.flink.table.expressions.Literal
 
productIterator() - Static method in class org.apache.flink.table.expressions.Ln
 
productIterator() - Static method in class org.apache.flink.table.expressions.LocalTime
 
productIterator() - Static method in class org.apache.flink.table.expressions.LocalTimestamp
 
productIterator() - Static method in class org.apache.flink.table.expressions.Log10
 
productIterator() - Static method in class org.apache.flink.table.expressions.Lower
 
productIterator() - Static method in class org.apache.flink.table.expressions.Max
 
productIterator() - Static method in class org.apache.flink.table.expressions.Min
 
productIterator() - Static method in class org.apache.flink.table.expressions.Minus
 
productIterator() - Static method in class org.apache.flink.table.expressions.Mod
 
productIterator() - Static method in class org.apache.flink.table.expressions.Mul
 
productIterator() - Static method in class org.apache.flink.table.expressions.Not
 
productIterator() - Static method in class org.apache.flink.table.expressions.NotEqualTo
 
productIterator() - Static method in class org.apache.flink.table.expressions.Null
 
productIterator() - Static method in class org.apache.flink.table.expressions.Or
 
productIterator() - Static method in class org.apache.flink.table.expressions.OverCall
 
productIterator() - Static method in class org.apache.flink.table.expressions.Overlay
 
productIterator() - Static method in class org.apache.flink.table.expressions.Pi
 
productIterator() - Static method in class org.apache.flink.table.expressions.Plus
 
productIterator() - Static method in class org.apache.flink.table.expressions.Position
 
productIterator() - Static method in class org.apache.flink.table.expressions.Power
 
productIterator() - Static method in class org.apache.flink.table.expressions.ProctimeAttribute
 
productIterator() - Static method in class org.apache.flink.table.expressions.Quarter
 
productIterator() - Static method in class org.apache.flink.table.expressions.Radians
 
productIterator() - Static method in class org.apache.flink.table.expressions.ResolvedFieldReference
 
productIterator() - Static method in class org.apache.flink.table.expressions.Round
 
productIterator() - Static method in class org.apache.flink.table.expressions.RowtimeAttribute
 
productIterator() - Static method in class org.apache.flink.table.expressions.ScalarFunctionCall
 
productIterator() - Static method in class org.apache.flink.table.expressions.Sign
 
productIterator() - Static method in class org.apache.flink.table.expressions.Similar
 
productIterator() - Static method in class org.apache.flink.table.expressions.Sin
 
productIterator() - Static method in class org.apache.flink.table.expressions.Sqrt
 
productIterator() - Static method in class org.apache.flink.table.expressions.StddevPop
 
productIterator() - Static method in class org.apache.flink.table.expressions.StddevSamp
 
productIterator() - Static method in class org.apache.flink.table.expressions.Substring
 
productIterator() - Static method in class org.apache.flink.table.expressions.Sum
 
productIterator() - Static method in class org.apache.flink.table.expressions.Sum0
 
productIterator() - Static method in class org.apache.flink.table.expressions.SymbolExpression
 
productIterator() - Static method in class org.apache.flink.table.expressions.TableFunctionCall
 
productIterator() - Static method in class org.apache.flink.table.expressions.Tan
 
productIterator() - Static method in class org.apache.flink.table.expressions.TemporalCeil
 
productIterator() - Static method in class org.apache.flink.table.expressions.TemporalFloor
 
productIterator() - Static method in class org.apache.flink.table.expressions.TemporalOverlaps
 
productIterator() - Static method in class org.apache.flink.table.expressions.Trim
 
productIterator() - Static method in class org.apache.flink.table.expressions.UDAGGExpression
 
productIterator() - Static method in class org.apache.flink.table.expressions.UnaryMinus
 
productIterator() - Static method in class org.apache.flink.table.expressions.UnresolvedAlias
 
productIterator() - Static method in class org.apache.flink.table.expressions.UnresolvedFieldReference
 
productIterator() - Static method in class org.apache.flink.table.expressions.UnresolvedOverCall
 
productIterator() - Static method in class org.apache.flink.table.expressions.Upper
 
productIterator() - Static method in class org.apache.flink.table.expressions.VarPop
 
productIterator() - Static method in class org.apache.flink.table.expressions.VarSamp
 
productIterator() - Static method in class org.apache.flink.table.expressions.WindowEnd
 
productIterator() - Static method in class org.apache.flink.table.expressions.WindowReference
 
productIterator() - Static method in class org.apache.flink.table.expressions.WindowStart
 
productIterator() - Static method in class org.apache.flink.table.plan.logical.Aggregate
 
productIterator() - Static method in class org.apache.flink.table.plan.logical.AliasNode
 
productIterator() - Static method in class org.apache.flink.table.plan.logical.CatalogNode
 
productIterator() - Static method in class org.apache.flink.table.plan.logical.Distinct
 
productIterator() - Static method in class org.apache.flink.table.plan.logical.Filter
 
productIterator() - Static method in class org.apache.flink.table.plan.logical.Intersect
 
productIterator() - Static method in class org.apache.flink.table.plan.logical.Join
 
productIterator() - Static method in class org.apache.flink.table.plan.logical.Limit
 
productIterator() - Static method in class org.apache.flink.table.plan.logical.LogicalRelNode
 
productIterator() - Static method in class org.apache.flink.table.plan.logical.LogicalTableFunctionCall
 
productIterator() - Static method in class org.apache.flink.table.plan.logical.Minus
 
productIterator() - Static method in class org.apache.flink.table.plan.logical.Project
 
productIterator() - Static method in class org.apache.flink.table.plan.logical.SessionGroupWindow
 
productIterator() - Static method in class org.apache.flink.table.plan.logical.SlidingGroupWindow
 
productIterator() - Static method in class org.apache.flink.table.plan.logical.Sort
 
productIterator() - Static method in class org.apache.flink.table.plan.logical.TumblingGroupWindow
 
productIterator() - Static method in class org.apache.flink.table.plan.logical.Union
 
productIterator() - Static method in class org.apache.flink.table.plan.logical.WindowAggregate
 
productIterator() - Static method in class org.apache.flink.table.plan.stats.ColumnStats
 
productIterator() - Static method in class org.apache.flink.table.plan.stats.TableStats
 
productIterator() - Static method in class org.apache.flink.table.validate.ValidationFailure
 
productPrefix() - Static method in class org.apache.flink.mesos.runtime.clusterframework.RegisteredMesosWorkerNode
 
productPrefix() - Static method in class org.apache.flink.ml.common.Block
 
productPrefix() - Static method in class org.apache.flink.ml.common.LabeledVector
 
productPrefix() - Static method in class org.apache.flink.ml.common.WeightVector
 
productPrefix() - Static method in class org.apache.flink.ml.math.DenseMatrix
 
productPrefix() - Static method in class org.apache.flink.ml.math.DenseVector
 
productPrefix() - Static method in class org.apache.flink.ml.math.distributed.IndexedRow
 
productPrefix() - Static method in class org.apache.flink.ml.math.SparseVector
 
productPrefix() - Static method in class org.apache.flink.ml.optimization.GenericLossFunction
 
productPrefix() - Static method in class org.apache.flink.ml.pipeline.ChainedPredictor
 
productPrefix() - Static method in class org.apache.flink.ml.pipeline.ChainedTransformer
 
productPrefix() - Static method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsErroneous
 
productPrefix() - Static method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsFound
 
productPrefix() - Static method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsNotFound
 
productPrefix() - Static method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultStringsFound
 
productPrefix() - Static method in class org.apache.flink.runtime.messages.accumulators.RequestAccumulatorResults
 
productPrefix() - Static method in class org.apache.flink.runtime.messages.accumulators.RequestAccumulatorResultsStringified
 
productPrefix() - Static method in exception org.apache.flink.table.api.AmbiguousTableSourceConverterException
 
productPrefix() - Static method in exception org.apache.flink.table.api.CatalogAlreadyExistException
 
productPrefix() - Static method in exception org.apache.flink.table.api.CatalogNotExistException
 
productPrefix() - Static method in class org.apache.flink.table.api.CurrentRange
 
productPrefix() - Static method in class org.apache.flink.table.api.CurrentRow
 
productPrefix() - Static method in exception org.apache.flink.table.api.ExpressionParserException
 
productPrefix() - Static method in exception org.apache.flink.table.api.ExternalCatalogAlreadyExistException
 
productPrefix() - Static method in exception org.apache.flink.table.api.ExternalCatalogNotExistException
 
productPrefix() - Static method in exception org.apache.flink.table.api.NoMatchedTableSourceConverterException
 
productPrefix() - Static method in class org.apache.flink.table.api.OverWindow
 
productPrefix() - Static method in class org.apache.flink.table.api.scala.OverWindowWithOrderBy
 
productPrefix() - Static method in class org.apache.flink.table.api.scala.PartitionedOver
 
productPrefix() - Static method in exception org.apache.flink.table.api.SqlParserException
 
productPrefix() - Static method in exception org.apache.flink.table.api.TableAlreadyExistException
 
productPrefix() - Static method in exception org.apache.flink.table.api.TableException
 
productPrefix() - Static method in exception org.apache.flink.table.api.TableNotExistException
 
productPrefix() - Static method in class org.apache.flink.table.api.UnboundedRange
 
productPrefix() - Static method in class org.apache.flink.table.api.UnboundedRow
 
productPrefix() - Static method in exception org.apache.flink.table.api.UnresolvedException
 
productPrefix() - Static method in exception org.apache.flink.table.api.ValidationException
 
productPrefix() - Static method in class org.apache.flink.table.catalog.ExternalCatalogTable
 
productPrefix() - Static method in class org.apache.flink.table.codegen.GeneratedAggregationsFunction
 
productPrefix() - Static method in class org.apache.flink.table.codegen.GeneratedCollector
 
productPrefix() - Static method in class org.apache.flink.table.codegen.GeneratedExpression
 
productPrefix() - Static method in class org.apache.flink.table.codegen.GeneratedFunction
 
productPrefix() - Static method in class org.apache.flink.table.codegen.GeneratedInput
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Abs
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Acos
 
productPrefix() - Static method in class org.apache.flink.table.expressions.AggFunctionCall
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Alias
 
productPrefix() - Static method in class org.apache.flink.table.expressions.And
 
productPrefix() - Static method in class org.apache.flink.table.expressions.ArrayCardinality
 
productPrefix() - Static method in class org.apache.flink.table.expressions.ArrayConstructor
 
productPrefix() - Static method in class org.apache.flink.table.expressions.ArrayElement
 
productPrefix() - Static method in class org.apache.flink.table.expressions.ArrayElementAt
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Asc
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Asin
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Atan
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Avg
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Call
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Cast
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Ceil
 
productPrefix() - Static method in class org.apache.flink.table.expressions.CharLength
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Cos
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Cot
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Count
 
productPrefix() - Static method in class org.apache.flink.table.expressions.CurrentDate
 
productPrefix() - Static method in class org.apache.flink.table.expressions.CurrentTime
 
productPrefix() - Static method in class org.apache.flink.table.expressions.CurrentTimestamp
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Degrees
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Desc
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Div
 
productPrefix() - Static method in class org.apache.flink.table.expressions.EqualTo
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Exp
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Extract
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Flattening
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Floor
 
productPrefix() - Static method in class org.apache.flink.table.expressions.GetCompositeField
 
productPrefix() - Static method in class org.apache.flink.table.expressions.GreaterThan
 
productPrefix() - Static method in class org.apache.flink.table.expressions.GreaterThanOrEqual
 
productPrefix() - Static method in class org.apache.flink.table.expressions.If
 
productPrefix() - Static method in class org.apache.flink.table.expressions.InitCap
 
productPrefix() - Static method in class org.apache.flink.table.expressions.IsFalse
 
productPrefix() - Static method in class org.apache.flink.table.expressions.IsNotFalse
 
productPrefix() - Static method in class org.apache.flink.table.expressions.IsNotNull
 
productPrefix() - Static method in class org.apache.flink.table.expressions.IsNotTrue
 
productPrefix() - Static method in class org.apache.flink.table.expressions.IsNull
 
productPrefix() - Static method in class org.apache.flink.table.expressions.IsTrue
 
productPrefix() - Static method in class org.apache.flink.table.expressions.LessThan
 
productPrefix() - Static method in class org.apache.flink.table.expressions.LessThanOrEqual
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Like
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Literal
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Ln
 
productPrefix() - Static method in class org.apache.flink.table.expressions.LocalTime
 
productPrefix() - Static method in class org.apache.flink.table.expressions.LocalTimestamp
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Log10
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Lower
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Max
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Min
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Minus
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Mod
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Mul
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Not
 
productPrefix() - Static method in class org.apache.flink.table.expressions.NotEqualTo
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Null
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Or
 
productPrefix() - Static method in class org.apache.flink.table.expressions.OverCall
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Overlay
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Pi
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Plus
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Position
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Power
 
productPrefix() - Static method in class org.apache.flink.table.expressions.ProctimeAttribute
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Quarter
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Radians
 
productPrefix() - Static method in class org.apache.flink.table.expressions.ResolvedFieldReference
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Round
 
productPrefix() - Static method in class org.apache.flink.table.expressions.RowtimeAttribute
 
productPrefix() - Static method in class org.apache.flink.table.expressions.ScalarFunctionCall
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Sign
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Similar
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Sin
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Sqrt
 
productPrefix() - Static method in class org.apache.flink.table.expressions.StddevPop
 
productPrefix() - Static method in class org.apache.flink.table.expressions.StddevSamp
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Substring
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Sum
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Sum0
 
productPrefix() - Static method in class org.apache.flink.table.expressions.SymbolExpression
 
productPrefix() - Static method in class org.apache.flink.table.expressions.TableFunctionCall
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Tan
 
productPrefix() - Static method in class org.apache.flink.table.expressions.TemporalCeil
 
productPrefix() - Static method in class org.apache.flink.table.expressions.TemporalFloor
 
productPrefix() - Static method in class org.apache.flink.table.expressions.TemporalOverlaps
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Trim
 
productPrefix() - Static method in class org.apache.flink.table.expressions.UDAGGExpression
 
productPrefix() - Static method in class org.apache.flink.table.expressions.UnaryMinus
 
productPrefix() - Static method in class org.apache.flink.table.expressions.UnresolvedAlias
 
productPrefix() - Static method in class org.apache.flink.table.expressions.UnresolvedFieldReference
 
productPrefix() - Static method in class org.apache.flink.table.expressions.UnresolvedOverCall
 
productPrefix() - Static method in class org.apache.flink.table.expressions.Upper
 
productPrefix() - Static method in class org.apache.flink.table.expressions.VarPop
 
productPrefix() - Static method in class org.apache.flink.table.expressions.VarSamp
 
productPrefix() - Static method in class org.apache.flink.table.expressions.WindowEnd
 
productPrefix() - Static method in class org.apache.flink.table.expressions.WindowReference
 
productPrefix() - Static method in class org.apache.flink.table.expressions.WindowStart
 
productPrefix() - Static method in class org.apache.flink.table.plan.logical.Aggregate
 
productPrefix() - Static method in class org.apache.flink.table.plan.logical.AliasNode
 
productPrefix() - Static method in class org.apache.flink.table.plan.logical.CatalogNode
 
productPrefix() - Static method in class org.apache.flink.table.plan.logical.Distinct
 
productPrefix() - Static method in class org.apache.flink.table.plan.logical.Filter
 
productPrefix() - Static method in class org.apache.flink.table.plan.logical.Intersect
 
productPrefix() - Static method in class org.apache.flink.table.plan.logical.Join
 
productPrefix() - Static method in class org.apache.flink.table.plan.logical.Limit
 
productPrefix() - Static method in class org.apache.flink.table.plan.logical.LogicalRelNode
 
productPrefix() - Static method in class org.apache.flink.table.plan.logical.LogicalTableFunctionCall
 
productPrefix() - Static method in class org.apache.flink.table.plan.logical.Minus
 
productPrefix() - Static method in class org.apache.flink.table.plan.logical.Project
 
productPrefix() - Static method in class org.apache.flink.table.plan.logical.SessionGroupWindow
 
productPrefix() - Static method in class org.apache.flink.table.plan.logical.SlidingGroupWindow
 
productPrefix() - Static method in class org.apache.flink.table.plan.logical.Sort
 
productPrefix() - Static method in class org.apache.flink.table.plan.logical.TumblingGroupWindow
 
productPrefix() - Static method in class org.apache.flink.table.plan.logical.Union
 
productPrefix() - Static method in class org.apache.flink.table.plan.logical.WindowAggregate
 
productPrefix() - Static method in class org.apache.flink.table.plan.stats.ColumnStats
 
productPrefix() - Static method in class org.apache.flink.table.plan.stats.TableStats
 
productPrefix() - Static method in class org.apache.flink.table.validate.ValidationFailure
 
Program - Interface in org.apache.flink.api.common
A Program represents and end-to-end Flink program.
ProgramAbortException() - Constructor for error org.apache.flink.client.program.OptimizerPlanEnvironment.ProgramAbortException
 
ProgramDescription - Interface in org.apache.flink.api.common
Implementing this interface allows a Program to have a description of the plan which can be shown to the user.
ProgramInvocationException - Exception in org.apache.flink.client.program
Exception used to indicate that there is an error during the invocation of a Flink program.
ProgramInvocationException(String) - Constructor for exception org.apache.flink.client.program.ProgramInvocationException
Creates a ProgramInvocationException with the given message.
ProgramInvocationException(Throwable) - Constructor for exception org.apache.flink.client.program.ProgramInvocationException
Creates a ProgramInvocationException for the given exception.
ProgramInvocationException(String, Throwable) - Constructor for exception org.apache.flink.client.program.ProgramInvocationException
Creates a ProgramInvocationException for the given exception with an additional message.
ProgramMissingJobException - Exception in org.apache.flink.client.program
Exception used to indicate that no job was executed during the invocation of a Flink program.
ProgramMissingJobException() - Constructor for exception org.apache.flink.client.program.ProgramMissingJobException
 
ProgramOptions - Class in org.apache.flink.client.cli
Base class for command line options that refer to a JAR file program.
ProgramOptions(CommandLine) - Constructor for class org.apache.flink.client.cli.ProgramOptions
 
ProgramParametrizationException - Exception in org.apache.flink.client.program
Exception used to indicate that there is an error in the parametrization of a Flink program.
ProgramParametrizationException(String) - Constructor for exception org.apache.flink.client.program.ProgramParametrizationException
Creates a ProgramParametrizationException with the given message.
progress() - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyProgressable
 
progress() - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyReporter
 
project(int...) - Method in class org.apache.flink.api.java.DataSet
Applies a Project transformation on a Tuple DataSet.
Note: Only Tuple DataSets can be projected using field indexes.
The transformation projects each Tuple of the DataSet onto a (sub)set of fields.
Additional fields can be added to the projection by calling DataSet.project(int[]).
project(int...) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Initiates a Project transformation on a Tuple DataStream.
Note: Only Tuple DataStreams can be projected.
project(Iterable<? extends RexNode>) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
project(Iterable<? extends RexNode>, Iterable<String>) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
project(Iterable<? extends RexNode>, Iterable<String>, boolean) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
project(RexNode[]) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
Project - Class in org.apache.flink.table.plan.logical
 
Project(Seq<NamedExpression>, LogicalNode) - Constructor for class org.apache.flink.table.plan.logical.Project
 
project(ImmutableBitSet, Set<RelDataTypeField>, RelBuilder) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
project(ImmutableBitSet, Set<RelDataTypeField>, RelBuilder) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
Project$ - Class in org.apache.flink.table.plan.logical
 
Project$() - Constructor for class org.apache.flink.table.plan.logical.Project$
 
ProjectableTableSource<T> - Interface in org.apache.flink.table.sources
Adds support for projection push-down to a TableSource.
ProjectCross(DataSet<I1>, DataSet<I2>, int[], boolean[], TupleTypeInfo<OUT>, CrossOperatorBase.CrossHint) - Constructor for class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
 
ProjectCross(DataSet<I1>, DataSet<I2>, int[], boolean[], TupleTypeInfo<OUT>, CrossOperator.CrossProjection<I1, I2>, CrossOperatorBase.CrossHint) - Constructor for class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
 
projectFields(int[]) - Method in class org.apache.flink.addons.hbase.HBaseTableSource
 
projectFields(int[]) - Method in class org.apache.flink.table.sources.CsvTableSource
Returns a copy of TableSource with ability to project fields
projectFields(int[]) - Method in interface org.apache.flink.table.sources.ProjectableTableSource
Creates a copy of the TableSource that projects its output on the specified fields.
projectFirst(int...) - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Continues a ProjectCross transformation and adds fields of the first cross input.
If the first cross input is a Tuple DataSet, fields can be selected by their index.
projectFirst(int...) - Method in class org.apache.flink.api.java.operators.CrossOperator.DefaultCross
Initiates a ProjectCross transformation and projects the first cross input
If the first cross input is a Tuple DataSet, fields can be selected by their index.
projectFirst(int...) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
Continues a ProjectCross transformation and adds fields of the first cross input to the projection.
If the first cross input is a Tuple DataSet, fields can be selected by their index.
projectFirst(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.DefaultJoin
Applies a ProjectJoin transformation and projects the first join input
If the first join input is a Tuple DataSet, fields can be selected by their index.
projectFirst(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Continues a ProjectJoin transformation and adds fields of the first join input.
If the first join input is a Tuple DataSet, fields can be selected by their index.
projectFirst(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
Continues a ProjectJoin transformation and adds fields of the first join input to the projection.
If the first join input is a Tuple DataSet, fields can be selected by their index.
projecting(Function2<Stream<L>, Stream<R>, O>, TypeInformation<O>, ClassTag<O>) - Method in class org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions.OnCoGroupDataSet
Co-groups the data sets using the function fun to project elements from both in the resulting data set
projecting(Function2<L, R, O>, TypeInformation<O>, ClassTag<O>) - Method in class org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions.OnCrossDataSet
Starting from a cross data set, uses the function fun to project elements from both the input data sets in the resulting data set
projecting(Function2<L, R, O>, TypeInformation<O>, ClassTag<O>) - Method in class org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions.OnJoinFunctionAssigner
Joins the data sets using the function fun to project elements from both in the resulting data set
projecting(Function2<L, R, O>, TypeInformation<O>) - Method in class org.apache.flink.streaming.api.scala.extensions.impl.acceptPartialFunctions.OnJoinedStream
Completes the join operation with the user function that is executed for windowed groups.
Projection(DataSet<T>, int[]) - Constructor for class org.apache.flink.api.java.operators.ProjectOperator.Projection
 
Projection<KC,VVC,VV,EV> - Class in org.apache.flink.graph.bipartite
The edge value of a full bipartite projection contains: the ID and vertex value of the connecting vertex the vertex value for the source and target vertex both edge values from the bipartite edges
Projection() - Constructor for class org.apache.flink.graph.bipartite.Projection
 
Projection(Vertex<KC, VVC>, VV, VV, EV, EV) - Constructor for class org.apache.flink.graph.bipartite.Projection
 
projectionBottomFull() - Method in class org.apache.flink.graph.bipartite.BipartiteGraph
Convert a bipartite graph into a graph that contains only bottom vertices.
projectionBottomSimple() - Method in class org.apache.flink.graph.bipartite.BipartiteGraph
Convert a bipartite graph into an undirected graph that contains only bottom vertices.
projectionTopFull() - Method in class org.apache.flink.graph.bipartite.BipartiteGraph
Convert a bipartite graph into a graph that contains only top vertices.
projectionTopSimple() - Method in class org.apache.flink.graph.bipartite.BipartiteGraph
Convert a bipartite graph into an undirected graph that contains only top vertices.
ProjectionTranslator - Class in org.apache.flink.table.plan
 
ProjectionTranslator() - Constructor for class org.apache.flink.table.plan.ProjectionTranslator
 
ProjectionTranslator$ - Class in org.apache.flink.table.plan
 
ProjectionTranslator$() - Constructor for class org.apache.flink.table.plan.ProjectionTranslator$
 
ProjectJoin(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, JoinOperatorBase.JoinHint, int[], boolean[], TupleTypeInfo<OUT>) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
 
ProjectJoin(DataSet<I1>, DataSet<I2>, Keys<I1>, Keys<I2>, JoinOperatorBase.JoinHint, int[], boolean[], TupleTypeInfo<OUT>, JoinOperator.JoinProjection<I1, I2>) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
 
projectList() - Method in class org.apache.flink.table.plan.logical.Project
 
projectNestedFields(int[], String[][]) - Method in interface org.apache.flink.table.sources.NestedFieldsProjectableTableSource
Creates a copy of the TableSource that projects its output on the specified nested fields.
ProjectOperator<IN,OUT extends Tuple> - Class in org.apache.flink.api.java.operators
This operator represents the application of a projection operation on a data set, and the result data set produced by the function.
ProjectOperator(DataSet<IN>, int[], TupleTypeInfo<OUT>) - Constructor for class org.apache.flink.api.java.operators.ProjectOperator
 
ProjectOperator.Projection<T> - Class in org.apache.flink.api.java.operators
 
projectSecond(int...) - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Continues a ProjectCross transformation and adds fields of the second cross input.
If the second cross input is a Tuple DataSet, fields can be selected by their index.
projectSecond(int...) - Method in class org.apache.flink.api.java.operators.CrossOperator.DefaultCross
Initiates a ProjectCross transformation and projects the second cross input
If the second cross input is a Tuple DataSet, fields can be selected by their index.
projectSecond(int...) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
Continues a ProjectCross transformation and adds fields of the second cross input to the projection.
If the second cross input is a Tuple DataSet, fields can be selected by their index.
projectSecond(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.DefaultJoin
Applies a ProjectJoin transformation and projects the second join input
If the second join input is a Tuple DataSet, fields can be selected by their index.
projectSecond(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Continues a ProjectJoin transformation and adds fields of the second join input.
If the second join input is a Tuple DataSet, fields can be selected by their index.
projectSecond(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
Continues a ProjectJoin transformation and adds fields of the second join input to the projection.
If the second join input is a Tuple DataSet, fields can be selected by their index.
projectTuple1() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple1() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple1() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple1() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple10() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple10() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple10() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple10() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple11() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple11() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple11() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple11() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple12() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple12() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple12() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple12() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple13() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple13() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple13() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple13() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple14() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple14() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple14() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple14() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple15() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple15() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple15() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple15() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple16() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple16() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple16() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple16() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple17() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple17() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple17() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple17() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple18() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple18() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple18() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple18() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple19() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple19() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple19() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple19() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple2() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple2() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple2() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple2() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple20() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple20() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple20() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple20() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple21() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple21() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple21() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple21() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple22() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple22() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple22() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple22() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple23() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple23() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple23() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple23() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple24() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple24() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple24() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple24() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple25() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple25() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple25() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple25() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple3() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple3() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple3() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple3() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple4() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple4() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple4() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple4() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple5() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple5() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple5() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple5() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple6() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple6() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple6() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple6() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple7() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple7() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple7() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple7() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple8() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple8() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple8() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple8() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTuple9() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Projects a pair of crossed elements to a Tuple with the previously selected fields.
projectTuple9() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Projects a pair of joined elements to a Tuple with the previously selected fields.
projectTuple9() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Projects a Tuple DataSet to the previously selected fields.
projectTuple9() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Projects a Tuple DataStream to the previously selected fields.
projectTupleX() - Method in class org.apache.flink.api.java.operators.CrossOperator.CrossProjection
Chooses a projectTupleX according to the length of CrossOperator.CrossProjection.fieldIndexes
projectTupleX() - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinProjection
Chooses a projectTupleX according to the length of JoinOperator.JoinProjection.fieldIndexes
projectTupleX() - Method in class org.apache.flink.api.java.operators.ProjectOperator.Projection
Chooses a projectTupleX according to the length of ProjectOperator.Projection.fieldIndexes
projectTupleX() - Method in class org.apache.flink.streaming.api.datastream.StreamProjection
Chooses a projectTupleX according to the length of StreamProjection.fieldIndexes.
prompt() - Method in class org.apache.flink.api.scala.ILoopCompat
 
properties - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer09
User-supplied properties for Kafka
properties - Variable in class org.apache.flink.streaming.connectors.kafka.KafkaTableSink
 
properties() - Method in class org.apache.flink.table.catalog.ExternalCatalogTable
 
PropertiesUtil - Class in org.apache.flink.util
Simple utilities for getting typed values from Properties.
property() - Method in class org.apache.flink.table.calcite.FlinkRelBuilder.NamedWindowProperty
 
propertyExpressions() - Method in class org.apache.flink.table.plan.logical.WindowAggregate
 
ProxyMetricGroup<P extends MetricGroup> - Class in org.apache.flink.runtime.metrics.groups
Metric group which forwards all registration calls to its parent metric group.
ProxyMetricGroup(P) - Constructor for class org.apache.flink.runtime.metrics.groups.ProxyMetricGroup
 
prune(long) - Method in class org.apache.flink.cep.nfa.SharedBuffer
Deletes all entries in each page which have expired with respect to given pruning timestamp.
pruneBuffer() - Method in class org.apache.flink.runtime.util.DataOutputSerializer
 
prunePlanAlternatives(List<PlanNode>) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
prunePlanAlternativesWithCommonBranching(List<PlanNode>) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
Public - Annotation Type in org.apache.flink.annotation
Annotation for marking classes as public, stable interfaces.
PublicEvolving - Annotation Type in org.apache.flink.annotation
Annotation to mark classes and methods for public use, but with evolving interfaces.
publish(TaskEvent) - Method in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
 
publish(TaskEvent) - Method in class org.apache.flink.runtime.io.network.api.TaskEventHandler
Publishes the task event to all subscribed event listeners.
publish(ResultPartitionID, TaskEvent) - Method in class org.apache.flink.runtime.io.network.TaskEventDispatcher
Publishes the event to the registered ResultPartitionWriter instances.
PUNCTUATED_WATERMARKS - Static variable in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
 
PurgingTrigger<T,W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
A trigger that can turn any Trigger into a purging Trigger.
push(RelNode) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
pushAll(Iterable<? extends RelNode>) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
pushDownPages() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
 
PushFilterIntoTableSourceScanRule - Class in org.apache.flink.table.plan.rules.logical
 
PushFilterIntoTableSourceScanRule() - Constructor for class org.apache.flink.table.plan.rules.logical.PushFilterIntoTableSourceScanRule
 
PushFilterIntoTableSourceScanRule$ - Class in org.apache.flink.table.plan.rules.logical
 
PushFilterIntoTableSourceScanRule$() - Constructor for class org.apache.flink.table.plan.rules.logical.PushFilterIntoTableSourceScanRule$
 
PushProjectIntoTableSourceScanRule - Class in org.apache.flink.table.plan.rules.logical
 
PushProjectIntoTableSourceScanRule() - Constructor for class org.apache.flink.table.plan.rules.logical.PushProjectIntoTableSourceScanRule
 
PushProjectIntoTableSourceScanRule$ - Class in org.apache.flink.table.plan.rules.logical
 
PushProjectIntoTableSourceScanRule$() - Constructor for class org.apache.flink.table.plan.rules.logical.PushProjectIntoTableSourceScanRule$
 
put(UK, UV) - Method in interface org.apache.flink.api.common.state.MapState
Associates a new value with the given key.
put(K, V, long, K, V, long, int, DeweyNumber) - Method in class org.apache.flink.cep.nfa.SharedBuffer
Stores given value (value + timestamp) under the given key.
put(K, V, long, DeweyNumber) - Method in class org.apache.flink.cep.nfa.SharedBuffer
Stores given value (value + timestamp) under the given key.
put(UK, UV) - Method in class org.apache.flink.contrib.streaming.state.RocksDBMapState
 
put(int, byte) - Method in class org.apache.flink.core.memory.HeapMemorySegment
 
put(int, byte[]) - Method in class org.apache.flink.core.memory.HeapMemorySegment
 
put(int, byte[], int, int) - Method in class org.apache.flink.core.memory.HeapMemorySegment
 
put(DataInput, int, int) - Method in class org.apache.flink.core.memory.HeapMemorySegment
 
put(int, ByteBuffer, int) - Method in class org.apache.flink.core.memory.HeapMemorySegment
 
put(int, byte) - Method in class org.apache.flink.core.memory.HybridMemorySegment
 
put(int, byte[]) - Method in class org.apache.flink.core.memory.HybridMemorySegment
 
put(int, byte[], int, int) - Method in class org.apache.flink.core.memory.HybridMemorySegment
 
put(DataInput, int, int) - Method in class org.apache.flink.core.memory.HybridMemorySegment
 
put(int, ByteBuffer, int) - Method in class org.apache.flink.core.memory.HybridMemorySegment
 
put(int, byte) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given byte into this buffer at the given position.
put(int, byte[]) - Method in class org.apache.flink.core.memory.MemorySegment
Bulk put method.
put(int, byte[], int, int) - Method in class org.apache.flink.core.memory.MemorySegment
Bulk put method.
put(DataInput, int, int) - Method in class org.apache.flink.core.memory.MemorySegment
Bulk put method.
put(int, ByteBuffer, int) - Method in class org.apache.flink.core.memory.MemorySegment
Bulk put method.
put(byte[]) - Method in class org.apache.flink.runtime.blob.BlobClient
Uploads the data of the given byte array to the BLOB server in a content-addressable manner.
put(byte[], int, int) - Method in class org.apache.flink.runtime.blob.BlobClient
Uploads data from the given byte array to the BLOB server in a content-addressable manner.
put(JobID, String, byte[]) - Method in class org.apache.flink.runtime.blob.BlobClient
Uploads the data of the given byte array to the BLOB server and stores it under the given job ID and key.
put(JobID, String, byte[], int, int) - Method in class org.apache.flink.runtime.blob.BlobClient
Uploads data from the given byte array to the BLOB server and stores it under the given job ID and key.
put(JobID, String, InputStream) - Method in class org.apache.flink.runtime.blob.BlobClient
Uploads data from the given input stream to the BLOB server and stores it under the given job ID and key.
put(InputStream) - Method in class org.apache.flink.runtime.blob.BlobClient
Uploads the data from the given input stream to the BLOB server in a content-addressable manner.
put(File, BlobKey) - Method in interface org.apache.flink.runtime.blob.BlobStore
Copies the local file to the blob store.
put(File, JobID, String) - Method in interface org.apache.flink.runtime.blob.BlobStore
Copies a local file to the blob store.
put(File, BlobKey) - Method in class org.apache.flink.runtime.blob.FileSystemBlobStore
 
put(File, JobID, String) - Method in class org.apache.flink.runtime.blob.FileSystemBlobStore
 
put(File, BlobKey) - Method in class org.apache.flink.runtime.blob.VoidBlobStore
 
put(File, JobID, String) - Method in class org.apache.flink.runtime.blob.VoidBlobStore
 
put(T) - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
Adds a buffer to a PriorityQueue in log(size) time.
put(K, int, N, S) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
put(N, S) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
put(UK, UV) - Method in class org.apache.flink.runtime.state.heap.HeapMapState
 
put(N, S) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
put(K, int, N, S) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
put(N, S) - Method in class org.apache.flink.runtime.state.heap.StateTable
Maps the composite of active key and given namespace to the specified state.
put(K, int, N, S) - Method in class org.apache.flink.runtime.state.heap.StateTable
 
put(JobID, JobManagerConnection) - Method in class org.apache.flink.runtime.taskexecutor.JobManagerTable
 
put(K, V) - Method in class org.apache.flink.runtime.util.LRUCacheMap
 
put(Object, Object) - Method in class org.apache.flink.storm.util.StormConfig
 
put(StreamElementQueueEntry<T>) - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
 
put(StreamElementQueueEntry<T>) - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
Put the given element in the queue if capacity is left.
put(StreamElementQueueEntry<T>) - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
 
put(K, V) - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
Inserts the given value, mapped under the given key.
put(K, V) - Method in class org.apache.flink.types.MapValue
 
putAll(Map<UK, UV>) - Method in interface org.apache.flink.api.common.state.MapState
Copies all of the mappings from the given map into the state.
putAll(Map<UK, UV>) - Method in class org.apache.flink.contrib.streaming.state.RocksDBMapState
 
putAll(Map<UK, UV>) - Method in class org.apache.flink.runtime.state.heap.HeapMapState
 
putAll(Map) - Method in class org.apache.flink.storm.util.StormConfig
 
putAll(Map<? extends K, ? extends V>) - Method in class org.apache.flink.types.MapValue
 
putAndGetOld(N, S) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
putAndGetOld(N, S) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
putAndGetOld(N, S) - Method in class org.apache.flink.runtime.state.heap.StateTable
Maps the composite of active key and given namespace to the specified state.
putBoolean(int, boolean) - Method in class org.apache.flink.core.memory.HeapMemorySegment
 
putBoolean(int, boolean) - Method in class org.apache.flink.core.memory.HybridMemorySegment
 
putBoolean(int, boolean) - Method in class org.apache.flink.core.memory.MemorySegment
Writes one byte containing the byte value into this buffer at the given position.
putChar(int, char) - Method in class org.apache.flink.core.memory.MemorySegment
Writes a char value to teh given position, in the system's native byte order.
putCharBigEndian(int, char) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given character (16 bit, 2 bytes) to the given position in big-endian byte order.
putCharLittleEndian(int, char) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given character (16 bit, 2 bytes) to the given position in little-endian byte order.
putDouble(int, double) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given double-precision floating-point value (64bit, 8 bytes) to the given position in the system's native byte order.
putDoubleBigEndian(int, double) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given double-precision floating-point value (64bit, 8 bytes) to the given position in big endian byte order.
putDoubleLittleEndian(int, double) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given double-precision floating-point value (64bit, 8 bytes) to the given position in little endian byte order.
putFloat(int, float) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given single-precision float value (32bit, 4 bytes) to the given position in the system's native byte order.
putFloatBigEndian(int, float) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given single-precision float value (32bit, 4 bytes) to the given position in big endian byte order.
putFloatLittleEndian(int, float) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given single-precision float value (32bit, 4 bytes) to the given position in little endian byte order.
putIfAbsent(K, KeyMap.LazyFactory<V>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
Inserts a value for the given key, if no value is yet contained for that key.
putInt(int, int) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given int value (32bit, 4 bytes) to the given position in the system's native byte order.
putIntBigEndian(int, int) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given int value (32bit, 4 bytes) to the given position in big endian byte order.
putIntLittleEndian(int, int) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given int value (32bit, 4 bytes) to the given position in little endian byte order.
putJobGraph(SubmittedJobGraph) - Method in class org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
 
putJobGraph(SubmittedJobGraph) - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
Adds the SubmittedJobGraph instance.
putJobGraph(SubmittedJobGraph) - Method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
 
putKvState(int, KeyGroupState) - Method in class org.apache.flink.migration.runtime.checkpoint.TaskState
Deprecated.
 
putLong(int, long) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given long value (64bit, 8 bytes) to the given position in the system's native byte order.
putLongBigEndian(int, long) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given long value (64bit, 8 bytes) to the given position in big endian byte order.
putLongLittleEndian(int, long) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given long value (64bit, 8 bytes) to the given position in little endian byte order.
putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
putNormalizedKey(BigDecimal, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.BigDecComparator
Adds a normalized key containing a normalized order of magnitude of the given record.
putNormalizedKey(BigInteger, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.BigIntComparator
Adds a normalized key containing the normalized number of bits and MSBs of the given record.
putNormalizedKey(Boolean, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.BooleanComparator
 
putNormalizedKey(BooleanValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
putNormalizedKey(Byte, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.ByteComparator
 
putNormalizedKey(ByteValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
putNormalizedKey(Character, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.CharComparator
 
putNormalizedKey(CharValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
putNormalizedKey(Date, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.DateComparator
 
putNormalizedKey(Double, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.DoubleComparator
 
putNormalizedKey(DoubleValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.EnumComparator
 
putNormalizedKey(Float, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.FloatComparator
 
putNormalizedKey(FloatValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
putNormalizedKey(Integer, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.IntComparator
 
putNormalizedKey(IntValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
putNormalizedKey(Long, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.LongComparator
 
putNormalizedKey(LongValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
putNormalizedKey(NullValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
putNormalizedKey(Short, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.ShortComparator
 
putNormalizedKey(ShortValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
putNormalizedKey(Date, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampComparator
 
putNormalizedKey(String, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
 
putNormalizedKey(StringValue, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Writes a normalized key for the given record into the target byte array, starting at the specified position and writing exactly the given number of bytes.
putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
putNormalizedKey(Row, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
 
putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
 
putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
 
putNormalizedKey(T, MemorySegment, int, int) - Method in class org.apache.flink.api.scala.typeutils.CaseClassComparator
 
putNormalizedKey(Enumeration.Value, MemorySegment, int, int) - Method in class org.apache.flink.api.scala.typeutils.EnumValueComparator
 
putNormalizedKey(Option<A>, MemorySegment, int, int) - Method in class org.apache.flink.api.scala.typeutils.OptionTypeComparator
 
putNormalizedKey(IntValueArray, MemorySegment, int, int) - Method in class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
 
putNormalizedKey(LongValueArray, MemorySegment, int, int) - Method in class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
 
putNormalizedKey(NullValueArray, MemorySegment, int, int) - Method in class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
 
putNormalizedKey(StringValueArray, MemorySegment, int, int) - Method in class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
 
putNormalizedKey(CRow, MemorySegment, int, int) - Method in class org.apache.flink.table.runtime.types.CRowComparator
 
putNormalizedKeyDate(Date, MemorySegment, int, int) - Static method in class org.apache.flink.api.common.typeutils.base.DateComparator
 
putOrAggregate(K, V, ReduceFunction<V>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
Inserts or aggregates a value into the hash map.
putShort(int, short) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given short value into this buffer at the given position, using the native byte order of the system.
putShortBigEndian(int, short) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given short integer value (16 bit, 2 bytes) to the given position in big-endian byte order.
putShortLittleEndian(int, short) - Method in class org.apache.flink.core.memory.MemorySegment
Writes the given short integer value (16 bit, 2 bytes) to the given position in little-endian byte order.
putState(int, SubtaskState) - Method in class org.apache.flink.migration.runtime.checkpoint.TaskState
Deprecated.
 
putState(int, OperatorSubtaskState) - Method in class org.apache.flink.runtime.checkpoint.OperatorState
 
putState(int, SubtaskState) - Method in class org.apache.flink.runtime.checkpoint.TaskState
Deprecated.
 
putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.BooleanSerializer
 
putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.ByteSerializer
 
putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.BytesSerializer
 
putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.CustomTypeWrapperSerializer
 
putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.DoubleSerializer
 
putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.FloatSerializer
 
putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.IntSerializer
 
putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.LongSerializer
 
putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.NullSerializer
 
putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.Serializer
 
putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.StringSerializer
 
putTypeInfo(ByteBuffer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.TupleSerializer
 
putVariables(Map<String, String>) - Method in class org.apache.flink.runtime.metrics.groups.ComponentMetricGroup
Enters all variables specific to this ComponentMetricGroup and their associated values into the map.
putVariables(Map<String, String>) - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
 
putVariables(Map<String, String>) - Method in class org.apache.flink.runtime.metrics.groups.JobMetricGroup
 
putVariables(Map<String, String>) - Method in class org.apache.flink.runtime.metrics.groups.OperatorMetricGroup
 
putVariables(Map<String, String>) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
 
putVariables(Map<String, String>) - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
putWorker(MesosWorkerStore.Worker) - Method in interface org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore
Put a worker into storage.
putWorker(MesosWorkerStore.Worker) - Method in class org.apache.flink.mesos.runtime.clusterframework.store.StandaloneMesosWorkerStore
 
putWorker(MesosWorkerStore.Worker) - Method in class org.apache.flink.mesos.runtime.clusterframework.store.ZooKeeperMesosWorkerStore
 
PYTHON_BINARY_PATH - Static variable in class org.apache.flink.python.api.PythonOptions
The config parameter defining the path to the python binary to use.
PythonCoGroup<IN1,IN2,OUT> - Class in org.apache.flink.python.api.functions
CoGroupFunction that uses a python script.
PythonCoGroup(Configuration, int, int, TypeInformation<OUT>) - Constructor for class org.apache.flink.python.api.functions.PythonCoGroup
 
PythonDualInputSender<IN1,IN2> - Class in org.apache.flink.python.api.streaming.data
This class is a PythonSender for operations with two input streams.
PythonDualInputSender(Configuration) - Constructor for class org.apache.flink.python.api.streaming.data.PythonDualInputSender
 
PythonDualInputStreamer<IN1,IN2,OUT> - Class in org.apache.flink.python.api.streaming.data
This class is a PythonStreamer for operations with two input stream.
PythonDualInputStreamer(AbstractRichFunction, Configuration, int, int, boolean) - Constructor for class org.apache.flink.python.api.streaming.data.PythonDualInputStreamer
 
PythonMapPartition<IN,OUT> - Class in org.apache.flink.python.api.functions
Multi-purpose class, usable by all operations using a python script with one input source and possibly differing in-/output types.
PythonMapPartition(Configuration, int, int, TypeInformation<OUT>) - Constructor for class org.apache.flink.python.api.functions.PythonMapPartition
 
PythonOperationInfo - Class in org.apache.flink.python.api
 
PythonOperationInfo(PythonPlanStreamer, int) - Constructor for class org.apache.flink.python.api.PythonOperationInfo
 
PythonOperationInfo.DatasizeHint - Enum in org.apache.flink.python.api
 
PythonOptions - Class in org.apache.flink.python.api
Configuration options for the Python API.
PythonPlanBinder - Class in org.apache.flink.python.api
This class allows the execution of a Flink plan written in python.
PythonPlanBinder(Configuration) - Constructor for class org.apache.flink.python.api.PythonPlanBinder
 
PythonPlanBinder.Operation - Enum in org.apache.flink.python.api
This enum contains the identifiers for all supported DataSet operations.
PythonPlanReceiver - Class in org.apache.flink.python.api.streaming.plan
Instances of this class can be used to receive data from the plan process.
PythonPlanReceiver(InputStream) - Constructor for class org.apache.flink.python.api.streaming.plan.PythonPlanReceiver
 
PythonPlanSender - Class in org.apache.flink.python.api.streaming.plan
Instances of this class can be used to send data to the plan process.
PythonPlanSender(OutputStream) - Constructor for class org.apache.flink.python.api.streaming.plan.PythonPlanSender
 
PythonPlanStreamer - Class in org.apache.flink.python.api.streaming.plan
Generic class to exchange data during the plan phase.
PythonPlanStreamer(Configuration) - Constructor for class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
 
PythonReceiver<OUT> - Class in org.apache.flink.python.api.streaming.data
This class is used to read data from memory-mapped files.
PythonReceiver(Configuration, boolean) - Constructor for class org.apache.flink.python.api.streaming.data.PythonReceiver
 
PythonSender - Class in org.apache.flink.python.api.streaming.data
General-purpose class to write data to memory-mapped files.
PythonSender(Configuration) - Constructor for class org.apache.flink.python.api.streaming.data.PythonSender
 
PythonSender.Serializer<T> - Class in org.apache.flink.python.api.streaming.data
 
PythonSingleInputSender<IN> - Class in org.apache.flink.python.api.streaming.data
This class is a PythonSender for operations with one input stream.
PythonSingleInputSender(Configuration) - Constructor for class org.apache.flink.python.api.streaming.data.PythonSingleInputSender
 
PythonSingleInputStreamer<IN,OUT> - Class in org.apache.flink.python.api.streaming.data
This class is a PythonStreamer for operations with one input stream.
PythonSingleInputStreamer(AbstractRichFunction, Configuration, int, int, boolean) - Constructor for class org.apache.flink.python.api.streaming.data.PythonSingleInputStreamer
 
PythonStreamer<S extends PythonSender,OUT> - Class in org.apache.flink.python.api.streaming.data
This streamer is used by functions to send/receive data to/from an external python process.
PythonStreamer(AbstractRichFunction, Configuration, int, int, boolean, S) - Constructor for class org.apache.flink.python.api.streaming.data.PythonStreamer
 

Q

QuadTree - Class in org.apache.flink.ml.nn
n-dimensional QuadTree data structure; partitions spatial data for faster queries (e.g.
QuadTree(Vector, Vector, DistanceMetric, int) - Constructor for class org.apache.flink.ml.nn.QuadTree
 
QuadTree.Node - Class in org.apache.flink.ml.nn
 
qualifyEnum(Enum<?>) - Method in class org.apache.flink.table.codegen.CodeGenUtils$
 
qualifyEnum(Enum<?>) - Static method in class org.apache.flink.table.codegen.CodeGenUtils
 
qualifyMethod(Method) - Method in class org.apache.flink.table.codegen.CodeGenUtils$
 
qualifyMethod(Method) - Static method in class org.apache.flink.table.codegen.CodeGenUtils
 
Quantifier - Class in org.apache.flink.cep.pattern
 
Quantifier.ConsumingStrategy - Enum in org.apache.flink.cep.pattern
 
Quantifier.QuantifierProperty - Enum in org.apache.flink.cep.pattern
Properties that a Quantifier can have.
QuarantineHandler - Interface in org.apache.flink.runtime.akka
Callback interface for the QuarantineMonitor which is called in case the actor system has been quarantined or quarantined another system.
QuarantineMonitor - Class in org.apache.flink.runtime.akka
The quarantine monitor subscribes to the event bus of the actor system in which it was started.
QuarantineMonitor(QuarantineHandler, Logger) - Constructor for class org.apache.flink.runtime.akka.QuarantineMonitor
 
QUARTER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The SQL QUARTER operator.
quarter() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Returns the quarter of a year from a SQL date.
Quarter - Class in org.apache.flink.table.expressions
Extracts the quarter of a year from a SQL date.
Quarter(Expression) - Constructor for class org.apache.flink.table.expressions.Quarter
 
QUARTER() - Method in class org.apache.flink.table.expressions.TimePointUnit$
 
QUARTER() - Static method in class org.apache.flink.table.expressions.TimePointUnit
 
Quarter$ - Class in org.apache.flink.table.expressions
 
Quarter$() - Constructor for class org.apache.flink.table.expressions.Quarter$
 
query - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
 
QueryableAppendingStateOperator<IN> - Class in org.apache.flink.streaming.api.functions.query
Internal operator handling queryable AppendingState instances.
QueryableAppendingStateOperator(String, StateDescriptor<? extends AppendingState<IN, ?>, ?>) - Constructor for class org.apache.flink.streaming.api.functions.query.QueryableAppendingStateOperator
 
QueryableStateClient - Class in org.apache.flink.runtime.query
Client for queryable state.
QueryableStateClient(Configuration, HighAvailabilityServices) - Constructor for class org.apache.flink.runtime.query.QueryableStateClient
Creates a client from the given configuration.
QueryableStateClient(KvStateLocationLookupService, KvStateClient, ExecutionContext) - Constructor for class org.apache.flink.runtime.query.QueryableStateClient
Creates a client.
QueryableStateConfiguration - Class in org.apache.flink.runtime.taskexecutor
Simple configuration object for the parameters for the server-side of queryable state.
QueryableStateConfiguration(boolean, int, int, int) - Constructor for class org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
 
QueryableStateOptions - Class in org.apache.flink.configuration
The set of configuration options relating to Queryable State.
QueryableStateStream<K,V> - Class in org.apache.flink.streaming.api.datastream
Queryable state stream instance.
QueryableStateStream(String, TypeSerializer<V>, TypeSerializer<K>) - Constructor for class org.apache.flink.streaming.api.datastream.QueryableStateStream
Creates a queryable state stream.
QueryableValueStateOperator<IN> - Class in org.apache.flink.streaming.api.functions.query
Internal operator handling queryable ValueState instances.
QueryableValueStateOperator(String, StateDescriptor<ValueState<IN>, IN>) - Constructor for class org.apache.flink.streaming.api.functions.query.QueryableValueStateOperator
 
QueryConfig - Class in org.apache.flink.table.api
 
QueryConfig() - Constructor for class org.apache.flink.table.api.QueryConfig
 
queryConfig() - Method in class org.apache.flink.table.api.StreamTableEnvironment
 
QueryScopeInfo - Class in org.apache.flink.runtime.metrics.dump
Container for scope related information as required by the MetricQueryService.
QueryScopeInfo.JobManagerQueryScopeInfo - Class in org.apache.flink.runtime.metrics.dump
Container for the job manager scope.
QueryScopeInfo.JobQueryScopeInfo - Class in org.apache.flink.runtime.metrics.dump
Container for the job scope.
QueryScopeInfo.OperatorQueryScopeInfo - Class in org.apache.flink.runtime.metrics.dump
Container for the operator scope.
QueryScopeInfo.TaskManagerQueryScopeInfo - Class in org.apache.flink.runtime.metrics.dump
Container for the task manager scope.
QueryScopeInfo.TaskQueryScopeInfo - Class in org.apache.flink.runtime.metrics.dump
Container for the task scope.
queryServiceScopeInfo - Variable in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
The metrics query service scope represented by this group, lazily computed.
queue() - Method in class org.apache.flink.api.scala.FlinkShell.YarnConfig
 
queueName - Variable in class org.apache.flink.streaming.connectors.rabbitmq.RMQSink
 
queueName - Variable in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
 
queues - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
The queue of empty buffer that can be used for reading;
QueuingCallback<T> - Class in org.apache.flink.runtime.io.disk.iomanager
A RequestDoneCallback that adds the memory segments to a blocking queue.
QueuingCallback(LinkedBlockingQueue<T>) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.QueuingCallback
 
QuickSort - Class in org.apache.flink.runtime.operators.sort
 
QuickSort() - Constructor for class org.apache.flink.runtime.operators.sort.QuickSort
 
quiesceAndAwaitPending() - Method in class org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
This method puts the service into a state where it does not register new timers, but returns for each call to ProcessingTimeService.registerTimer(long, ProcessingTimeCallback) only a "mock" future.
quiesceAndAwaitPending() - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
 
quiesceAndAwaitPending() - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
quoteCharacter - Variable in class org.apache.flink.api.java.io.CsvReader
 
quoteCharacter(Character) - Method in class org.apache.flink.table.sources.CsvTableSource.Builder
Sets a quote character for String values, null by default.

R

RADIANS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
radians() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Converts numeric from degrees to radians.
RADIANS() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
RADIANS() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
Radians - Class in org.apache.flink.table.expressions
 
Radians(Expression) - Constructor for class org.apache.flink.table.expressions.Radians
 
Radians$ - Class in org.apache.flink.table.expressions
 
Radians$() - Constructor for class org.apache.flink.table.expressions.Radians$
 
RADIANS_DEC() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
RADIANS_DEC() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
RAND - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The RAND([seed]) function, which yields a random double, optionally with seed.
RAND_INTEGER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The RAND_INTEGER([seed, ] bound) function, which yields a random integer, optionally with seed.
RandomAccessInputView - Class in org.apache.flink.runtime.io.disk
 
RandomAccessInputView(ArrayList<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.io.disk.RandomAccessInputView
 
RandomAccessInputView(ArrayList<MemorySegment>, int, int) - Constructor for class org.apache.flink.runtime.io.disk.RandomAccessInputView
 
RandomAccessOutputView - Class in org.apache.flink.runtime.io.disk
 
RandomAccessOutputView(MemorySegment[], int) - Constructor for class org.apache.flink.runtime.io.disk.RandomAccessOutputView
 
RandomAccessOutputView(MemorySegment[], int, int) - Constructor for class org.apache.flink.runtime.io.disk.RandomAccessOutputView
 
randomEmit(T) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
This is used to send LatencyMarks to a random target channel
randomEmit(T) - Method in class org.apache.flink.streaming.runtime.io.StreamRecordWriter
 
randomFactors(int, Random) - Method in class org.apache.flink.ml.recommendation.ALS$
 
randomFactors(int, Random) - Static method in class org.apache.flink.ml.recommendation.ALS
 
RandomGenerable<T extends org.apache.commons.math3.random.RandomGenerator> - Interface in org.apache.flink.graph.generator.random
A RandomGenerable provides deferred instantiation and initialization of a RandomGenerator.
RandomGenerableFactory<T extends org.apache.commons.math3.random.RandomGenerator> - Interface in org.apache.flink.graph.generator.random
A RandomGenerableFactory returns a scale-free collection of sources of pseudorandomness which can be used to perform repeatable parallel computation regardless of parallelism.
RandomSampler<T> - Class in org.apache.flink.api.java.sampling
A data sample is a set of data selected from a statistical population by a defined procedure.
RandomSampler() - Constructor for class org.apache.flink.api.java.sampling.RandomSampler
 
randomSplit(DataSet<T>, double, boolean, long, TypeInformation<T>, ClassTag<T>) - Method in class org.apache.flink.ml.preprocessing.Splitter$
Split a DataSet by the probability fraction of each element.
randomSplit(DataSet<T>, double, boolean, long, TypeInformation<T>, ClassTag<T>) - Static method in class org.apache.flink.ml.preprocessing.Splitter
Split a DataSet by the probability fraction of each element.
RandomSpout - Class in org.apache.flink.storm.split.operators
 
RandomSpout(boolean, long) - Constructor for class org.apache.flink.storm.split.operators.RandomSpout
 
range(long, long) - Static method in class org.apache.flink.mesos.Utils
Construct a range value.
RangeBoundaries<T> - Interface in org.apache.flink.api.common.distributions
RangeBoundaries is used to split the records into multiple ranges.
RangeBoundaryBuilder<T> - Class in org.apache.flink.runtime.operators.udf
Build RangeBoundaries with input records.
RangeBoundaryBuilder(TypeComparatorFactory<T>, int) - Constructor for class org.apache.flink.runtime.operators.udf.RangeBoundaryBuilder
 
RangePartitionRewriter - Class in org.apache.flink.optimizer.traversals
 
RangePartitionRewriter(OptimizedPlan) - Constructor for class org.apache.flink.optimizer.traversals.RangePartitionRewriter
 
ranges(String, String, Protos.Value.Range...) - Static method in class org.apache.flink.mesos.Utils
Construct a ranges resource value.
RANK - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
RANK window function.
rank() - Method in class org.apache.flink.examples.scala.graph.PageRankBasic.Page
 
RankAssigner(double) - Constructor for class org.apache.flink.examples.java.graph.PageRank.RankAssigner
 
RankMessenger() - Constructor for class org.apache.flink.graph.examples.PageRank.RankMessenger
 
RANKS - Static variable in class org.apache.flink.examples.java.relational.util.WebLogData
 
RANKS - Static variable in class org.apache.flink.test.testdata.WebLogAnalysisData
 
RANKS_AFTER_3_ITERATIONS - Static variable in class org.apache.flink.graph.examples.data.PageRankData
 
RANKS_AFTER_3_ITERATIONS - Static variable in class org.apache.flink.test.testdata.PageRankData
 
RANKS_AFTER_EPSILON_0_0001_CONVERGENCE - Static variable in class org.apache.flink.test.testdata.PageRankData
 
rate - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.MeterDump
 
Rating(long, long, double) - Constructor for class org.apache.flink.ml.recommendation.ALS.Rating
 
rating() - Method in class org.apache.flink.ml.recommendation.ALS.Rating
 
Rating$() - Constructor for class org.apache.flink.ml.recommendation.ALS.Rating$
 
ratings() - Method in class org.apache.flink.ml.recommendation.ALS.BlockRating
 
ratingsForBlock() - Method in class org.apache.flink.ml.recommendation.ALS.InBlockInformation
 
reacceptRegisteredWorkers(Collection<ResourceID>) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
Accept the given registered workers into the internal state.
reacceptRegisteredWorkers(Collection<ResourceID>) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
This method is called when the resource manager starts after a failure and reconnects to the leader JobManager, who still has some workers registered.
reacceptRegisteredWorkers(Collection<ResourceID>) - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
 
reacceptRegisteredWorkers(Collection<ResourceID>) - Method in class org.apache.flink.yarn.YarnFlinkResourceManager
 
reachedEnd() - Method in class org.apache.flink.addons.hbase.AbstractTableInputFormat
 
reachedEnd() - Method in class org.apache.flink.api.common.io.BinaryInputFormat
 
reachedEnd() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
Checks whether the current split is at its end.
reachedEnd() - Method in interface org.apache.flink.api.common.io.InputFormat
Method used to check if the end of the input is reached.
reachedEnd() - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
 
reachedEnd() - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
reachedEnd() - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
reachedEnd() - Method in class org.apache.flink.api.java.io.AvroInputFormat
 
reachedEnd() - Method in class org.apache.flink.api.java.io.CollectionInputFormat
 
reachedEnd() - Method in class org.apache.flink.api.java.io.IteratorInputFormat
 
reachedEnd() - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat
Checks whether all data has been read.
reachedEnd() - Method in class org.apache.flink.api.java.io.ParallelIteratorInputFormat
 
reachedEnd() - Method in class org.apache.flink.batch.connectors.cassandra.CassandraInputFormat
 
reachedEnd() - Method in class org.apache.flink.examples.java.distcp.FileCopyTaskInputFormat
 
reachedEnd() - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
 
reachedEnd() - Method in class org.apache.flink.storm.util.FiniteFileSpout
Can be called before nextTuple() any times including 0.
reachedEnd() - Method in class org.apache.flink.storm.util.FiniteInMemorySpout
 
reachedEnd() - Method in interface org.apache.flink.storm.util.FiniteSpout
When returns true, the spout has reached the end of the stream.
reachedEnd() - Method in class org.apache.flink.storm.util.NullTerminatingSpout
 
reachedEnd() - Method in class org.apache.flink.table.runtime.io.CRowValuesInputFormat
 
reachedEnd() - Method in class org.apache.flink.table.runtime.io.ValuesInputFormat
 
read(byte[], int, int) - Method in class org.apache.flink.api.avro.FSDataInputStreamWrapper
 
read() - Method in class org.apache.flink.api.common.io.BinaryInputFormat.BlockBasedInput
 
read(byte[]) - Method in class org.apache.flink.api.common.io.BinaryInputFormat.BlockBasedInput
 
read(byte[], int, int) - Method in class org.apache.flink.api.common.io.BinaryInputFormat.BlockBasedInput
 
read(DataInputView) - Method in class org.apache.flink.api.common.io.BlockInfo
 
read() - Method in class org.apache.flink.api.common.io.InputStreamFSInputWrapper
 
read(byte[], int, int) - Method in class org.apache.flink.api.common.io.InputStreamFSInputWrapper
 
read(byte[]) - Method in class org.apache.flink.api.common.io.InputStreamFSInputWrapper
 
read(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot
 
read(DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializerConfigSnapshot
 
read(DataInputView) - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
 
read(DataInputView) - Method in class org.apache.flink.api.common.typeutils.GenericTypeSerializerConfigSnapshot
 
read(DataInputView) - Method in class org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
 
read(DataInputView) - Method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil.TypeSerializerSerializationProxy
 
read(ObjectInputStream) - Method in class org.apache.flink.api.java.hadoop.common.HadoopInputFormatCommonBase
 
read(ObjectInputStream) - Method in class org.apache.flink.api.java.hadoop.common.HadoopOutputFormatCommonBase
 
read(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer.AvroSerializerConfigSnapshot
 
read() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
 
read(byte[], int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
 
read(Kryo, Input, Class) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.JavaSerializer
 
read(Kryo, Input, Class<Schema>) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.AvroSchemaSerializer
 
read(Kryo, Input, Class) - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot.DummyKryoSerializerClass
 
read(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot
 
read() - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
read(byte[], int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
read(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
 
read(DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerConfigSnapshot
 
read(DataInputView) - Method in class org.apache.flink.api.scala.typeutils.EnumValueSerializer.ScalaEnumSerializerConfigSnapshot
 
read(DataInputView) - Method in class org.apache.flink.configuration.Configuration
 
read(DataInputView) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
read() - Method in class org.apache.flink.core.fs.AbstractMultiFSDataInputStream
 
read() - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
 
read(byte[]) - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
 
read(byte[], int, int) - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
 
read() - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
 
read(byte[], int, int) - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
 
read(DataInputView) - Method in class org.apache.flink.core.fs.Path
 
read(DataInputView) - Method in interface org.apache.flink.core.io.IOReadableWritable
Reads the object's internal data from the given data input view.
read(DataInputView) - Method in class org.apache.flink.core.io.VersionedIOReadableWritable
 
read() - Method in class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
 
read(byte[], int, int) - Method in class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
 
read(byte[], int, int) - Method in interface org.apache.flink.core.memory.DataInputView
Reads up to len bytes of memory and stores it into b starting at offset off.
read(byte[]) - Method in interface org.apache.flink.core.memory.DataInputView
Tries to fill the given byte array b.
read(DataInputView) - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
 
read(DataInputView) - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
 
read(DataInputView) - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
 
read(DataInputView) - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
 
read(DataInputView) - Method in class org.apache.flink.ml.recommendation.ALS.OutLinks
 
read() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
 
read(byte[], int, int) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
 
read() - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileSegmentReader
 
read() - Method in interface org.apache.flink.runtime.io.disk.iomanager.BufferFileSegmentReader
 
read(DataInputView) - Method in class org.apache.flink.runtime.io.network.api.CancelCheckpointMarker
 
read(DataInputView) - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
 
read(DataInputView) - Method in class org.apache.flink.runtime.io.network.api.EndOfPartitionEvent
 
read(DataInputView) - Method in class org.apache.flink.runtime.io.network.api.EndOfSuperstepEvent
 
read(DataInputView) - Method in class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
 
read(DataInputView) - Method in class org.apache.flink.runtime.iterative.event.TerminationEvent
 
read(DataInputView) - Method in class org.apache.flink.runtime.iterative.event.WorkerDoneEvent
 
read(byte[]) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
 
read(byte[], int, int) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
 
read(DataInputView) - Method in class org.apache.flink.runtime.plugable.NonReusingDeserializationDelegate
 
read(DataInputView) - Method in class org.apache.flink.runtime.plugable.ReusingDeserializationDelegate
 
read(DataInputView) - Method in class org.apache.flink.runtime.plugable.SerializationDelegate
 
read() - Method in class org.apache.flink.runtime.state.BoundedInputStream
 
read(byte[]) - Method in class org.apache.flink.runtime.state.BoundedInputStream
 
read(byte[], int, int) - Method in class org.apache.flink.runtime.state.BoundedInputStream
 
read(DataInputView) - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
 
read(DataInputView) - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
 
read(byte[], int, int) - Method in class org.apache.flink.runtime.util.DataInputDeserializer
 
read(byte[]) - Method in class org.apache.flink.runtime.util.DataInputDeserializer
 
read() - Method in class org.apache.flink.runtime.util.NonClosingStreamDecorator
 
read(byte[]) - Method in class org.apache.flink.runtime.util.NonClosingStreamDecorator
 
read(byte[], int, int) - Method in class org.apache.flink.runtime.util.NonClosingStreamDecorator
 
read(DataInputView) - Method in class org.apache.flink.types.BooleanValue
 
read(DataInputView) - Method in class org.apache.flink.types.ByteValue
 
read(DataInputView) - Method in class org.apache.flink.types.CharValue
 
read(DataInputView) - Method in class org.apache.flink.types.DoubleValue
 
read(DataInputView) - Method in class org.apache.flink.types.FloatValue
 
read(DataInputView) - Method in class org.apache.flink.types.IntValue
 
read(DataInputView) - Method in class org.apache.flink.types.ListValue
 
read(DataInputView) - Method in class org.apache.flink.types.LongValue
 
read(DataInputView) - Method in class org.apache.flink.types.MapValue
 
read(DataInputView) - Method in class org.apache.flink.types.NullValue
 
read(DataInputView) - Method in class org.apache.flink.types.Record
 
read(DataInputView) - Method in class org.apache.flink.types.ShortValue
 
read(DataInputView) - Method in class org.apache.flink.types.StringValue
 
READ_WHOLE_SPLIT_FLAG - Static variable in class org.apache.flink.api.common.io.FileInputFormat
The splitLength is set to -1L for reading the whole split.
readAllResultLines(List<String>, String) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
readAllResultLines(List<String>, String, String[]) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
readAllResultLines(List<String>, String, String[], boolean) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
readAndSetBroadcastInput(int, String, DistributedRuntimeUDFContext, int) - Method in class org.apache.flink.runtime.operators.BatchTask
 
readArrayStart() - Method in class org.apache.flink.api.avro.DataInputDecoder
 
readArrayStart() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
readBigDecimal(DataInputView) - Static method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
readBigInteger(DataInputView) - Static method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
readBlock(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockReader
Issues a read request, which will asynchronously fill the given segment with the next block in the underlying file channel.
readBlock(T) - Method in interface org.apache.flink.runtime.io.disk.iomanager.BlockChannelReader
Issues a read request, which will fill the given segment with the next block in the underlying file channel.
readBoolean() - Method in class org.apache.flink.api.avro.DataInputDecoder
 
readBoolean() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
readBoolean() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
 
readBoolean() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
 
readByte() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
 
readByte() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
 
readBytes(ByteBuffer) - Method in class org.apache.flink.api.avro.DataInputDecoder
 
readBytes(ByteBuffer) - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
readBytes(byte[], int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
readChar() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
 
readChar() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
 
readClassDescriptor() - Method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil.SerialUIDMismatchTolerantInputStream
 
readCsvFile(String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a CSV reader to read a comma separated value (CSV) file.
readCsvFile(String, String, String, Character, boolean, String, boolean, int[], String[], ClassTag<T>, TypeInformation<T>) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Creates a DataSet by reading the given CSV file.
readDouble() - Method in class org.apache.flink.api.avro.DataInputDecoder
 
readDouble() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
readDouble() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
 
readDouble() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
 
readDualForwardAnnotations(Class<?>) - Static method in class org.apache.flink.api.java.functions.FunctionAnnotation
Reads the annotations of a user defined function with two inputs and returns semantic properties according to the forwarded fields annotated.
readEnum() - Method in class org.apache.flink.api.avro.DataInputDecoder
 
readEnum() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
reader - Variable in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
 
Reader<T extends IOReadableWritable> - Interface in org.apache.flink.runtime.io.network.api.reader
A record-oriented reader for immutable record types.
reader - Variable in class org.apache.flink.storm.util.FileSpout
 
ReaderBase - Interface in org.apache.flink.runtime.io.network.api.reader
The basic API for every reader.
ReaderIterator<T> - Class in org.apache.flink.runtime.operators.util
A MutableObjectIterator that wraps a reader from an input channel and produces the reader's records.
ReaderIterator(MutableReader<DeserializationDelegate<T>>, TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.operators.util.ReaderIterator
Creates a new iterator, wrapping the given reader.
readFile(FileInputFormat<X>, String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
 
readFile(FileInputFormat<T>, String, ClassTag<T>, TypeInformation<T>) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Creates a new DataSource by reading the specified file using the custom FileInputFormat.
readFile(FileInputFormat<OUT>, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Reads the contents of the user-specified filePath based on the given FileInputFormat.
readFile(FileInputFormat<OUT>, String, FileProcessingMode, long, FilePathFilter) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
readFile(FileInputFormat<OUT>, String, FileProcessingMode, long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Reads the contents of the user-specified filePath based on the given FileInputFormat.
readFile(FileInputFormat<OUT>, String, FileProcessingMode, long, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Reads the contents of the user-specified filePath based on the given FileInputFormat.
readFile(FileInputFormat<T>, String, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Reads the given file with the given input format.
readFile(FileInputFormat<T>, String, FileProcessingMode, long, FilePathFilter, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Deprecated.
Use FileInputFormat#setFilesFilter(FilePathFilter) to set a filter and StreamExecutionEnvironment#readFile(FileInputFormat, String, FileProcessingMode, long)
readFile(FileInputFormat<T>, String, FileProcessingMode, long, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Reads the contents of the user-specified path based on the given FileInputFormat.
readFile(File, String) - Static method in class org.apache.flink.util.FileUtils
 
readFileInfoFromConfig(Configuration) - Static method in class org.apache.flink.api.common.cache.DistributedCache
 
readFileOfPrimitives(String, Class<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a DataSet that represents the primitive type produced by reading the given file line wise.
readFileOfPrimitives(String, String, Class<X>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a DataSet that represents the primitive type produced by reading the given file in delimited way.
readFileOfPrimitives(String, String, ClassTag<T>, TypeInformation<T>) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Creates a DataSet that represents the primitive type produced by reading the given file in delimited way.This method is similar to readCsvFile with single field, but it produces a DataSet not through Tuple.
readFileStream(String, long, FileMonitoringFunction.WatchType) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
readFileStream(String, long, FileMonitoringFunction.WatchType) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Creates a DataStream that contains the contents of file created while system watches the given path.
readFileUtf8(File) - Static method in class org.apache.flink.util.FileUtils
 
readFixed(byte[], int, int) - Method in class org.apache.flink.api.avro.DataInputDecoder
 
readFixed(byte[], int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
readFloat() - Method in class org.apache.flink.api.avro.DataInputDecoder
 
readFloat() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
readFloat() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
 
readFloat() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
 
readFromInput(DataInputView, TypeSerializer<Key>, TypeSerializer<Aggregate>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
 
ReadFromKafka - Class in org.apache.flink.streaming.examples.kafka
Read Strings from Kafka and print them to standard out.
ReadFromKafka() - Constructor for class org.apache.flink.streaming.examples.kafka.ReadFromKafka
 
readFully(byte[]) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
 
readFully(byte[], int, int) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
 
readFully(byte[]) - Method in class org.apache.flink.runtime.util.DataInputDeserializer
 
readFully(byte[], int, int) - Method in class org.apache.flink.runtime.util.DataInputDeserializer
 
readFully(InputStream, byte[], int, int) - Static method in class org.apache.flink.util.IOUtils
Reads len bytes in a loop.
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String, JobConf) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Please use org.apache.flink.hadoopcompatibility.HadoopInputs#readHadoopFile(org.apache.hadoop.mapred.FileInputFormat, Class, Class, String, JobConf) from the flink-hadoop-compatibility module.
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Please use org.apache.flink.hadoopcompatibility.HadoopInputs#readHadoopFile(org.apache.hadoop.mapred.FileInputFormat, Class, Class, String) from the flink-hadoop-compatibility module.
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String, Job) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Please use org.apache.flink.hadoopcompatibility.HadoopInputs#readHadoopFile(org.apache.hadoop.mapreduce.lib.input.FileInputFormat, Class, Class, String, Job) from the flink-hadoop-compatibility module.
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Please use org.apache.flink.hadoopcompatibility.HadoopInputs#readHadoopFile(org.apache.hadoop.mapreduce.lib.input.FileInputFormat, Class, Class, String) from the flink-hadoop-compatibility module.
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String, JobConf, TypeInformation<Tuple2<K, V>>) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String, TypeInformation<Tuple2<K, V>>) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String, Job, TypeInformation<Tuple2<K, V>>) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String, TypeInformation<Tuple2<K, V>>) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String, JobConf) - Static method in class org.apache.flink.hadoopcompatibility.HadoopInputs
Creates a Flink InputFormat that wraps the given Hadoop FileInputFormat.
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String) - Static method in class org.apache.flink.hadoopcompatibility.HadoopInputs
Creates a Flink InputFormat that wraps the given Hadoop FileInputFormat.
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String, Job) - Static method in class org.apache.flink.hadoopcompatibility.HadoopInputs
Creates a Flink InputFormat that wraps the given Hadoop FileInputFormat.
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String) - Static method in class org.apache.flink.hadoopcompatibility.HadoopInputs
Creates a Flink InputFormat that wraps the given Hadoop FileInputFormat.
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String, JobConf, TypeInformation<Tuple2<K, V>>) - Method in class org.apache.flink.hadoopcompatibility.scala.HadoopInputs$
Creates a Flink InputFormat that wraps the given Hadoop FileInputFormat.
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String, TypeInformation<Tuple2<K, V>>) - Method in class org.apache.flink.hadoopcompatibility.scala.HadoopInputs$
Creates a Flink InputFormat that wraps the given Hadoop FileInputFormat.
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String, Job, TypeInformation<Tuple2<K, V>>) - Method in class org.apache.flink.hadoopcompatibility.scala.HadoopInputs$
Creates a Flink InputFormat that wraps the given Hadoop FileInputFormat.
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String, TypeInformation<Tuple2<K, V>>) - Method in class org.apache.flink.hadoopcompatibility.scala.HadoopInputs$
Creates a Flink InputFormat that wraps the given Hadoop FileInputFormat.
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String, JobConf, TypeInformation<Tuple2<K, V>>) - Static method in class org.apache.flink.hadoopcompatibility.scala.HadoopInputs
Creates a Flink InputFormat that wraps the given Hadoop FileInputFormat.
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String, TypeInformation<Tuple2<K, V>>) - Static method in class org.apache.flink.hadoopcompatibility.scala.HadoopInputs
Creates a Flink InputFormat that wraps the given Hadoop FileInputFormat.
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String, Job, TypeInformation<Tuple2<K, V>>) - Static method in class org.apache.flink.hadoopcompatibility.scala.HadoopInputs
Creates a Flink InputFormat that wraps the given Hadoop FileInputFormat.
readHadoopFile(FileInputFormat<K, V>, Class<K>, Class<V>, String, TypeInformation<Tuple2<K, V>>) - Static method in class org.apache.flink.hadoopcompatibility.scala.HadoopInputs
Creates a Flink InputFormat that wraps the given Hadoop FileInputFormat.
readIndex() - Method in class org.apache.flink.api.avro.DataInputDecoder
 
readIndex() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
ReadingThread(ExceptionHandler<IOException>, MutableObjectIterator<E>, UnilateralSortMerger.CircularQueues<E>, LargeRecordHandler<E>, E, AbstractInvokable, long) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ReadingThread
Creates a new reading thread.
readInt() - Method in class org.apache.flink.api.avro.DataInputDecoder
 
readInt() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
readInt() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
 
readInt() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
 
readInto(Buffer) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileReader
 
readInto(Buffer) - Method in interface org.apache.flink.runtime.io.disk.iomanager.BufferFileReader
 
readInto(Buffer) - Method in class org.apache.flink.runtime.io.disk.iomanager.SynchronousBufferFileReader
 
readIntoAndCopyNullMask(int, DataInputView, DataOutputView, boolean[]) - Static method in class org.apache.flink.api.java.typeutils.runtime.NullMaskUtils
 
readIntoNullMask(int, DataInputView, boolean[]) - Static method in class org.apache.flink.api.java.typeutils.runtime.NullMaskUtils
 
readKeyWithGroupAndNamespace(ByteArrayInputStreamWithPos, DataInputView) - Method in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
 
readLibSVM(ExecutionEnvironment, String) - Method in class org.apache.flink.ml.MLUtils$
Reads a file in libSVM/SVMLight format and converts the data into a data set of LabeledVector.
readLibSVM(ExecutionEnvironment, String) - Static method in class org.apache.flink.ml.MLUtils
Reads a file in libSVM/SVMLight format and converts the data into a data set of LabeledVector.
readLine() - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
readLine() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
 
readLine() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
 
readLong() - Method in class org.apache.flink.api.avro.DataInputDecoder
 
readLong() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
readLong() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
 
readLong() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
 
readMapStart() - Method in class org.apache.flink.api.avro.DataInputDecoder
 
readMapStart() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
readNull() - Method in class org.apache.flink.api.avro.DataInputDecoder
 
readNull() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
readNullableString(DataInputView) - Static method in class org.apache.flink.util.StringUtils
Reads a String from the given input.
readObjectFromConfig(Configuration, String, ClassLoader) - Static method in class org.apache.flink.util.InstantiationUtil
 
readParametersFromConfig(Configuration, ClassLoader) - Method in interface org.apache.flink.api.common.typeutils.TypeComparatorFactory
 
readParametersFromConfig(Configuration, ClassLoader) - Method in interface org.apache.flink.api.common.typeutils.TypeSerializerFactory
 
readParametersFromConfig(Configuration, ClassLoader) - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeComparatorFactory
 
readParametersFromConfig(Configuration, ClassLoader) - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
 
readPhase - Variable in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
readRecord(OT, byte[], int, int) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
This function parses the given byte array which represents a serialized record.
readRecord(OUT, byte[], int, int) - Method in class org.apache.flink.api.java.io.CsvInputFormat
 
readRecord(OT, byte[], int, int) - Method in class org.apache.flink.api.java.io.PrimitiveInputFormat
 
readRecord(String, byte[], int, int) - Method in class org.apache.flink.api.java.io.TextInputFormat
 
readRecord(StringValue, byte[], int, int) - Method in class org.apache.flink.api.java.io.TextValueInputFormat
 
readRecord(Tweet, byte[], int, int) - Method in class org.apache.flink.contrib.tweetinputformat.io.SimpleTweetInputFormat
 
readRecordAt(long, T) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
 
readRecordAt(long) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
 
readResolve() - Method in class org.apache.flink.runtime.messages.Acknowledge
Read resolve to preserve the singleton object property.
readResolve() - Static method in class org.apache.flink.table.expressions.TimeIntervalUnit
 
readResolve() - Static method in class org.apache.flink.table.expressions.TimePointUnit
 
readResolve() - Static method in class org.apache.flink.table.expressions.TrimMode
 
readResolve() - Static method in class org.apache.flink.table.plan.nodes.datastream.AccMode
 
readSequenceFile(Class<K>, Class<V>, String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
Please use org.apache.flink.hadoopcompatibility.HadoopInputs#readSequenceFile(Class, Class, String) from the flink-hadoop-compatibility module.
readSequenceFile(Class<K>, Class<V>, String, TypeInformation<Tuple2<K, V>>) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
readSequenceFile(Class<K>, Class<V>, String) - Static method in class org.apache.flink.hadoopcompatibility.HadoopInputs
Creates a Flink InputFormat to read a Hadoop sequence file for the given key and value classes.
readSequenceFile(Class<K>, Class<V>, String, TypeInformation<Tuple2<K, V>>) - Method in class org.apache.flink.hadoopcompatibility.scala.HadoopInputs$
Creates a Flink InputFormat that reads a Hadoop sequence file with the given key and value classes.
readSequenceFile(Class<K>, Class<V>, String, TypeInformation<Tuple2<K, V>>) - Static method in class org.apache.flink.hadoopcompatibility.scala.HadoopInputs
Creates a Flink InputFormat that reads a Hadoop sequence file with the given key and value classes.
readSerializerConfigSnapshot(DataInputView, ClassLoader) - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
readSerializerConfigSnapshots(DataInputView, ClassLoader) - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
readSerializersAndConfigsWithResilience(DataInputView, ClassLoader) - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
Reads from a data input view a list of serializers and their corresponding config snapshots written using TypeSerializerSerializationUtil.writeSerializersAndConfigsWithResilience(DataOutputView, List).
readShort() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
 
readShort() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
 
readSingleForwardAnnotations(Class<?>) - Static method in class org.apache.flink.api.java.functions.FunctionAnnotation
Reads the annotations of a user defined function with one input and returns semantic properties according to the forwarded fields annotated.
readStateMetaInfo(DataInputView) - Method in interface org.apache.flink.runtime.state.KeyedBackendStateMetaInfoSnapshotReaderWriters.KeyedBackendStateMetaInfoReader
 
readStateMetaInfo(DataInputView) - Method in interface org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoReader
 
readStateMetaInfo(DataInputView) - Method in class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoReaderV1
 
readStateMetaInfo(DataInputView) - Method in class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoReaderV2
 
readString(Utf8) - Method in class org.apache.flink.api.avro.DataInputDecoder
 
readString() - Method in class org.apache.flink.api.avro.DataInputDecoder
 
readString(Utf8) - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
readString() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
readString(DataInput) - Static method in class org.apache.flink.types.StringValue
 
readString(DataInputView) - Static method in class org.apache.flink.util.StringUtils
Reads a non-null String from the given input.
readStubAnnotations() - Method in class org.apache.flink.optimizer.dag.AbstractPartialSolutionNode
 
readStubAnnotations() - Method in class org.apache.flink.optimizer.dag.BinaryUnionNode
 
readStubAnnotations() - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
 
readStubAnnotations() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
Reads all stub annotations, i.e.
readStubAnnotations() - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
 
readTextFile(String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a DataSet that represents the Strings produced by reading the given file line wise.
readTextFile(String, String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a DataSet that represents the Strings produced by reading the given file line wise.
readTextFile(String, String) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Creates a DataSet of Strings produced by reading the given file line wise.
readTextFile(String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Reads the given file line-by-line and creates a data stream that contains a string with the contents of each such line.
readTextFile(String, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Reads the given file line-by-line and creates a data stream that contains a string with the contents of each such line.
readTextFile(String) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Creates a DataStream that represents the Strings produced by reading the given file line wise.
readTextFile(String, String) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Creates a data stream that represents the Strings produced by reading the given file line wise.
readTextFileWithValue(String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a DataSet that represents the Strings produced by reading the given file line wise.
readTextFileWithValue(String, String, boolean) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Creates a DataSet that represents the Strings produced by reading the given file line wise.
readTextFileWithValue(String, String) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Creates a DataSet of Strings produced by reading the given file line wise.
readUniqueFieldsAnnotation() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
readUnsignedByte() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
 
readUnsignedByte() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
 
readUnsignedShort() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
 
readUnsignedShort() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
 
readUTF() - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
 
readUTF() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
 
readVarLongCount(DataInput) - Static method in class org.apache.flink.api.avro.DataInputDecoder
 
readVarLongCount(DataInput) - Static method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
readWithKeyDenormalization(BooleanValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
readWithKeyDenormalization(ByteValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
readWithKeyDenormalization(CharValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
readWithKeyDenormalization(DoubleValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
readWithKeyDenormalization(FloatValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
readWithKeyDenormalization(IntValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
readWithKeyDenormalization(LongValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
readWithKeyDenormalization(NullValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
readWithKeyDenormalization(ShortValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
readWithKeyDenormalization(StringValue, DataInputView) - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Reads the record back while de-normalizing the key fields.
readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
readWithKeyDenormalization(Row, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
 
readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
readWithKeyDenormalization(T, DataInputView) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
 
readWithKeyDenormalization(Enumeration.Value, DataInputView) - Method in class org.apache.flink.api.scala.typeutils.EnumValueComparator
 
readWithKeyDenormalization(Option<A>, DataInputView) - Method in class org.apache.flink.api.scala.typeutils.OptionTypeComparator
 
readWithKeyDenormalization(IntValueArray, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
 
readWithKeyDenormalization(LongValueArray, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
 
readWithKeyDenormalization(NullValueArray, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
 
readWithKeyDenormalization(StringValueArray, DataInputView) - Method in class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
 
readWithKeyDenormalization(CRow, DataInputView) - Method in class org.apache.flink.table.runtime.types.CRowComparator
 
reason() - Method in class org.apache.flink.runtime.messages.RegistrationMessages.RefuseRegistration
 
rebalance() - Method in class org.apache.flink.api.java.DataSet
Enforces a re-balancing of the DataSet, i.e., the DataSet is evenly distributed over all parallel instances of the following task.
rebalance() - Static method in class org.apache.flink.api.scala.CrossDataSet
 
rebalance() - Method in class org.apache.flink.api.scala.DataSet
Enforces a re-balancing of the DataSet, i.e., the DataSet is evenly distributed over all parallel instances of the following task.
rebalance(String, RebalanceOptions) - Method in class org.apache.flink.storm.api.FlinkLocalCluster
 
rebalance() - Method in class org.apache.flink.streaming.api.datastream.DataStream
Sets the partitioning of the DataStream so that the output elements are distributed evenly to instances of the next operation in a round-robin fashion.
rebalance() - Method in class org.apache.flink.streaming.api.scala.DataStream
Sets the partitioning of the DataStream so that the output tuples are distributed evenly to the next component.
RebalancePartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
Partitioner that distributes the data equally by cycling through the output channels.
RebalancePartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
 
receive() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
receive() - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
receive() - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
receive() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
receive() - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
receive() - Method in class org.apache.flink.mesos.scheduler.Tasks
 
receive() - Method in interface org.apache.flink.runtime.FlinkActor
 
receive() - Static method in class org.apache.flink.runtime.jobmanager.JobManager
 
receive() - Method in interface org.apache.flink.runtime.LeaderSessionMessageFilter
 
receive() - Method in interface org.apache.flink.runtime.LogMessages
 
receive() - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
 
receive() - Static method in class org.apache.flink.yarn.ApplicationClient
 
receive() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
receiveAcknowledgeMessage(AcknowledgeCheckpoint) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Receives an AcknowledgeCheckpoint message and returns whether the message was associated with a pending checkpoint.
receiveDeclineMessage(DeclineCheckpoint) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Receives a DeclineCheckpoint message for a pending checkpoint.
receiveHeartbeat(ResourceID, I) - Method in class org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
 
receiveHeartbeat(ResourceID, I) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatTarget
Sends a heartbeat response to the target.
receiver - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
receiver - Variable in class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
 
recomputeDigest() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
recomputeDigest() - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
recomputeDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
recomputeDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
recomputeDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
recomputeDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
recomputeDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
recomputeDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
recomputeDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
recomputeDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
recomputeDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
recomputeDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
recomputeDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
recomputeDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
recomputeDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
recomputeDigest() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
Reconcile(Seq<Protos.TaskStatus>, boolean) - Constructor for class org.apache.flink.mesos.scheduler.ReconciliationCoordinator.Reconcile
 
Reconcile$() - Constructor for class org.apache.flink.mesos.scheduler.ReconciliationCoordinator.Reconcile$
 
RECONCILIATION_MAX_BACKOFF() - Method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator$
 
RECONCILIATION_MAX_BACKOFF() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
RECONCILIATION_MIN_BACKOFF() - Method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator$
 
RECONCILIATION_MIN_BACKOFF() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
ReconciliationCoordinator - Class in org.apache.flink.mesos.scheduler
Coordinates task reconciliation between Mesos and the scheduler.
ReconciliationCoordinator(Configuration, SchedulerDriver) - Constructor for class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
ReconciliationCoordinator$ - Class in org.apache.flink.mesos.scheduler
 
ReconciliationCoordinator$() - Constructor for class org.apache.flink.mesos.scheduler.ReconciliationCoordinator$
 
ReconciliationCoordinator.Idle$ - Class in org.apache.flink.mesos.scheduler
The state of idling when reconciliation is not underway.
ReconciliationCoordinator.Reconcile - Class in org.apache.flink.mesos.scheduler
Initiates the task reconciliation process.
ReconciliationCoordinator.Reconcile$ - Class in org.apache.flink.mesos.scheduler
 
ReconciliationCoordinator.ReconciliationData - Class in org.apache.flink.mesos.scheduler
The state data of the reconciliation coordinator.
ReconciliationCoordinator.ReconciliationData$ - Class in org.apache.flink.mesos.scheduler
 
ReconciliationCoordinator.Reconciling$ - Class in org.apache.flink.mesos.scheduler
The state of active reconciliation.
ReconciliationCoordinator.Suspended$ - Class in org.apache.flink.mesos.scheduler
The state of being disconnected from Mesos.
ReconciliationCoordinator.TaskState - Interface in org.apache.flink.mesos.scheduler
An abstract FSM state.
ReconciliationData(Map<Protos.TaskID, Protos.TaskStatus>, int) - Constructor for class org.apache.flink.mesos.scheduler.ReconciliationCoordinator.ReconciliationData
 
ReconciliationData$() - Constructor for class org.apache.flink.mesos.scheduler.ReconciliationCoordinator.ReconciliationData$
 
Reconciling$() - Constructor for class org.apache.flink.mesos.scheduler.ReconciliationCoordinator.Reconciling$
 
Reconciling$() - Constructor for class org.apache.flink.mesos.scheduler.TaskMonitor.Reconciling$
 
ReconnectResourceManager - Class in org.apache.flink.runtime.clusterframework.messages
This message signals that the ResourceManager should reconnect to the JobManager.
ReconnectResourceManager(ActorRef, long) - Constructor for class org.apache.flink.runtime.clusterframework.messages.ReconnectResourceManager
 
Record - Class in org.apache.flink.types
The Record represents a multi-valued data record.
Record() - Constructor for class org.apache.flink.types.Record
Required nullary constructor for instantiation by serialization logic.
Record(Value) - Constructor for class org.apache.flink.types.Record
Creates a new record containing only a single field, which is the given value.
Record(Value, Value) - Constructor for class org.apache.flink.types.Record
Creates a new record containing exactly two fields, which are the given values.
Record(int) - Constructor for class org.apache.flink.types.Record
Creates a new record, containing the given number of fields.
RECORD_DELIMITER - Static variable in class org.apache.flink.api.common.io.DelimitedInputFormat
The configuration key to set the record delimiter.
RecordDeserializer<T extends IOReadableWritable> - Interface in org.apache.flink.runtime.io.network.api.serialization
Interface for turning sequences of memory segments into records.
RecordDeserializer.DeserializationResult - Enum in org.apache.flink.runtime.io.network.api.serialization
 
recordReader - Variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
RecordReader<T extends IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.reader
 
RecordReader(InputGate, Class<T>, String[]) - Constructor for class org.apache.flink.runtime.io.network.api.reader.RecordReader
Creates a new RecordReader that de-serializes records from the given input gate and can spill partial records to disk, if they grow large.
RecordSerializer<T extends IOReadableWritable> - Interface in org.apache.flink.runtime.io.network.api.serialization
Interface for turning records into sequences of memory segments.
RecordSerializer.SerializationResult - Enum in org.apache.flink.runtime.io.network.api.serialization
 
recordSize() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
recordSize() - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
Gets the size of each record, the number of bytes separating the head of successive records.
recordSize() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
recordsPerSegment() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
recordsPerSegment() - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
Gets the number of elements in each memory segment.
recordsPerSegment() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
recordWriter - Variable in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormatBase
 
recordWriter - Variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
 
RecordWriter<T extends IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.writer
A record-oriented runtime result writer.
RecordWriter(ResultPartitionWriter) - Constructor for class org.apache.flink.runtime.io.network.api.writer.RecordWriter
 
RecordWriter(ResultPartitionWriter, ChannelSelector<T>) - Constructor for class org.apache.flink.runtime.io.network.api.writer.RecordWriter
 
RecordWriterOutput<OUT> - Class in org.apache.flink.streaming.runtime.io
Implementation of Output that sends data using a RecordWriter.
RecordWriterOutput(StreamRecordWriter<SerializationDelegate<StreamRecord<OUT>>>, TypeSerializer<OUT>, OutputTag, StreamStatusProvider) - Constructor for class org.apache.flink.streaming.runtime.io.RecordWriterOutput
 
recover() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
Recover available CompletedCheckpoint instances.
recover() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
 
recover() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
Gets the latest checkpoint from ZooKeeper and removes all others.
RecoverAllJobs$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RecoverAllJobs$
 
RecoverJob(JobID) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RecoverJob
 
RecoverJob$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RecoverJob$
 
recoverJobGraph(JobID) - Method in class org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
 
recoverJobGraph(JobID) - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
Returns the SubmittedJobGraph with the given JobID.
recoverJobGraph(JobID) - Method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
 
RecoverSubmittedJob(SubmittedJobGraph) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RecoverSubmittedJob
 
RecoverSubmittedJob$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RecoverSubmittedJob$
 
recoverWorkers() - Method in interface org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore
Recover the stored workers.
recoverWorkers() - Method in class org.apache.flink.mesos.runtime.clusterframework.store.StandaloneMesosWorkerStore
 
recoverWorkers() - Method in class org.apache.flink.mesos.runtime.clusterframework.store.ZooKeeperMesosWorkerStore
 
RECOVERY_JOB_DELAY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Deprecated in favour of ConfigConstants.HA_JOB_DELAY.
RECOVERY_JOB_MANAGER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Deprecated in favour of ConfigConstants.HA_JOB_MANAGER_PORT.
RECOVERY_MODE - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Deprecated in favour of ConfigConstants.HA_MODE.
recursionLevel - Variable in class org.apache.flink.runtime.operators.hash.HashPartition
 
RecursiveDescriptor(int, scala.reflect.macros.Context.universe, int) - Constructor for class org.apache.flink.api.scala.codegen.TypeDescriptors.RecursiveDescriptor
 
recursivelyRegisterType(TypeInformation<?>, ExecutionConfig, Set<Class<?>>) - Static method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers
 
recursivelyRegisterType(Class<?>, ExecutionConfig, Set<Class<?>>) - Static method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers
 
recycle() - Method in class org.apache.flink.runtime.io.network.buffer.Buffer
 
recycle(MemorySegment) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferRecycler
Recycles the MemorySegment to its original BufferPool instance.
recycle(MemorySegment) - Method in class org.apache.flink.runtime.io.network.buffer.FreeingBufferRecycler
Frees the given memory segment.
recycle(MemorySegment) - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
reduce(Iterable<T>, Collector<O>) - Method in interface org.apache.flink.api.common.functions.GroupReduceFunction
The reduce method.
reduce(T, T) - Method in interface org.apache.flink.api.common.functions.ReduceFunction
The core method of ReduceFunction, combining two values into one value of the same type.
reduce(Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.api.common.functions.RichGroupReduceFunction
 
reduce(T, T) - Method in class org.apache.flink.api.common.functions.RichReduceFunction
 
reduce(ReduceFunction<T>) - Method in class org.apache.flink.api.java.DataSet
Applies a Reduce transformation on a non-grouped DataSet.
The transformation consecutively calls a RichReduceFunction until only a single element remains which is the result of the transformation.
reduce(Iterable<T>, Collector<T>) - Method in class org.apache.flink.api.java.functions.FirstReducer
 
reduce(Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.api.java.functions.GroupReduceIterator
 
reduce(Iterable<IntermediateSampleData<T>>, Collector<T>) - Method in class org.apache.flink.api.java.functions.SampleInCoordinator
 
reduce(T, T) - Method in class org.apache.flink.api.java.functions.SelectByMaxFunction
Reduce implementation, returns bigger tuple or value1 if both tuples are equal.
reduce(T, T) - Method in class org.apache.flink.api.java.functions.SelectByMinFunction
Reduce implementation, returns smaller tuple or value1 if both tuples are equal.
reduce(Iterable<T>, Collector<T>) - Method in class org.apache.flink.api.java.operators.AggregateOperator.AggregatingUdf
 
reduce(T, T) - Method in class org.apache.flink.api.java.operators.DistinctOperator.DistinctFunction
 
reduce(Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.CombineToGroupCombineWrapper
 
reduce(Iterable<Tuple2<K, IN>>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingReduceGroupOperator.TupleUnwrappingGroupCombinableGroupReducer
 
reduce(Iterable<Tuple2<K, IN>>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingReduceGroupOperator.TupleUnwrappingNonCombinableGroupReducer
 
reduce(Tuple2<K, T>, Tuple2<K, T>) - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingReduceOperator.ReduceWrapper
 
reduce(Iterable<Tuple3<K1, K2, IN>>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingSortedReduceGroupOperator.TupleUnwrappingGroupCombinableGroupReducer
 
reduce(Iterable<Tuple3<K1, K2, IN>>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingSortedReduceGroupOperator.TupleUnwrappingNonCombinableGroupReducer
 
reduce(Iterable<IN>, Collector<OUT>) - Method in class org.apache.flink.api.java.operators.translation.RichCombineToGroupCombineWrapper
 
reduce(ReduceFunction<T>) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Applies a Reduce transformation on a grouped DataSet.
For each group, the transformation consecutively calls a RichReduceFunction until only a single element for each group remains.
reduce(ReduceFunction<T>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
reduce(Function2<T, T, T>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
reduce(ReduceFunction<T>) - Method in class org.apache.flink.api.scala.DataSet
Creates a new DataSet by merging the elements of this DataSet using an associative reduce function.
reduce(Function2<T, T, T>) - Method in class org.apache.flink.api.scala.DataSet
Creates a new DataSet by merging the elements of this DataSet using an associative reduce function.
reduce(Function2<T, T, T>) - Method in class org.apache.flink.api.scala.GroupedDataSet
Creates a new DataSet by merging the elements of each group (elements with the same key) using an associative reduce function.
reduce(Function2<T, T, T>, ReduceOperatorBase.CombineHint) - Method in class org.apache.flink.api.scala.GroupedDataSet
Special reduce operation for explicitly telling the system what strategy to use for the combine phase.
reduce(ReduceFunction<T>) - Method in class org.apache.flink.api.scala.GroupedDataSet
Creates a new DataSet by merging the elements of each group (elements with the same key) using an associative reduce function.
reduce(ReduceFunction<T>, ReduceOperatorBase.CombineHint) - Method in class org.apache.flink.api.scala.GroupedDataSet
Special reduce operation for explicitly telling the system what strategy to use for the combine phase.
reduce(Iterable<T>, Collector<T>) - Method in class org.apache.flink.api.scala.operators.ScalaAggregateOperator.AggregatingUdf
 
reduce(T, T) - Method in class org.apache.flink.api.scala.SelectByMaxFunction
 
reduce(T, T) - Method in class org.apache.flink.api.scala.SelectByMinFunction
 
reduce(Tuple3<Integer, KMeans.Point, Long>, Tuple3<Integer, KMeans.Point, Long>) - Method in class org.apache.flink.examples.java.clustering.KMeans.CentroidAccumulator
 
reduce(Iterable<Tuple2<Long, Long>>, Collector<Tuple2<Long, Long[]>>) - Method in class org.apache.flink.examples.java.graph.PageRank.BuildOutgoingEdgeList
 
reduce(Long, Long) - Method in class org.apache.flink.examples.java.misc.PiEstimation.SumReducer
 
reduce(Tuple2<LinearRegression.Params, Integer>, Tuple2<LinearRegression.Params, Integer>) - Method in class org.apache.flink.examples.java.ml.LinearRegression.UpdateAccumulator
 
reduce(Iterable<EnumTriangles.Edge>, Collector<EnumTriangles.Triad>) - Method in class org.apache.flink.examples.scala.graph.EnumTriangles.TriadBuilder
 
reduce(Vertex<K, LongValue>, Vertex<K, LongValue>) - Method in class org.apache.flink.graph.asm.degree.annotate.DegreeAnnotationFunctions.DegreeCount
 
reduce(Iterable<Edge<String, Integer>>, Collector<Edge<String, NullValue>>) - Method in class org.apache.flink.graph.examples.MusicProfiles.CreateSimilarUserEdges
 
reduce(Iterable<Tuple2<K, Either<NullValue, Message>>>, Collector<Tuple2<K, Either<NullValue, Message>>>) - Method in class org.apache.flink.graph.pregel.VertexCentricIteration.MessageCombinerUdf
 
reduce(LongValue, LongValue) - Method in class org.apache.flink.graph.utils.GraphUtils.AddLongValue
 
reduce(Iterable<Tuple2<KEYIN, VALUEIN>>, Collector<Tuple2<KEYOUT, VALUEOUT>>) - Method in class org.apache.flink.hadoopcompatibility.mapred.HadoopReduceCombineFunction
 
reduce(Iterable<Tuple2<KEYIN, VALUEIN>>, Collector<Tuple2<KEYOUT, VALUEOUT>>) - Method in class org.apache.flink.hadoopcompatibility.mapred.HadoopReduceFunction
 
reduce(Iterable<IN>, Collector<IN>) - Method in class org.apache.flink.python.api.functions.util.IdentityGroupReduce
 
reduce(ReduceFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies a reduce function to the window.
reduce(ReduceFunction<T>, AllWindowFunction<T, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
reduce(ReduceFunction<T>, AllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
reduce(ReduceFunction<T>, ProcessAllWindowFunction<T, R, W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
reduce(ReduceFunction<T>, ProcessAllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies the given window function to each window.
reduce(ReduceFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Applies a reduce transformation on the grouped data stream grouped on by the given key position.
reduce(ReduceFunction<T>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies a reduce function to the window.
reduce(ReduceFunction<T>, WindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
reduce(ReduceFunction<T>, WindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
reduce(ReduceFunction<T>, ProcessWindowFunction<T, R, K, W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
reduce(ReduceFunction<T>, ProcessWindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies the given window function to each window.
reduce(T, T) - Method in class org.apache.flink.streaming.api.functions.aggregation.ComparableAggregator
 
reduce(T, T) - Method in class org.apache.flink.streaming.api.functions.aggregation.SumAggregator
 
reduce(ReduceFunction<T>) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Applies a reduce function to the window.
reduce(Function2<T, T, T>) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Applies a reduce function to the window.
reduce(ReduceFunction<T>, AllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Applies the given window function to each window.
reduce(Function2<T, T, T>, Function3<W, Iterable<T>, Collector<R>, BoxedUnit>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Applies the given window function to each window.
reduce(ReduceFunction<T>, ProcessAllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Applies the given window function to each window.
reduce(Function2<T, T, T>, ProcessAllWindowFunction<T, R, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Applies the given window function to each window.
reduce(T, T) - Method in class org.apache.flink.streaming.api.scala.function.util.ScalaReduceFunction
 
reduce(ReduceFunction<T>) - Method in class org.apache.flink.streaming.api.scala.KeyedStream
Creates a new DataStream by reducing the elements of this DataStream using an associative reduce function.
reduce(Function2<T, T, T>) - Method in class org.apache.flink.streaming.api.scala.KeyedStream
Creates a new DataStream by reducing the elements of this DataStream using an associative reduce function.
reduce(ReduceFunction<T>) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Applies a reduce function to the window.
reduce(Function2<T, T, T>) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Applies a reduce function to the window.
reduce(ReduceFunction<T>, WindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Applies the given window function to each window.
reduce(Function2<T, T, T>, Function4<K, W, Iterable<T>, Collector<R>, BoxedUnit>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Applies the given window function to each window.
reduce(Function2<T, T, T>, ProcessWindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Applies the given reduce function to each window.
reduce(ReduceFunction<T>, ProcessWindowFunction<T, R, K, W>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Applies the given reduce function to each window.
reduce(Tuple2<Long, Long>, Tuple2<Long, Long>) - Method in class org.apache.flink.streaming.examples.windowing.GroupedProcessingTimeWindowExample.SummingReducer
 
reduce(RexBuilder, List<RexNode>, List<RexNode>) - Method in class org.apache.flink.table.codegen.ExpressionReducer
 
reduce(Iterable<Row>, Collector<Row>) - Method in class org.apache.flink.table.runtime.aggregate.DataSetAggFunction
 
reduce(Iterable<Row>, Collector<Row>) - Method in class org.apache.flink.table.runtime.aggregate.DataSetFinalAggFunction
 
reduce(Iterable<Row>, Collector<Row>) - Method in class org.apache.flink.table.runtime.aggregate.DataSetSessionWindowAggReduceGroupFunction
For grouped intermediate aggregate Rows, divide window according to the window-start and window-end, merge data (within a unified window) into an aggregate buffer, calculate aggregated values output from aggregate buffer, and then set them into output Row based on the mapping relationship between intermediate aggregate data and output data.
reduce(Iterable<Row>, Collector<Row>) - Method in class org.apache.flink.table.runtime.aggregate.DataSetSlideTimeWindowAggReduceGroupFunction
 
reduce(Iterable<Row>, Collector<Row>) - Method in class org.apache.flink.table.runtime.aggregate.DataSetSlideWindowAggReduceGroupFunction
 
reduce(Iterable<Row>, Collector<Row>) - Method in class org.apache.flink.table.runtime.aggregate.DataSetTumbleCountWindowAggReduceGroupFunction
 
reduce(Iterable<Row>, Collector<Row>) - Method in class org.apache.flink.table.runtime.aggregate.DataSetTumbleTimeWindowAggReduceGroupFunction
 
reduce(Row, Row) - Method in class org.apache.flink.table.runtime.aggregate.DistinctReduce
 
reduce(Long, Long) - Method in class org.apache.flink.table.runtime.triggers.StateCleaningCountTrigger.Sum
 
ReduceApplyAllWindowFunction<W extends Window,T,R> - Class in org.apache.flink.streaming.api.functions.windowing
Internal AllWindowFunction that is used for implementing a fold on a window configuration that only allows AllWindowFunction and cannot directly execute a ReduceFunction.
ReduceApplyAllWindowFunction(ReduceFunction<T>, AllWindowFunction<T, R, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceApplyAllWindowFunction
 
ReduceApplyProcessAllWindowFunction<W extends Window,T,R> - Class in org.apache.flink.streaming.api.functions.windowing
Internal ProcessAllWindowFunction that is used for implementing a fold on a window configuration that only allows AllWindowFunction and cannot directly execute a ReduceFunction.
ReduceApplyProcessAllWindowFunction(ReduceFunction<T>, ProcessAllWindowFunction<T, R, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
 
ReduceApplyProcessWindowFunction<K,W extends Window,T,R> - Class in org.apache.flink.streaming.api.functions.windowing
Internal ProcessWindowFunction that is used for implementing a fold on a window configuration that only allows AllWindowFunction and cannot directly execute a ReduceFunction.
ReduceApplyProcessWindowFunction(ReduceFunction<T>, ProcessWindowFunction<T, R, K, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
 
ReduceApplyWindowFunction<K,W extends Window,T,R> - Class in org.apache.flink.streaming.api.functions.windowing
Internal WindowFunction that is used for implementing a fold on a window configuration that only allows WindowFunction and cannot directly execute a ReduceFunction.
ReduceApplyWindowFunction(ReduceFunction<T>, WindowFunction<T, R, K, W>) - Constructor for class org.apache.flink.streaming.api.functions.windowing.ReduceApplyWindowFunction
 
ReduceCombineDriver<T> - Class in org.apache.flink.runtime.operators
Combine operator for Reduce functions, standalone (not chained).
ReduceCombineDriver() - Constructor for class org.apache.flink.runtime.operators.ReduceCombineDriver
 
ReduceDriver<T> - Class in org.apache.flink.runtime.operators
Reduce driver which is executed by a Task Manager.
ReduceDriver() - Constructor for class org.apache.flink.runtime.operators.ReduceDriver
 
reduceEdges(EV, EV) - Method in interface org.apache.flink.graph.ReduceEdgesFunction
It combines two neighboring edge values into one new value of the same type.
ReduceEdgesFunction<EV> - Interface in org.apache.flink.graph
Interface to be implemented by the function applied to a vertex neighborhood in the Graph.reduceOnEdges(org.apache.flink.graph.ReduceEdgesFunction, EdgeDirection) method.
ReduceFacade(ReduceFunction<T>, Collector<T>, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.ReduceFacade
 
ReduceFunction<T> - Interface in org.apache.flink.api.common.functions
Base interface for Reduce functions.
reduceGroup(GroupReduceFunction<T, R>) - Method in class org.apache.flink.api.java.DataSet
Applies a GroupReduce transformation on a non-grouped DataSet.
The transformation calls a RichGroupReduceFunction once with the full DataSet.
reduceGroup(Iterable<IN>) - Method in class org.apache.flink.api.java.functions.GroupReduceIterator
 
reduceGroup(GroupReduceFunction<T, R>) - Method in class org.apache.flink.api.java.operators.SortedGrouping
Applies a GroupReduce transformation on a grouped and sorted DataSet.
The transformation calls a RichGroupReduceFunction for each group of the DataSet.
reduceGroup(GroupReduceFunction<T, R>) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Applies a GroupReduce transformation on a grouped DataSet.
The transformation calls a RichGroupReduceFunction for each group of the DataSet.
reduceGroup(GroupReduceFunction<T, R>, TypeInformation<R>, ClassTag<R>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
reduceGroup(Function2<Iterator<T>, Collector<R>, BoxedUnit>, TypeInformation<R>, ClassTag<R>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
reduceGroup(Function1<Iterator<T>, R>, TypeInformation<R>, ClassTag<R>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
reduceGroup(GroupReduceFunction<T, R>, TypeInformation<R>, ClassTag<R>) - Method in class org.apache.flink.api.scala.DataSet
Creates a new DataSet by passing all elements in this DataSet to the group reduce function.
reduceGroup(Function2<Iterator<T>, Collector<R>, BoxedUnit>, TypeInformation<R>, ClassTag<R>) - Method in class org.apache.flink.api.scala.DataSet
Creates a new DataSet by passing all elements in this DataSet to the group reduce function.
reduceGroup(Function1<Iterator<T>, R>, TypeInformation<R>, ClassTag<R>) - Method in class org.apache.flink.api.scala.DataSet
Creates a new DataSet by passing all elements in this DataSet to the group reduce function.
reduceGroup(Function1<Iterator<T>, R>, TypeInformation<R>, ClassTag<R>) - Method in class org.apache.flink.api.scala.GroupedDataSet
Creates a new DataSet by passing for each group (elements with the same key) the list of elements to the group reduce function.
reduceGroup(Function2<Iterator<T>, Collector<R>, BoxedUnit>, TypeInformation<R>, ClassTag<R>) - Method in class org.apache.flink.api.scala.GroupedDataSet
Creates a new DataSet by passing for each group (elements with the same key) the list of elements to the group reduce function.
reduceGroup(GroupReduceFunction<T, R>, TypeInformation<R>, ClassTag<R>) - Method in class org.apache.flink.api.scala.GroupedDataSet
Creates a new DataSet by passing for each group (elements with the same key) the list of elements to the GroupReduceFunction.
reduceGroupWith(Function1<Stream<T>, R>, TypeInformation<R>, ClassTag<R>) - Method in class org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions.OnDataSet
Applies a reducer fun to a grouped data set
reduceGroupWith(Function1<Stream<T>, R>, TypeInformation<R>, ClassTag<R>) - Method in class org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions.OnGroupedDataSet
Reduces the data set group-wise with a reducer fun
reduceNeighbors(VV, VV) - Method in interface org.apache.flink.graph.ReduceNeighborsFunction
It combines two neighboring vertex values into one new value of the same type.
ReduceNeighborsFunction<VV> - Interface in org.apache.flink.graph
Interface to be implemented by the function applied to a vertex neighborhood in the Graph.reduceOnNeighbors(ReduceNeighborsFunction, EdgeDirection) method.
ReduceNode - Class in org.apache.flink.optimizer.dag
The Optimizer representation of a Reduce operator.
ReduceNode(ReduceOperatorBase<?, ?>) - Constructor for class org.apache.flink.optimizer.dag.ReduceNode
 
ReduceNode(ReduceNode) - Constructor for class org.apache.flink.optimizer.dag.ReduceNode
 
reduceOnEdges(ReduceEdgesFunction<EV>, EdgeDirection) - Method in class org.apache.flink.graph.Graph
Compute a reduce transformation over the edge values of each vertex.
reduceOnEdges(ReduceEdgesFunction<EV>, EdgeDirection) - Method in class org.apache.flink.graph.scala.Graph
Compute a reduce transformation over the neighbors' vertex values of each vertex.
reduceOnNeighbors(ReduceNeighborsFunction<VV>, EdgeDirection) - Method in class org.apache.flink.graph.Graph
Compute a reduce transformation over the neighbors' vertex values of each vertex.
reduceOnNeighbors(ReduceNeighborsFunction<VV>, EdgeDirection) - Method in class org.apache.flink.graph.scala.Graph
Compute a reduce transformation over the neighbors' vertex values of each vertex.
ReduceOperator<IN> - Class in org.apache.flink.api.java.operators
This operator represents the application of a "reduce" function on a data set, and the result data set produced by the function.
ReduceOperator(DataSet<IN>, ReduceFunction<IN>, String) - Constructor for class org.apache.flink.api.java.operators.ReduceOperator
This is the case for a reduce-all case (in contrast to the reduce-per-group case).
ReduceOperator(Grouping<IN>, ReduceFunction<IN>, String) - Constructor for class org.apache.flink.api.java.operators.ReduceOperator
 
ReduceOperatorBase<T,FT extends ReduceFunction<T>> - Class in org.apache.flink.api.common.operators.base
Base data flow operator for Reduce user-defined functions.
ReduceOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<T, T>, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.ReduceOperatorBase
Creates a grouped reduce data flow operator.
ReduceOperatorBase(FT, UnaryOperatorInformation<T, T>, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.ReduceOperatorBase
Creates a grouped reduce data flow operator.
ReduceOperatorBase(Class<? extends FT>, UnaryOperatorInformation<T, T>, int[], String) - Constructor for class org.apache.flink.api.common.operators.base.ReduceOperatorBase
Creates a grouped reduce data flow operator.
ReduceOperatorBase(UserCodeWrapper<FT>, UnaryOperatorInformation<T, T>, String) - Constructor for class org.apache.flink.api.common.operators.base.ReduceOperatorBase
Creates a non-grouped reduce data flow operator (all-reduce).
ReduceOperatorBase(FT, UnaryOperatorInformation<T, T>, String) - Constructor for class org.apache.flink.api.common.operators.base.ReduceOperatorBase
Creates a non-grouped reduce data flow operator (all-reduce).
ReduceOperatorBase(Class<? extends FT>, UnaryOperatorInformation<T, T>, String) - Constructor for class org.apache.flink.api.common.operators.base.ReduceOperatorBase
Creates a non-grouped reduce data flow operator (all-reduce).
ReduceOperatorBase.CombineHint - Enum in org.apache.flink.api.common.operators.base
An enumeration of hints, optionally usable to tell the system exactly how to execute the combiner phase of a reduce.
ReduceProperties - Class in org.apache.flink.optimizer.operators
 
ReduceProperties(FieldSet, DriverStrategy) - Constructor for class org.apache.flink.optimizer.operators.ReduceProperties
 
ReduceProperties(FieldSet, Partitioner<?>, DriverStrategy) - Constructor for class org.apache.flink.optimizer.operators.ReduceProperties
 
reduceWith(Function2<T, T, T>) - Method in class org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions.OnDataSet
Applies a reducer fun to the data set
reduceWith(Function2<T, T, T>) - Method in class org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions.OnGroupedDataSet
Reduces the whole data set with a reducer fun
reduceWith(Function2<T, T, T>) - Method in class org.apache.flink.streaming.api.scala.extensions.impl.acceptPartialFunctions.OnKeyedStream
Applies a reducer fun to the stream
reduceWith(Function2<T, T, T>) - Method in class org.apache.flink.streaming.api.scala.extensions.impl.acceptPartialFunctions.OnWindowedStream
Applies a reduce function to the window.
ReducingState<T> - Interface in org.apache.flink.api.common.state
State interface for reducing state.
ReducingStateDescriptor<T> - Class in org.apache.flink.api.common.state
ReducingStateDescriptor(String, ReduceFunction<T>, Class<T>) - Constructor for class org.apache.flink.api.common.state.ReducingStateDescriptor
Creates a new ReducingStateDescriptor with the given name, type, and default value.
ReducingStateDescriptor(String, ReduceFunction<T>, TypeInformation<T>) - Constructor for class org.apache.flink.api.common.state.ReducingStateDescriptor
Creates a new ReducingStateDescriptor with the given name and default value.
ReducingStateDescriptor(String, ReduceFunction<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.api.common.state.ReducingStateDescriptor
Creates a new ValueStateDescriptor with the given name and default value.
reference - Variable in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
RefFieldAccessorVisitor - Class in org.apache.flink.table.plan.util
A RexVisitor to extract used nested input fields
RefFieldAccessorVisitor(int[]) - Constructor for class org.apache.flink.table.plan.util.RefFieldAccessorVisitor
 
refId() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.RecursiveDescriptor
 
ReflectionUtil - Class in org.apache.flink.util
 
ReflectionUtil.FullTypeInfo - Class in org.apache.flink.util
Container for the full type information of a type.
reflectiveFieldReadAccess(String, Field, String) - Method in class org.apache.flink.table.codegen.CodeGenUtils$
 
reflectiveFieldReadAccess(String, Field, String) - Static method in class org.apache.flink.table.codegen.CodeGenUtils
 
reflectiveFieldWriteAccess(String, Field, String, String) - Method in class org.apache.flink.table.codegen.CodeGenUtils$
 
reflectiveFieldWriteAccess(String, Field, String, String) - Static method in class org.apache.flink.table.codegen.CodeGenUtils
 
refresh() - Method in class org.apache.flink.runtime.security.DynamicConfiguration
 
RefuseRegistration(Throwable) - Constructor for class org.apache.flink.runtime.messages.RegistrationMessages.RefuseRegistration
 
RefuseRegistration$() - Constructor for class org.apache.flink.runtime.messages.RegistrationMessages.RefuseRegistration$
 
regex(Regex) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
register(RelNode, JoinRelType) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
 
register(RelNode, JoinRelType, List<RexNode>) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
Registers a relational expression.
register(Metric, String, AbstractMetricGroup) - Method in class org.apache.flink.runtime.metrics.MetricRegistry
Registers a new Metric with this registry.
register(Logger) - Static method in class org.apache.flink.runtime.util.SignalHandler
Register some signal handlers.
register(RelOptPlanner) - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
register(RelOptPlanner) - Method in class org.apache.flink.table.plan.nodes.datastream.AccModeTrait
 
register(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
register(RelOptPlanner) - Method in class org.apache.flink.table.plan.nodes.datastream.UpdateAsRetractionTrait
 
register(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
register(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
register(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
register(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
register(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
register(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
register(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
register(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
register(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
register(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
register(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
register(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
register(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
register(RelOptPlanner) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
registerAggregateFunctionInternal(String, AggregateFunction<T, ACC>, TypeInformation<T>) - Method in class org.apache.flink.table.api.TableEnvironment
Registers an AggregateFunction under a unique name.
registerAggregationConvergenceCriterion(String, Aggregator<T>, ConvergenceCriterion<T>) - Method in class org.apache.flink.api.common.aggregators.AggregatorRegistry
 
registerAggregationConvergenceCriterion(String, Aggregator<X>, ConvergenceCriterion<X>) - Method in class org.apache.flink.api.java.operators.DeltaIteration
Registers an Aggregator for the iteration together with a ConvergenceCriterion.
registerAggregationConvergenceCriterion(String, Aggregator<X>, ConvergenceCriterion<X>) - Method in class org.apache.flink.api.java.operators.IterativeDataSet
Registers an Aggregator for the iteration together with a ConvergenceCriterion.
registerAggregator(String, Aggregator<?>) - Method in class org.apache.flink.api.common.aggregators.AggregatorRegistry
 
registerAggregator(String, Aggregator<?>) - Method in class org.apache.flink.api.java.operators.DeltaIteration
Registers an Aggregator for the iteration.
registerAggregator(String, Aggregator<?>) - Method in class org.apache.flink.api.java.operators.IterativeDataSet
Registers an Aggregator for the iteration.
registerAggregator(String, Aggregator<?>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
registerAggregator(String, Aggregator<?>) - Method in class org.apache.flink.api.scala.DataSet
Registers an Aggregator for the iteration.
registerAggregator(String, Aggregator<?>) - Method in class org.apache.flink.graph.IterationConfiguration
Registers a new aggregator.
registerAll(Iterable<? extends CompositeStateHandle>) - Method in class org.apache.flink.runtime.state.SharedStateRegistry
Register given shared states in the registry.
registerAllRequestsProcessedListener(NotificationListener) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileWriter
 
registerAllRequestsProcessedListener(NotificationListener) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
Registers a listener to be notified when all outstanding requests have been processed.
registerAllRequestsProcessedListener(NotificationListener) - Method in interface org.apache.flink.runtime.io.disk.iomanager.BufferFileWriter
Registers a listener, which is notified after all outstanding requests have been processed.
RegisterApplicationClient$() - Constructor for class org.apache.flink.yarn.YarnMessages.RegisterApplicationClient$
 
registerBufferPool(BufferPool) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
Registers a buffer pool with this result partition.
registerCachedFile(String, DistributedCache.DistributedCacheEntry) - Method in class org.apache.flink.api.common.Plan
register cache files in program level
registerCachedFile(String, String) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Registers a file at the distributed cache under the given name.
registerCachedFile(String, String, boolean) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Registers a file at the distributed cache under the given name.
registerCachedFile(String, String, boolean) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Registers a file at the distributed cache under the given name.
registerCachedFile(String, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Registers a file at the distributed cache under the given name.
registerCachedFile(String, String, boolean) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Registers a file at the distributed cache under the given name.
registerCachedFile(String, String) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Registers a file at the distributed cache under the given name.
registerCachedFile(String, String, boolean) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Registers a file at the distributed cache under the given name.
registerCachedFilesWithPlan(Plan) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Registers all files that were registered at this execution environment's cache registry of the given plan's cache registry.
registerCatalog(SchemaPlus, String, ExternalCatalog) - Method in class org.apache.flink.table.catalog.ExternalCatalogSchema$
Registers an external catalog in a Calcite schema.
registerCatalog(SchemaPlus, String, ExternalCatalog) - Static method in class org.apache.flink.table.catalog.ExternalCatalogSchema
Registers an external catalog in a Calcite schema.
registerChannelToBeRemovedAtShudown(FileIOChannel.ID) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Adds a channel to the list of channels that are to be removed at shutdown.
registerCheckpointEventHandler(StatefulTask) - Method in class org.apache.flink.streaming.runtime.io.BarrierBuffer
 
registerCheckpointEventHandler(StatefulTask) - Method in class org.apache.flink.streaming.runtime.io.BarrierTracker
 
registerCheckpointEventHandler(StatefulTask) - Method in interface org.apache.flink.streaming.runtime.io.CheckpointBarrierHandler
Registers the task be notified once all checkpoint barriers have been received for a checkpoint.
registerCleanupTimer(W) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
Registers a timer to cleanup the content of the window.
registerClosable(C) - Method in class org.apache.flink.util.AbstractCloseableRegistry
Registers a Closeable with the registry.
registerCloseable(Closeable) - Method in class org.apache.flink.migration.runtime.state.AbstractCloseableHandle
Deprecated.
 
registerConsumer() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
 
registerConverterRule(RelOptPlanner, ConverterRule) - Static method in class org.apache.flink.table.plan.nodes.datastream.AccModeTraitDef
 
registerConverterRule(RelOptPlanner, ConverterRule) - Static method in class org.apache.flink.table.plan.nodes.datastream.UpdateAsRetractionTraitDef
 
registerDataSet(String, DataSet<T>) - Method in class org.apache.flink.table.api.java.BatchTableEnvironment
Registers the given DataSet as table in the TableEnvironment's catalog.
registerDataSet(String, DataSet<T>, String) - Method in class org.apache.flink.table.api.java.BatchTableEnvironment
Registers the given DataSet as table with specified field names in the TableEnvironment's catalog.
registerDataSet(String, DataSet<T>) - Method in class org.apache.flink.table.api.scala.BatchTableEnvironment
Registers the given DataSet as table in the TableEnvironment's catalog.
registerDataSet(String, DataSet<T>, Seq<Expression>) - Method in class org.apache.flink.table.api.scala.BatchTableEnvironment
Registers the given DataSet as table with specified field names in the TableEnvironment's catalog.
registerDataSetInternal(String, DataSet<T>) - Method in class org.apache.flink.table.api.BatchTableEnvironment
Registers a DataSet as a table under a given name in the TableEnvironment's catalog.
registerDataSetInternal(String, DataSet<T>, Expression[]) - Method in class org.apache.flink.table.api.BatchTableEnvironment
Registers a DataSet as a table under a given name with field names as specified by field expressions in the TableEnvironment's catalog.
registerDataStream(String, DataStream<T>) - Method in class org.apache.flink.table.api.java.StreamTableEnvironment
Registers the given DataStream as table in the TableEnvironment's catalog.
registerDataStream(String, DataStream<T>, String) - Method in class org.apache.flink.table.api.java.StreamTableEnvironment
Registers the given DataStream as table with specified field names in the TableEnvironment's catalog.
registerDataStream(String, DataStream<T>) - Method in class org.apache.flink.table.api.scala.StreamTableEnvironment
Registers the given DataStream as table in the TableEnvironment's catalog.
registerDataStream(String, DataStream<T>, Seq<Expression>) - Method in class org.apache.flink.table.api.scala.StreamTableEnvironment
Registers the given DataStream as table with specified field names in the TableEnvironment's catalog.
registerDataStreamInternal(String, DataStream<T>) - Method in class org.apache.flink.table.api.StreamTableEnvironment
Registers a DataStream as a table under a given name in the TableEnvironment's catalog.
registerDataStreamInternal(String, DataStream<T>, Expression[]) - Method in class org.apache.flink.table.api.StreamTableEnvironment
Registers a DataStream as a table under a given name with field names as specified by field expressions in the TableEnvironment's catalog.
Registered - Class in org.apache.flink.mesos.scheduler.messages
Message sent by the callback handler to the scheduler actor when the scheduler successfully registers with a Mesos master.
Registered(Protos.FrameworkID, Protos.MasterInfo) - Constructor for class org.apache.flink.mesos.scheduler.messages.Registered
 
registered(SchedulerDriver, Protos.FrameworkID, Protos.MasterInfo) - Method in class org.apache.flink.mesos.scheduler.SchedulerProxy
 
registered() - Method in class org.apache.flink.mesos.scheduler.Tasks
Cache of current connection state.
RegisteredAtJobManager(UUID) - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages.RegisteredAtJobManager
 
RegisteredAtJobManager$() - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages.RegisteredAtJobManager$
 
RegisteredKeyedBackendStateMetaInfo<N,S> - Class in org.apache.flink.runtime.state
Compound meta information for a registered state in a keyed state backend.
RegisteredKeyedBackendStateMetaInfo(StateDescriptor.Type, String, TypeSerializer<N>, TypeSerializer<S>) - Constructor for class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo
 
RegisteredKeyedBackendStateMetaInfo.Snapshot<N,S> - Class in org.apache.flink.runtime.state
A consistent snapshot of a RegisteredKeyedBackendStateMetaInfo.
RegisteredMesosWorkerNode - Class in org.apache.flink.mesos.runtime.clusterframework
A representation of a registered Mesos task managed by the MesosFlinkResourceManager.
RegisteredMesosWorkerNode(MesosWorkerStore.Worker) - Constructor for class org.apache.flink.mesos.runtime.clusterframework.RegisteredMesosWorkerNode
 
RegisteredMesosWorkerNode$ - Class in org.apache.flink.mesos.runtime.clusterframework
 
RegisteredMesosWorkerNode$() - Constructor for class org.apache.flink.mesos.runtime.clusterframework.RegisteredMesosWorkerNode$
 
RegisteredOperatorBackendStateMetaInfo<S> - Class in org.apache.flink.runtime.state
Compound meta information for a registered state in an operator state backend.
RegisteredOperatorBackendStateMetaInfo(String, TypeSerializer<S>, OperatorStateHandle.Mode) - Constructor for class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo
 
RegisteredOperatorBackendStateMetaInfo.Snapshot<S> - Class in org.apache.flink.runtime.state
A consistent snapshot of a RegisteredOperatorBackendStateMetaInfo.
registeredPartitions - Variable in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
 
RegisteredRpcConnection<Gateway extends RpcGateway,Success extends RegistrationResponse.Success> - Class in org.apache.flink.runtime.registration
This utility class implements the basis of RPC connecting from one component to another component, for example the RPC connection from TaskExecutor to ResourceManager.
RegisteredRpcConnection(Logger, String, UUID, Executor) - Constructor for class org.apache.flink.runtime.registration.RegisteredRpcConnection
 
RegisteredTaskManagers(Iterable<Instance>) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RegisteredTaskManagers
 
RegisteredTaskManagers$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RegisteredTaskManagers$
 
RegisteredYarnWorkerNode - Class in org.apache.flink.yarn
A representation of a registered Yarn container managed by the YarnFlinkResourceManager.
RegisteredYarnWorkerNode(Container) - Constructor for class org.apache.flink.yarn.RegisteredYarnWorkerNode
 
registerEventTimeTimer(N, long) - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
 
registerEventTimeTimer(N, long) - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
Registers a timer to be fired when processing time passes the given time.
registerEventTimeTimer(long) - Method in class org.apache.flink.streaming.api.SimpleTimerService
 
registerEventTimeTimer(long) - Method in interface org.apache.flink.streaming.api.TimerService
Registers a timer to be fired when the event time watermark passes the given time.
registerEventTimeTimer(long) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
Register an event-time callback.
registerEventTimeTimer(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
registerExecutionListener(ExecutionStatusListener) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
registerExecutionListener(TaskExecutionStateListener) - Method in class org.apache.flink.runtime.taskmanager.Task
 
registerExternalCatalog(String, ExternalCatalog) - Method in class org.apache.flink.table.api.TableEnvironment
Registers an ExternalCatalog under a unique name in the TableEnvironment's schema.
registerFlinkMLTypes(ExecutionEnvironment) - Method in class org.apache.flink.ml.common.FlinkMLTools$
Registers the different FlinkML related types for Kryo serialization
registerFlinkMLTypes(ExecutionEnvironment) - Static method in class org.apache.flink.ml.common.FlinkMLTools
Registers the different FlinkML related types for Kryo serialization
registerFunction(String, TableFunction<T>) - Method in class org.apache.flink.table.api.java.BatchTableEnvironment
Registers a TableFunction under a unique name in the TableEnvironment's catalog.
registerFunction(String, AggregateFunction<T, ACC>) - Method in class org.apache.flink.table.api.java.BatchTableEnvironment
Registers an AggregateFunction under a unique name in the TableEnvironment's catalog.
registerFunction(String, TableFunction<T>) - Method in class org.apache.flink.table.api.java.StreamTableEnvironment
Registers a TableFunction under a unique name in the TableEnvironment's catalog.
registerFunction(String, AggregateFunction<T, ACC>) - Method in class org.apache.flink.table.api.java.StreamTableEnvironment
Registers an AggregateFunction under a unique name in the TableEnvironment's catalog.
registerFunction(String, TableFunction<T>, TypeInformation<T>) - Method in class org.apache.flink.table.api.scala.BatchTableEnvironment
Registers a TableFunction under a unique name in the TableEnvironment's catalog.
registerFunction(String, AggregateFunction<T, ACC>, TypeInformation<T>) - Method in class org.apache.flink.table.api.scala.BatchTableEnvironment
Registers an AggregateFunction under a unique name in the TableEnvironment's catalog.
registerFunction(String, TableFunction<T>, TypeInformation<T>) - Method in class org.apache.flink.table.api.scala.StreamTableEnvironment
Registers a TableFunction under a unique name in the TableEnvironment's catalog.
registerFunction(String, AggregateFunction<T, ACC>, TypeInformation<T>) - Method in class org.apache.flink.table.api.scala.StreamTableEnvironment
Registers an AggregateFunction under a unique name in the TableEnvironment's catalog.
registerFunction(String, ScalarFunction) - Method in class org.apache.flink.table.api.TableEnvironment
Registers a ScalarFunction under a unique name.
registerFunction(String, Class<?>) - Method in class org.apache.flink.table.validate.FunctionCatalog
 
registerInflaterInputStreamFactory(String, InflaterInputStreamFactory<?>) - Static method in class org.apache.flink.api.common.io.FileInputFormat
Registers a decompression algorithm through a InflaterInputStreamFactory with a file extension for transparent decompression.
RegisterInfoMessageListener - Class in org.apache.flink.runtime.clusterframework.messages
This message signals to the resource master to register the sender as an info message listener.
registerInfoMessageListener(String) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
Registers an info message listener
registerInfoMessageListener(String) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Registers an infoMessage listener
RegisterInfoMessageListenerSuccessful - Class in org.apache.flink.runtime.clusterframework.messages
This message signals to the application client that the registration was successful.
registerJob(JobID, Collection<BlobKey>, Collection<URL>) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
 
registerJob(JobID, Collection<BlobKey>, Collection<URL>) - Method in class org.apache.flink.runtime.execution.librarycache.FallbackLibraryCacheManager
 
registerJob(JobID, Collection<BlobKey>, Collection<URL>) - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
Registers a job with its required jar files and classpaths.
RegisterJobClient(JobID, ListeningBehaviour) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RegisterJobClient
 
RegisterJobClient$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RegisterJobClient$
 
RegisterJobClientSuccess(JobID) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RegisterJobClientSuccess
 
RegisterJobClientSuccess$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RegisterJobClientSuccess$
 
registerJobManager(UUID, UUID, ResourceID, String, JobID) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
registerJobManager(UUID, UUID, ResourceID, String, JobID, Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Register a JobMaster at the resource manager.
registerJobStatusListener(JobStatusListener) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
registerKryoType(Class<?>) - Method in class org.apache.flink.api.common.ExecutionConfig
Registers the given type with the serialization stack.
registerKvState(JobID, JobVertexID, KeyGroupRange, String, InternalKvState<?>) - Method in class org.apache.flink.runtime.query.KvStateRegistry
Registers the KvState instance and returns the assigned ID.
registerKvState(KeyGroupRange, String, InternalKvState<?>) - Method in class org.apache.flink.runtime.query.TaskKvStateRegistry
Registers the KvState instance at the KvStateRegistry.
registerListener(InputGateListener) - Method in interface org.apache.flink.runtime.io.network.partition.consumer.InputGate
 
registerListener(InputGateListener) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
registerListener(InputGateListener) - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
 
registerListener(KvStateRegistryListener) - Method in class org.apache.flink.runtime.query.KvStateRegistry
Registers a listener with the registry.
registerLocalResource(FileSystem, Path, LocalResource) - Static method in class org.apache.flink.yarn.Utils
 
registerMetrics(MetricGroup) - Method in class org.apache.flink.runtime.executiongraph.failover.FailoverStrategy
Tells the FailoverStrategy to register its metrics.
registerMetrics(MetricGroup) - Method in class org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy
 
registerOpenChannelToBeRemovedAtShudown(FileIOChannel) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Adds a channel reader/writer to the list of channels that are to be removed at shutdown.
registerPojoType(Class<?>) - Method in class org.apache.flink.api.common.ExecutionConfig
Registers the given type with the serialization stack.
registerProcessingCleanupTimer(ProcessFunction<IN, OUT>.Context, long) - Method in class org.apache.flink.table.runtime.aggregate.ProcessFunctionWithCleanupState
 
registerProcessingTimeTimer(N, long) - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
 
registerProcessingTimeTimer(N, long) - Method in interface org.apache.flink.streaming.api.operators.InternalTimerService
Registers a timer to be fired when processing time passes the given time.
registerProcessingTimeTimer(long) - Method in class org.apache.flink.streaming.api.SimpleTimerService
 
registerProcessingTimeTimer(long) - Method in interface org.apache.flink.streaming.api.TimerService
Registers a timer to be fired when processing time passes the given time.
registerProcessingTimeTimer(long) - Method in interface org.apache.flink.streaming.api.windowing.triggers.Trigger.TriggerContext
Register a system time callback.
registerProcessingTimeTimer(long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
registerQueueLengthMetrics(MetricGroup, SingleInputGate) - Static method in class org.apache.flink.runtime.io.network.partition.consumer.InputGateMetrics
 
registerQueueLengthMetrics(MetricGroup, ResultPartition) - Static method in class org.apache.flink.runtime.io.network.partition.ResultPartitionMetrics
 
registerReference(SharedStateRegistryKey, StreamStateHandle) - Method in class org.apache.flink.runtime.state.SharedStateRegistry
Register a reference to the given shared state in the registry.
RegisterResourceManager - Class in org.apache.flink.runtime.clusterframework.messages
This message signals that the resource manager wants to register at the JobManager leader.
RegisterResourceManager(ActorRef) - Constructor for class org.apache.flink.runtime.clusterframework.messages.RegisterResourceManager
 
RegisterResourceManagerSuccessful - Class in org.apache.flink.runtime.clusterframework.messages
Message that informs the resource manager that the JobManager accepted its registration.
RegisterResourceManagerSuccessful(ActorRef, Collection<ResourceID>) - Constructor for class org.apache.flink.runtime.clusterframework.messages.RegisterResourceManagerSuccessful
Creates a new message with a list of existing known TaskManagers.
registerRestoredLegacyStateState() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
registerResultPartition(ResultPartition) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
 
registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.checkpoint.OperatorState
 
registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
 
registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
 
registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.checkpoint.TaskState
Deprecated.
 
registerSharedStates(SharedStateRegistry) - Method in interface org.apache.flink.runtime.state.CompositeStateHandle
Register both newly created and already referenced shared states in the given SharedStateRegistry.
registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
 
registerSharedStates(SharedStateRegistry) - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
 
registerSharedStatesAfterRestored(SharedStateRegistry) - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
Register all shared states in the given registry.
registerSlotRequest(SlotRequest) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Requests a slot with the respective resource profile.
registerSqlFunction(SqlFunction) - Method in class org.apache.flink.table.validate.FunctionCatalog
 
registerSqlFunctions(Seq<SqlFunction>) - Method in class org.apache.flink.table.validate.FunctionCatalog
Register multiple SQL functions at the same time.
registerSubSchemas(SchemaPlus) - Method in class org.apache.flink.table.catalog.ExternalCatalogSchema
Registers sub-Schemas to current schema plus
registerTable(String, Table) - Method in class org.apache.flink.table.api.TableEnvironment
Registers a Table under a unique name in the TableEnvironment's catalog.
registerTableFunctionInternal(String, TableFunction<T>, TypeInformation<T>) - Method in class org.apache.flink.table.api.TableEnvironment
Registers a TableFunction under a unique name.
registerTableInternal(String, AbstractTable) - Method in class org.apache.flink.table.api.TableEnvironment
Registers a Calcite AbstractTable in the TableEnvironment's catalog.
registerTableSource(String, TableSource<?>) - Method in class org.apache.flink.table.api.BatchTableEnvironment
Registers an external BatchTableSource in this TableEnvironment's catalog.
registerTableSource(String, TableSource<?>) - Method in class org.apache.flink.table.api.StreamTableEnvironment
Registers an external StreamTableSource in this TableEnvironment's catalog.
registerTableSource(String, TableSource<?>) - Method in class org.apache.flink.table.api.TableEnvironment
Registers an external TableSource in this TableEnvironment's catalog.
registerTask(JobID, ExecutionAttemptID, Collection<BlobKey>, Collection<URL>) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
 
registerTask(JobID, ExecutionAttemptID, Collection<BlobKey>, Collection<URL>) - Method in class org.apache.flink.runtime.execution.librarycache.FallbackLibraryCacheManager
 
registerTask(JobID, ExecutionAttemptID, Collection<BlobKey>, Collection<URL>) - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
Registers a job task execution with its required jar files and classpaths.
registerTask(Task) - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
registerTaskEventListener(EventListener<TaskEvent>, Class<? extends TaskEvent>) - Method in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
 
registerTaskEventListener(EventListener<TaskEvent>, Class<? extends TaskEvent>) - Method in interface org.apache.flink.runtime.io.network.api.reader.ReaderBase
 
registerTaskExecutor(UUID, String, ResourceID, SlotReport) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
Register a TaskExecutor at the resource manager
registerTaskExecutor(UUID, String, ResourceID, SlotReport, Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Register a TaskExecutor at the resource manager.
registerTaskManager(TaskManagerGateway, TaskManagerLocation, HardwareDescription, int) - Method in class org.apache.flink.runtime.instance.InstanceManager
Registers a task manager.
registerTaskManager(ResourceID) - Method in class org.apache.flink.runtime.instance.SlotPool
Register TaskManager to this pool, only those slots come from registered TaskManager will be considered valid.
registerTaskManager(ResourceID) - Method in interface org.apache.flink.runtime.instance.SlotPoolGateway
 
registerTaskManager(String, TaskManagerLocation, UUID) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
registerTaskManager(String, TaskManagerLocation, UUID, Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
Register the task manager at the job manager.
RegisterTaskManager(ResourceID, TaskManagerLocation, HardwareDescription, int) - Constructor for class org.apache.flink.runtime.messages.RegistrationMessages.RegisterTaskManager
 
registerTaskManager(TaskExecutorConnection, SlotReport) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Registers a new task manager at the slot manager.
RegisterTaskManager$() - Constructor for class org.apache.flink.runtime.messages.RegistrationMessages.RegisterTaskManager$
 
registerTimeout(K, long, TimeUnit) - Method in class org.apache.flink.runtime.taskexecutor.slot.TimerService
Register a timeout for the given key which shall occur in the given delay.
registerTimer(long, ProcessingTimeCallback) - Method in class org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
Registers a task to be executed when (processing) time is timestamp.
registerTimer(long, ProcessingTimeCallback) - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
Registers a task to be executed no sooner than time timestamp, but without strong guarantees of order.
registerTimer(long, ProcessingTimeCallback) - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
registerType(Class<?>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Registers the given type with the serialization stack.
registerType(Class<?>) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Registers the given type with the serialization stack.
registerType(Class<?>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Registers the given type with the serialization stack.
registerType(Class<?>) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Registers the given type with the serialization stack.
registerTypeWithKryoSerializer(Class<?>, T) - Method in class org.apache.flink.api.common.ExecutionConfig
Registers the given type with a Kryo Serializer.
registerTypeWithKryoSerializer(Class<?>, Class<? extends Serializer>) - Method in class org.apache.flink.api.common.ExecutionConfig
Registers the given Serializer via its class as a serializer for the given type at the KryoSerializer
registerTypeWithKryoSerializer(Class<?>, T) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Registers the given type with a Kryo Serializer.
registerTypeWithKryoSerializer(Class<?>, Class<? extends Serializer<?>>) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Registers the given Serializer via its class as a serializer for the given type at the KryoSerializer
registerTypeWithKryoSerializer(Class<?>, T) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Registers the given type with the serializer at the KryoSerializer.
registerTypeWithKryoSerializer(Class<?>, Class<? extends Serializer<?>>) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Registers the given type with the serializer at the KryoSerializer.
registerTypeWithKryoSerializer(Class<?>, T) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Registers the given type with a Kryo Serializer.
registerTypeWithKryoSerializer(Class<?>, Class<? extends Serializer>) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Registers the given Serializer via its class as a serializer for the given type at the KryoSerializer.
registerTypeWithKryoSerializer(Class<?>, T) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Registers the given type with the serializer at the KryoSerializer.
registerTypeWithKryoSerializer(Class<?>, Class<? extends Serializer<?>>) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Registers the given type with the serializer at the KryoSerializer.
registerWriterForIncomingTaskEvents(ResultPartitionID, ResultPartitionWriter) - Method in class org.apache.flink.runtime.io.network.TaskEventDispatcher
 
RegistrationConnectionListener<Success extends RegistrationResponse.Success> - Interface in org.apache.flink.runtime.registration
Classes which want to be notified about the registration result by the RegisteredRpcConnection have to implement this interface.
RegistrationMessages - Class in org.apache.flink.runtime.messages
A set of messages between TaskManager and JobManager to handle the registration of the TaskManager at the JobManager.
RegistrationMessages() - Constructor for class org.apache.flink.runtime.messages.RegistrationMessages
 
RegistrationMessages$ - Class in org.apache.flink.runtime.messages
A set of messages between TaskManager and JobManager to handle the registration of the TaskManager at the JobManager.
RegistrationMessages$() - Constructor for class org.apache.flink.runtime.messages.RegistrationMessages$
 
RegistrationMessages.AcknowledgeRegistration - Class in org.apache.flink.runtime.messages
Denotes the successful registration of a task manager at the JobManager.
RegistrationMessages.AcknowledgeRegistration$ - Class in org.apache.flink.runtime.messages
 
RegistrationMessages.AlreadyRegistered - Class in org.apache.flink.runtime.messages
Denotes that the TaskManager has already been registered at the JobManager.
RegistrationMessages.AlreadyRegistered$ - Class in org.apache.flink.runtime.messages
 
RegistrationMessages.RefuseRegistration - Class in org.apache.flink.runtime.messages
Denotes the unsuccessful registration of a task manager at the JobManager.
RegistrationMessages.RefuseRegistration$ - Class in org.apache.flink.runtime.messages
 
RegistrationMessages.RegisterTaskManager - Class in org.apache.flink.runtime.messages
Registers a task manager at the JobManager.
RegistrationMessages.RegisterTaskManager$ - Class in org.apache.flink.runtime.messages
 
RegistrationMessages.RegistrationMessage - Interface in org.apache.flink.runtime.messages
Marker trait for registration messages.
RegistrationMessages.TriggerTaskManagerRegistration - Class in org.apache.flink.runtime.messages
Triggers the TaskManager to attempt a registration at the JobManager.
RegistrationMessages.TriggerTaskManagerRegistration$ - Class in org.apache.flink.runtime.messages
 
RegistrationResponse - Class in org.apache.flink.runtime.registration
Base class for responses given to registration attempts from RetryingRegistration.
RegistrationResponse() - Constructor for class org.apache.flink.runtime.registration.RegistrationResponse
 
RegistrationResponse.Decline - Class in org.apache.flink.runtime.registration
A rejected (declined) registration.
RegistrationResponse.Success - Class in org.apache.flink.runtime.registration
Base class for a successful registration.
registrationRun() - Method in class org.apache.flink.runtime.messages.RegistrationMessages.TriggerTaskManagerRegistration
 
RegistrationTimeout$() - Constructor for class org.apache.flink.runtime.messages.JobClientMessages.RegistrationTimeout$
 
registry - Variable in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
 
registry - Variable in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
The registry that this metrics group belongs to
regLoss(double, Vector, double) - Method in class org.apache.flink.ml.optimization.L1Regularization$
Adds regularization to the loss value
regLoss(double, Vector, double) - Static method in class org.apache.flink.ml.optimization.L1Regularization
Adds regularization to the loss value
regLoss(double, Vector, double) - Method in class org.apache.flink.ml.optimization.L2Regularization$
Adds regularization to the loss value
regLoss(double, Vector, double) - Static method in class org.apache.flink.ml.optimization.L2Regularization
Adds regularization to the loss value
regLoss(double, Vector, double) - Method in class org.apache.flink.ml.optimization.NoRegularization$
Returns the unmodified loss value
regLoss(double, Vector, double) - Static method in class org.apache.flink.ml.optimization.NoRegularization
Returns the unmodified loss value
regLoss(double, Vector, double) - Method in interface org.apache.flink.ml.optimization.RegularizationPenalty
Adds regularization to the loss value
REGR_SXX - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
REGR_SXX aggregate function.
REGR_SYY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
REGR_SYY aggregate function.
Regularization$() - Constructor for class org.apache.flink.ml.classification.SVM.Regularization$
 
RegularizationConstant$() - Constructor for class org.apache.flink.ml.optimization.Solver.RegularizationConstant$
 
RegularizationPenalty - Interface in org.apache.flink.ml.optimization
Represents a type of regularization penalty
RegularizationPenaltyValue$() - Constructor for class org.apache.flink.ml.optimization.Solver.RegularizationPenaltyValue$
 
RegularToMutableObjectIterator<T> - Class in org.apache.flink.runtime.util
 
RegularToMutableObjectIterator(Iterator<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.util.RegularToMutableObjectIterator
 
REINTERPRET - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
An REINTERPRET operator is internal to the planner.
rel(SqlNode) - Method in class org.apache.flink.table.calcite.FlinkPlannerImpl
 
relativeTimeMillis() - Method in class org.apache.flink.runtime.util.clock.Clock
 
relativeTimeMillis() - Method in class org.apache.flink.runtime.util.clock.SystemClock
 
relativeTimeNanos() - Method in class org.apache.flink.runtime.util.clock.Clock
 
relativeTimeNanos() - Method in class org.apache.flink.runtime.util.clock.SystemClock
 
relBuilder() - Method in class org.apache.flink.table.api.Table
 
relBuilder() - Method in class org.apache.flink.table.api.TableEnvironment
 
release(K, V, long, int) - Method in class org.apache.flink.cep.nfa.SharedBuffer
Decreases the reference counter for the given value, key, timestamp entry so that it can be removed once the reference counter reaches 0.
release() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
 
release(Throwable) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
Releases the result partition.
release() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
release(MemorySegment) - Method in class org.apache.flink.runtime.memory.MemoryManager
Tries to release the memory for the specified segment.
release(Collection<MemorySegment>) - Method in class org.apache.flink.runtime.memory.MemoryManager
Tries to release many memory segments together.
release() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTableSnapshot
 
release(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Releases the lock from the node under the given ZooKeeper path.
releaseAll(Object) - Method in class org.apache.flink.runtime.memory.MemoryManager
Releases all memory segments for the given owner.
releaseAll() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Releases all lock nodes of this ZooKeeperStateHandleStore.
releaseAllReferencesFromTask(BatchTask<?, ?>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableManager
 
releaseAllResources() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
releaseAllResources() - Method in interface org.apache.flink.runtime.io.network.partition.ResultSubpartitionView
 
releaseAllSlotsSilently(List<ExecutionAndSlot[]>) - Static method in class org.apache.flink.runtime.executiongraph.ExecutionGraphUtils
Releases the all the slots in the list of arrays of ExecutionAndSlot.
releaseAndTryRemove(String) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Releases the lock for the given state node and tries to remove the state node if it is no longer locked.
releaseAndTryRemove(String, ZooKeeperStateHandleStore.RemoveCallback<T>) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Releases the lock for the given state node and tries to remove the state node if it is no longer locked.
releaseAndTryRemoveAll() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Releases all lock nodes of this ZooKeeperStateHandleStores and tries to remove all state nodes which are not locked anymore.
releaseArrays() - Method in class org.apache.flink.runtime.util.DataInputDeserializer
 
releaseBroadcastVariables(String, int, DistributedRuntimeUDFContext) - Method in class org.apache.flink.runtime.operators.BatchTask
 
Released(Protos.TaskID, Protos.SlaveID) - Constructor for class org.apache.flink.mesos.scheduler.TaskMonitor.Released
 
Released$() - Constructor for class org.apache.flink.mesos.scheduler.TaskMonitor.Released$
 
releaseMemory(int) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPoolOwner
 
releaseMemory(int) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
Releases buffers held by this result partition.
releaseOutputs() - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
This method releases all resources of the record writer output.
releasePartitionsProducedBy(ExecutionAttemptID) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
 
releasePartitionsProducedBy(ExecutionAttemptID, Throwable) - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
 
releasePendingWorker(ResourceID) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
Release the given pending worker.
releasePendingWorker(ResourceID) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Trigger a release of a pending worker.
releasePendingWorker(ResourceID) - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
 
releasePendingWorker(ResourceID) - Method in class org.apache.flink.yarn.YarnFlinkResourceManager
 
releaseReference(String, int, BatchTask<?, ?>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableManager
 
releaseReference(BroadcastVariableKey, BatchTask<?, ?>) - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableManager
 
releaseResource(InstanceID) - Method in interface org.apache.flink.runtime.resourcemanager.slotmanager.ResourceManagerActions
 
releaseSlot() - Method in class org.apache.flink.runtime.instance.SharedSlot
 
releaseSlot() - Method in class org.apache.flink.runtime.instance.SimpleSlot
 
releaseSlot() - Method in class org.apache.flink.runtime.instance.Slot
This method cancels and releases the slot and all its sub-slots.
releaseSlotFuture(Future<SimpleSlot>) - Static method in class org.apache.flink.runtime.executiongraph.ExecutionGraphUtils
Releases the slot represented by the given future.
releaseStartedWorker(RegisteredMesosWorkerNode) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
Release the given started worker.
releaseStartedWorker(WorkerType) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Trigger a release of a started worker.
releaseStartedWorker(ResourceID) - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
 
releaseStartedWorker(RegisteredYarnWorkerNode) - Method in class org.apache.flink.yarn.YarnFlinkResourceManager
 
releaseTable() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
Releases the table (the array of buckets) and returns the occupied memory segments to the list of free segments.
releaseTable() - Method in class org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
 
releaseTaskManager(ResourceID) - Method in class org.apache.flink.runtime.instance.SlotPool
Unregister TaskManager from this pool, all the related slots will be released and tasks be canceled.
releaseTaskManager(ResourceID) - Method in interface org.apache.flink.runtime.instance.SlotPoolGateway
 
releaseWorker() - Method in class org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore.Worker
Transition the worker to a released state.
relNode() - Method in class org.apache.flink.table.plan.logical.LogicalRelNode
 
RelTable - Class in org.apache.flink.table.plan.schema
A Table implementation for registering Table API Tables in the Calcite schema to be used by Flink SQL.
RelTable(RelNode) - Constructor for class org.apache.flink.table.plan.schema.RelTable
 
RelTimeIndicatorConverter - Class in org.apache.flink.table.calcite
Traverses a RelNode tree and converts fields with TimeIndicatorRelDataType type.
RelTimeIndicatorConverter(RexBuilder) - Constructor for class org.apache.flink.table.calcite.RelTimeIndicatorConverter
 
RelTimeIndicatorConverter$ - Class in org.apache.flink.table.calcite
 
RelTimeIndicatorConverter$() - Constructor for class org.apache.flink.table.calcite.RelTimeIndicatorConverter$
 
RelTimeIndicatorConverter.RexTimeIndicatorMaterializer - Class in org.apache.flink.table.calcite
 
remaining() - Method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator.ReconciliationData
 
remainingCapacity() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
Returns the remaining capacity of the backing array.
REMOTE() - Method in class org.apache.flink.api.scala.FlinkShell.ExecutionMode$
 
RemoteAddressExtension - Class in org.apache.flink.runtime.akka
 
RemoteAddressExtension() - Constructor for class org.apache.flink.runtime.akka.RemoteAddressExtension
 
RemoteAddressExtension$ - Class in org.apache.flink.runtime.akka
 
RemoteAddressExtension$() - Constructor for class org.apache.flink.runtime.akka.RemoteAddressExtension$
 
RemoteAddressExtensionImplementation - Class in org.apache.flink.runtime.akka
ActorSystem Extension used to obtain the Address on which the given ActorSystem is listening.
RemoteAddressExtensionImplementation(ExtendedActorSystem) - Constructor for class org.apache.flink.runtime.akka.RemoteAddressExtensionImplementation
 
RemoteEnvironment - Class in org.apache.flink.api.java
An ExecutionEnvironment that sends programs to a cluster for execution.
RemoteEnvironment(String, int, String...) - Constructor for class org.apache.flink.api.java.RemoteEnvironment
Creates a new RemoteEnvironment that points to the master (JobManager) described by the given host name and port.
RemoteEnvironment(String, int, Configuration, String[]) - Constructor for class org.apache.flink.api.java.RemoteEnvironment
Creates a new RemoteEnvironment that points to the master (JobManager) described by the given host name and port.
RemoteEnvironment(String, int, Configuration, String[], URL[]) - Constructor for class org.apache.flink.api.java.RemoteEnvironment
Creates a new RemoteEnvironment that points to the master (JobManager) described by the given host name and port.
RemoteExecutor - Class in org.apache.flink.client
The RemoteExecutor is a PlanExecutor that takes the program and ships it to a remote Flink cluster for execution.
RemoteExecutor(String, int) - Constructor for class org.apache.flink.client.RemoteExecutor
 
RemoteExecutor(String, int, URL) - Constructor for class org.apache.flink.client.RemoteExecutor
 
RemoteExecutor(String, URL) - Constructor for class org.apache.flink.client.RemoteExecutor
 
RemoteExecutor(String, int, List<URL>) - Constructor for class org.apache.flink.client.RemoteExecutor
 
RemoteExecutor(String, int, Configuration) - Constructor for class org.apache.flink.client.RemoteExecutor
 
RemoteExecutor(String, int, Configuration, URL) - Constructor for class org.apache.flink.client.RemoteExecutor
 
RemoteExecutor(String, Configuration, URL) - Constructor for class org.apache.flink.client.RemoteExecutor
 
RemoteExecutor(String, int, Configuration, List<URL>, List<URL>) - Constructor for class org.apache.flink.client.RemoteExecutor
 
RemoteExecutor(InetSocketAddress, Configuration, List<URL>, List<URL>) - Constructor for class org.apache.flink.client.RemoteExecutor
 
RemoteInputChannel - Class in org.apache.flink.runtime.io.network.partition.consumer
An input channel, which requests a remote partition queue.
RemoteInputChannel(SingleInputGate, int, ResultPartitionID, ConnectionID, ConnectionManager, TaskIOMetricGroup) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
RemoteInputChannel(SingleInputGate, int, ResultPartitionID, ConnectionID, ConnectionManager, int, int, TaskIOMetricGroup) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
RemoteRpcInvocation - Class in org.apache.flink.runtime.rpc.akka.messages
Remote rpc invocation message which is used when the actor communication is remote and, thus, the message has to be serialized.
RemoteRpcInvocation(String, Class<?>[], Object[]) - Constructor for class org.apache.flink.runtime.rpc.akka.messages.RemoteRpcInvocation
 
RemoteStreamEnvironment - Class in org.apache.flink.streaming.api.environment
A StreamExecutionEnvironment for executing on a cluster.
RemoteStreamEnvironment(String, int, String...) - Constructor for class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
Creates a new RemoteStreamEnvironment that points to the master (JobManager) described by the given host name and port.
RemoteStreamEnvironment(String, int, Configuration, String...) - Constructor for class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
Creates a new RemoteStreamEnvironment that points to the master (JobManager) described by the given host name and port.
RemoteStreamEnvironment(String, int, Configuration, String[], URL[]) - Constructor for class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
Creates a new RemoteStreamEnvironment that points to the master (JobManager) described by the given host name and port.
RemoteTransportException - Exception in org.apache.flink.runtime.io.network.netty.exception
 
RemoteTransportException(String, SocketAddress) - Constructor for exception org.apache.flink.runtime.io.network.netty.exception.RemoteTransportException
 
RemoteTransportException(String, SocketAddress, Throwable) - Constructor for exception org.apache.flink.runtime.io.network.netty.exception.RemoteTransportException
 
remove() - Method in class org.apache.flink.api.common.functions.util.CopyingIterator
 
remove() - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase.SimpleListIterable.SimpleListIterator
 
remove() - Method in class org.apache.flink.api.common.operators.util.ListKeyGroupedIterator.ValuesIterator
 
remove(UK) - Method in interface org.apache.flink.api.common.state.MapState
Deletes the mapping of the given key.
remove() - Method in class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
 
remove() - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
 
remove(UK) - Method in class org.apache.flink.contrib.streaming.state.RocksDBMapState
 
remove() - Method in class org.apache.flink.graph.pregel.MessageIterator
 
remove() - Method in class org.apache.flink.graph.spargel.MessageIterator
 
remove() - Method in class org.apache.flink.hadoopcompatibility.mapred.wrapper.HadoopTupleUnwrappingIterator
 
remove(String) - Method in class org.apache.flink.runtime.iterative.concurrent.Broker
blocking retrieval and removal of the object to share
remove(Object) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
remove() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable.SimpleIterator
 
remove() - Method in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
remove() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
remove() - Method in class org.apache.flink.runtime.operators.util.metrics.CountingIterator
 
remove(N) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
remove(UK) - Method in class org.apache.flink.runtime.state.heap.HeapMapState
 
remove(N) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
remove(N) - Method in class org.apache.flink.runtime.state.heap.StateTable
Removes the mapping for the composite of active key and given namespace.
remove(JobID) - Method in class org.apache.flink.runtime.taskexecutor.JobManagerTable
 
remove(ExecutionAttemptID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlot
Remove the task identified by the given execution attempt id.
remove() - Method in class org.apache.flink.runtime.util.EmptyIterator
remove(K) - Method in class org.apache.flink.runtime.util.LRUCacheMap
 
remove() - Method in class org.apache.flink.runtime.util.NonReusingKeyGroupedIterator.ValuesIterator
 
remove() - Method in class org.apache.flink.runtime.util.NonReusingMutableToRegularIteratorWrapper
 
remove() - Method in class org.apache.flink.runtime.util.ReusingKeyGroupedIterator.ValuesIterator
 
remove() - Method in class org.apache.flink.runtime.util.ReusingMutableToRegularIteratorWrapper
 
remove() - Method in class org.apache.flink.runtime.util.SingleElementIterator
 
remove(Object) - Method in class org.apache.flink.storm.util.StormConfig
 
remove() - Method in class org.apache.flink.streaming.examples.join.WindowJoinSampleData.GradeSource
 
remove() - Method in class org.apache.flink.streaming.examples.join.WindowJoinSampleData.SalarySource
 
remove() - Method in class org.apache.flink.streaming.examples.utils.ThrottledIterator
 
remove() - Method in class org.apache.flink.table.runtime.aggregate.SingleElementIterable.SingleElementIterator
 
remove(int) - Method in class org.apache.flink.types.ListValue
 
remove(Object) - Method in class org.apache.flink.types.ListValue
 
remove(Object) - Method in class org.apache.flink.types.MapValue
 
remove() - Method in class org.apache.flink.util.LongValueSequenceIterator
 
remove() - Method in class org.apache.flink.util.NumberSequenceIterator
 
remove() - Method in class org.apache.flink.util.UnionIterator
 
removeAll(Collection<?>) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
removeAll(Collection<?>) - Method in class org.apache.flink.types.ListValue
 
removeAndGetOld(N) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
removeAndGetOld(N) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
removeAndGetOld(N) - Method in class org.apache.flink.runtime.state.heap.StateTable
Removes the mapping for the composite of active key and given namespace, returning the state that was found under the entry.
RemoveCachedJob(JobID) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RemoveCachedJob
 
RemoveCachedJob$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RemoveCachedJob$
 
removeClosedBranches(List<OptimizerNode.UnclosedBranchDescriptor>) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
removeEdge(Edge<K, EV>) - Method in class org.apache.flink.graph.Graph
Removes all edges that match the given edge from the graph.
removeEdge(Edge<K, EV>) - Method in class org.apache.flink.graph.scala.Graph
Removes all edges that match the given edge from the graph.
removeEdges(List<Edge<K, EV>>) - Method in class org.apache.flink.graph.Graph
Removes all the edges that match the edges in the given data set from the graph.
removeEdges(List<Edge<K, EV>>) - Method in class org.apache.flink.graph.scala.Graph
Removes all the edges that match the edges in the given data set from the graph.
removeField(int) - Method in class org.apache.flink.types.Record
Removes the field at the given position.
removeInstanceListener(InstanceListener) - Method in class org.apache.flink.runtime.instance.InstanceManager
 
RemoveJob(JobID, boolean) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RemoveJob
 
removeJob(JobID) - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
 
removeJob(JobID) - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
Remove the given job from being monitored by the service.
removeJob(JobID) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
removeJob(JobID) - Method in class org.apache.flink.runtime.taskexecutor.JobLeaderService
Remove the given job from being monitored by the job leader service.
RemoveJob$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RemoveJob$
 
removeJobFromStateBackend() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RemoveJob
 
removeJobGraph(JobID) - Method in class org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
 
removeJobGraph(JobID) - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
Removes the SubmittedJobGraph with the given JobID if it exists.
removeJobGraph(JobID) - Method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
 
removeJobMetricsGroup(JobID, TaskManagerJobMetricGroup) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
 
removeLast() - Method in class org.apache.flink.runtime.util.IntArrayList
 
removeLong(int) - Method in class org.apache.flink.runtime.util.LongArrayList
 
removeLRU() - Method in class org.apache.flink.runtime.util.LRUCache
 
removeLRU() - Method in class org.apache.flink.runtime.util.LRUCacheMap
 
removePath(Path) - Method in class org.apache.flink.mesos.util.MesosArtifactServer
 
RemoveRangeIndex<T> - Class in org.apache.flink.runtime.operators.udf
 
RemoveRangeIndex() - Constructor for class org.apache.flink.runtime.operators.udf.RemoveRangeIndex
 
RemoveResource - Class in org.apache.flink.runtime.clusterframework.messages
Message sent to the ResourceManager by the JobManager to instruct to remove a resource.
RemoveResource(ResourceID) - Constructor for class org.apache.flink.runtime.clusterframework.messages.RemoveResource
Constructor for a shutdown of a registered resource.
removeSavepointFile(String) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointStore
Removes the savepoint meta data w/o loading and disposing it.
RemoveScoreFromVertexValuesMapper() - Constructor for class org.apache.flink.graph.library.CommunityDetection.RemoveScoreFromVertexValuesMapper
 
removeSlotListener() - Method in class org.apache.flink.runtime.instance.Instance
Removes the listener that receives notifications for slot availability.
removeTask(ExecutionAttemptID) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Remove the task with the given execution attempt id from its task slot.
removeTaskMetricGroup(AbstractID) - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerJobMetricGroup
 
removeUngroupedInputs(TaggedValue) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
 
removeUngroupedInputsFromContainer(TaggedValue) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
 
removeVertex(Vertex<K, VV>) - Method in class org.apache.flink.graph.Graph
Removes the given vertex and its edges from the graph.
removeVertex(Vertex<K, VV>) - Method in class org.apache.flink.graph.scala.Graph
Removes the given vertex and its edges from the graph.
removeVertexFromGroup(JobVertexID) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
 
removeVertices(List<Vertex<K, VV>>) - Method in class org.apache.flink.graph.Graph
Removes the given list of vertices and its edges from the graph.
removeVertices(List<Vertex<K, VV>>) - Method in class org.apache.flink.graph.scala.Graph
Removes the given vertex and its edges from the graph.
removeWorker(Protos.TaskID) - Method in interface org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore
Remove a worker from storage.
removeWorker(Protos.TaskID) - Method in class org.apache.flink.mesos.runtime.clusterframework.store.StandaloneMesosWorkerStore
 
removeWorker(Protos.TaskID) - Method in class org.apache.flink.mesos.runtime.clusterframework.store.ZooKeeperMesosWorkerStore
 
rename(Path, Path) - Method in class org.apache.flink.core.fs.FileSystem
Renames the file/directory src to dst.
rename(Path, Path) - Method in class org.apache.flink.core.fs.local.LocalFileSystem
 
rename(Path, Path) - Method in class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
rename(Path, Path) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopFileSystem
 
rename(Path, Path) - Method in class org.apache.flink.runtime.fs.maprfs.MapRFileSystem
 
reopen(FileInputSplit, Tuple2<Long, Long>) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
 
reopen(S, T) - Method in interface org.apache.flink.api.common.io.CheckpointableInputFormat
Restores the state of a parallel instance reading from an InputFormat.
reopen(FileInputSplit, Long) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
reopen(FileInputSplit, Tuple2<Long, Long>) - Method in class org.apache.flink.api.java.io.AvroInputFormat
 
reopen(Iterator<T>) - Method in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
ReOpenableHashPartition<BT,PT> - Class in org.apache.flink.runtime.operators.hash
 
ReOpenableMutableHashTable<BT,PT> - Class in org.apache.flink.runtime.operators.hash
 
ReOpenableMutableHashTable(TypeSerializer<BT>, TypeSerializer<PT>, TypeComparator<BT>, TypeComparator<PT>, TypePairComparator<PT, BT>, List<MemorySegment>, IOManager, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
 
reopenProbe(MutableObjectIterator<V2>) - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildFirstReOpenableHashJoinIterator
Set new input for probe side
reopenProbe(MutableObjectIterator<V1>) - Method in class org.apache.flink.runtime.operators.hash.NonReusingBuildSecondReOpenableHashJoinIterator
Set new input for probe side
reopenProbe(MutableObjectIterator<PT>) - Method in class org.apache.flink.runtime.operators.hash.ReOpenableMutableHashTable
 
reopenProbe(MutableObjectIterator<V2>) - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildFirstReOpenableHashJoinIterator
Set new input for probe side
reopenProbe(MutableObjectIterator<V1>) - Method in class org.apache.flink.runtime.operators.hash.ReusingBuildSecondReOpenableHashJoinIterator
Set new input for probe side
rep(Function0<Parsers.Parser<T>>) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
rep1(Function0<Parsers.Parser<T>>) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
rep1(Function0<Parsers.Parser<T>>, Function0<Parsers.Parser<T>>) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
rep1sep(Function0<Parsers.Parser<T>>, Function0<Parsers.Parser<Object>>) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
repartitionState(List<OperatorStateHandle>, int) - Method in interface org.apache.flink.runtime.checkpoint.OperatorStateRepartitioner
 
repartitionState(List<OperatorStateHandle>, int) - Method in class org.apache.flink.runtime.checkpoint.RoundRobinOperatorStateRepartitioner
 
REPLACE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The REPLACE(string, search, replace) function.
replace() - Method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator.Reconcile
 
replace(String, int, T) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
Replaces a state handle in ZooKeeper and discards the old state handle.
replace(X) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
Replace the currently stored value by the given new value.
replace(X, long) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
Replace the currently stored value by the given new value and the currently stored timestamp with the new timestamp.
replaceAggFunctionCall(Expression, TableEnvironment) - Method in class org.apache.flink.table.plan.ProjectionTranslator$
Find and replace UDAGG function Call to AggFunctionCall
replaceAggFunctionCall(Expression, TableEnvironment) - Static method in class org.apache.flink.table.plan.ProjectionTranslator
Find and replace UDAGG function Call to AggFunctionCall
replaceAggregationsAndProperties(Seq<Expression>, TableEnvironment, Map<Expression, String>, Map<Expression, String>) - Method in class org.apache.flink.table.plan.ProjectionTranslator$
Replaces expressions with deduplicated aggregations and properties.
replaceAggregationsAndProperties(Seq<Expression>, TableEnvironment, Map<Expression, String>, Map<Expression, String>) - Static method in class org.apache.flink.table.plan.ProjectionTranslator
Replaces expressions with deduplicated aggregations and properties.
replaceDecoRuleSet(RuleSet) - Method in class org.apache.flink.table.calcite.CalciteConfigBuilder
Replaces the built-in decoration rule set with the given rule set.
replaceGroupAuxiliaries(RexNode, RelBuilder) - Method in class org.apache.flink.table.plan.rules.common.WindowStartEndPropertiesBaseRule
 
replaceInput(int, RelNode) - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
replaceInput(int, RelNode) - Static method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
replaceInput(int, RelNode) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
replaceInput(int, RelNode) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
replaceInput(int, RelNode) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
replaceInput(int, RelNode) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
replaceInput(int, RelNode) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
replaceInput(int, RelNode) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
replaceInput(int, RelNode) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
replaceInput(int, RelNode) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
replaceInput(int, RelNode) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
replaceInput(int, RelNode) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
replaceInput(int, RelNode) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
replaceInput(int, RelNode) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
replaceInput(int, RelNode) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
replaceInput(int, RelNode) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
replaceLogicalOptRuleSet(RuleSet) - Method in class org.apache.flink.table.calcite.CalciteConfigBuilder
Replaces the built-in optimization rule set with the given rule set.
replacement() - Method in class org.apache.flink.table.expressions.Overlay
 
replaceNonWordChars(StringValue, char) - Static method in class org.apache.flink.util.StringValueUtils
Replaces all non-word characters in a string by a given character.
replaceNormRuleSet(RuleSet) - Method in class org.apache.flink.table.calcite.CalciteConfigBuilder
Replaces the built-in normalization rule set with the given rule set.
replacePhysicalOptRuleSet(RuleSet) - Method in class org.apache.flink.table.calcite.CalciteConfigBuilder
Replaces the built-in optimization rule set with the given rule set.
replaceRegisteredTable(String, AbstractTable) - Method in class org.apache.flink.table.api.TableEnvironment
Replaces a registered Table with another Table under the same name.
replacesDecoRuleSet() - Method in interface org.apache.flink.table.calcite.CalciteConfig
Returns whether this configuration replaces the built-in decoration rule set.
replacesLogicalOptRuleSet() - Method in interface org.apache.flink.table.calcite.CalciteConfig
Returns whether this configuration replaces the built-in logical optimization rule set.
replacesNormRuleSet() - Method in interface org.apache.flink.table.calcite.CalciteConfig
Returns whether this configuration replaces the built-in normalization rule set.
replacesPhysicalOptRuleSet() - Method in interface org.apache.flink.table.calcite.CalciteConfig
Returns whether this configuration replaces the built-in physical optimization rule set.
replaceSqlOperatorTable(SqlOperatorTable) - Method in class org.apache.flink.table.calcite.CalciteConfigBuilder
Replaces the built-in SQL operator table with the given table.
replaceSqlParserConfig(SqlParser.Config) - Method in class org.apache.flink.table.calcite.CalciteConfigBuilder
Replaces the built-in SQL parser configuration with the given configuration.
replacesSqlOperatorTable() - Method in interface org.apache.flink.table.calcite.CalciteConfig
Returns whether this configuration replaces the built-in SQL operator table.
ReplicatingInputFormat<OT,S extends InputSplit> - Class in org.apache.flink.api.common.io
A ReplicatingInputFormat replicates any InputFormat to all parallel instances of a DataSource, i.e., the full input of the replicated InputFormat is completely processed by each parallel instance of the DataSource.
ReplicatingInputFormat(InputFormat<OT, S>) - Constructor for class org.apache.flink.api.common.io.ReplicatingInputFormat
 
ReplicatingInputSplitAssigner - Class in org.apache.flink.api.common.io
Assigns each InputSplit to each requesting parallel instance.
ReplicatingInputSplitAssigner(Collection<InputSplit>) - Constructor for class org.apache.flink.api.common.io.ReplicatingInputSplitAssigner
 
ReplicatingInputSplitAssigner(InputSplit[]) - Constructor for class org.apache.flink.api.common.io.ReplicatingInputSplitAssigner
 
repN(int, Function0<Parsers.Parser<T>>) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
report() - Method in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
 
report() - Method in class org.apache.flink.metrics.datadog.DatadogHttpReporter
 
report() - Method in interface org.apache.flink.metrics.reporter.Scheduled
Report the current measurements.
report() - Method in class org.apache.flink.metrics.statsd.StatsDReporter
 
reportActiveConnection() - Method in class org.apache.flink.runtime.query.netty.AtomicKvStateRequestStats
 
reportActiveConnection() - Method in class org.apache.flink.runtime.query.netty.DisabledKvStateRequestStats
 
reportActiveConnection() - Method in interface org.apache.flink.runtime.query.netty.KvStateRequestStats
Reports an active connection.
reporter - Variable in class org.apache.flink.dropwizard.ScheduledDropwizardReporter
 
reporterIndex - Variable in class org.apache.flink.runtime.metrics.groups.FrontMetricGroup
 
reportError(Throwable) - Method in class org.apache.flink.streaming.connectors.kafka.internal.Handover
Reports an exception.
reportError(Throwable) - Method in class org.apache.flink.streaming.connectors.kafka.internals.ExceptionProxy
Sets the exception and interrupts the target thread, if no other exception has occurred so far.
REPORTERS_LIST - Static variable in class org.apache.flink.configuration.MetricOptions
The list of named reporters.
reportFailedRequest() - Method in class org.apache.flink.runtime.query.netty.AtomicKvStateRequestStats
 
reportFailedRequest() - Method in class org.apache.flink.runtime.query.netty.DisabledKvStateRequestStats
 
reportFailedRequest() - Method in interface org.apache.flink.runtime.query.netty.KvStateRequestStats
Reports a failure during a request.
reportHeartBeat() - Method in class org.apache.flink.runtime.instance.Instance
Updates the time of last received heart beat to the current system time.
reportHeartBeat(InstanceID) - Method in class org.apache.flink.runtime.instance.InstanceManager
 
reportInactiveConnection() - Method in class org.apache.flink.runtime.query.netty.AtomicKvStateRequestStats
 
reportInactiveConnection() - Method in class org.apache.flink.runtime.query.netty.DisabledKvStateRequestStats
 
reportInactiveConnection() - Method in interface org.apache.flink.runtime.query.netty.KvStateRequestStats
Reports an inactive connection.
reportLatency(LatencyMarker, boolean) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator.LatencyGauge
 
reportOrForwardLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
reportOrForwardLatencyMarker(LatencyMarker) - Method in class org.apache.flink.streaming.api.operators.StreamSink
 
reportPayload(ResourceID, I) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatListener
Callback which is called whenever a heartbeat with an associated payload is received.
reportRequest() - Method in class org.apache.flink.runtime.query.netty.AtomicKvStateRequestStats
 
reportRequest() - Method in class org.apache.flink.runtime.query.netty.DisabledKvStateRequestStats
 
reportRequest() - Method in interface org.apache.flink.runtime.query.netty.KvStateRequestStats
Reports an incoming request.
reportSlotStatus(InstanceID, SlotReport) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Reports the current slot allocations for a task manager identified by the given instance id.
reportSuccessfulRequest(long) - Method in class org.apache.flink.runtime.query.netty.AtomicKvStateRequestStats
 
reportSuccessfulRequest(long) - Method in class org.apache.flink.runtime.query.netty.DisabledKvStateRequestStats
 
reportSuccessfulRequest(long) - Method in interface org.apache.flink.runtime.query.netty.KvStateRequestStats
Reports a successfully handled request.
repsep(Function0<Parsers.Parser<T>>, Function0<Parsers.Parser<Object>>) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
RequestAccumulatorResults - Class in org.apache.flink.runtime.messages.accumulators
Requests the accumulator results of the job identified by jobID from the job manager.
RequestAccumulatorResults(JobID) - Constructor for class org.apache.flink.runtime.messages.accumulators.RequestAccumulatorResults
 
RequestAccumulatorResults$ - Class in org.apache.flink.runtime.messages.accumulators
 
RequestAccumulatorResults$() - Constructor for class org.apache.flink.runtime.messages.accumulators.RequestAccumulatorResults$
 
RequestAccumulatorResultsStringified - Class in org.apache.flink.runtime.messages.accumulators
Requests the accumulator results of the job as strings.
RequestAccumulatorResultsStringified(JobID) - Constructor for class org.apache.flink.runtime.messages.accumulators.RequestAccumulatorResultsStringified
 
RequestAccumulatorResultsStringified$ - Class in org.apache.flink.runtime.messages.accumulators
 
RequestAccumulatorResultsStringified$() - Constructor for class org.apache.flink.runtime.messages.accumulators.RequestAccumulatorResultsStringified$
 
RequestArchive$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RequestArchive$
 
RequestArchivedJob(JobID) - Constructor for class org.apache.flink.runtime.messages.ArchiveMessages.RequestArchivedJob
 
RequestArchivedJob$() - Constructor for class org.apache.flink.runtime.messages.ArchiveMessages.RequestArchivedJob$
 
RequestArchivedJobs$() - Constructor for class org.apache.flink.runtime.messages.ArchiveMessages.RequestArchivedJobs$
 
RequestBlobManagerPort$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RequestBlobManagerPort$
 
RequestBroadcastVariablesWithReferences$() - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages.RequestBroadcastVariablesWithReferences$
 
requestBuffer() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
Returns a Buffer instance from the buffer provider, if one is available.
requestBufferBlocking() - Method in interface org.apache.flink.runtime.io.network.buffer.BufferProvider
Returns a Buffer instance from the buffer provider.
requestClassloadingProps() - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
requestClassloadingProps() - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
Request the classloading props of this job.
RequestClassloadingProps(JobID) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RequestClassloadingProps
 
RequestClassloadingProps$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RequestClassloadingProps$
 
RequestDoneCallback<T> - Interface in org.apache.flink.runtime.io.disk.iomanager
Callback to be executed on completion of an asynchronous I/O request.
RequestedGlobalProperties - Class in org.apache.flink.optimizer.dataproperties
This class represents the global properties of the data that are requested by an operator.
RequestedGlobalProperties() - Constructor for class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
Initializes the global properties with no partitioning.
RequestedLocalProperties - Class in org.apache.flink.optimizer.dataproperties
This class represents the local properties of the data that are requested by an operator.
RequestedLocalProperties() - Constructor for class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
Default constructor for trivial local properties.
RequestedLocalProperties(Ordering) - Constructor for class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
Creates interesting properties for the given ordering.
RequestedLocalProperties(FieldSet) - Constructor for class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
Creates interesting properties for the given grouping.
requestFailed(T, IOException) - Method in class org.apache.flink.runtime.io.disk.iomanager.QueuingCallback
 
requestFailed(T, IOException) - Method in interface org.apache.flink.runtime.io.disk.iomanager.RequestDoneCallback
 
RequestHandler - Interface in org.apache.flink.runtime.webmonitor.handlers
Base interface for all request handlers.
RequestHandlerException - Exception in org.apache.flink.runtime.webmonitor.handlers
Base class for request handler exceptions.
RequestHandlerException(String) - Constructor for exception org.apache.flink.runtime.webmonitor.handlers.RequestHandlerException
 
requestHeartbeat(ResourceID, I) - Method in class org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
 
requestHeartbeat(ResourceID, I) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatTarget
Requests a heartbeat from the target.
requestIFEQLoopModification() - Method in class org.apache.flink.api.java.sca.ModifiedASMAnalyzer
 
requestIFNELoopModification() - Method in class org.apache.flink.api.java.sca.ModifiedASMAnalyzer
 
RequestIndexer - Interface in org.apache.flink.streaming.connectors.elasticsearch
Users add multiple ActionRequests to a RequestIndexer to prepare them for sending to an Elasticsearch cluster.
RequestIndexer - Interface in org.apache.flink.streaming.connectors.elasticsearch2
Deprecated.
Deprecated since 1.2, to be removed at 2.0. This class has been deprecated due to package relocation. Please use RequestIndexer instead.
RequestJob(JobID) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RequestJob
 
RequestJob$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RequestJob$
 
RequestJobCounts$() - Constructor for class org.apache.flink.runtime.messages.ArchiveMessages.RequestJobCounts$
 
RequestJobDetails - Class in org.apache.flink.runtime.messages.webmonitor
This message requests an overview of the jobs on the JobManager, including running jobs and/or finished jobs.
RequestJobDetails(boolean, boolean) - Constructor for class org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
 
RequestJobManagerStatus$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RequestJobManagerStatus$
 
RequestJobsOverview - Class in org.apache.flink.runtime.messages.webmonitor
This message requests an overview of how many jobs are in which status.
RequestJobStatus(JobID) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RequestJobStatus
 
RequestJobStatus$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RequestJobStatus$
 
RequestJobsWithIDsOverview - Class in org.apache.flink.runtime.messages.webmonitor
This message requests an overview of how many jobs are in which status.
RequestLeaderSessionID$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RequestLeaderSessionID$
 
requestMemorySegment() - Method in class org.apache.flink.runtime.io.network.buffer.NetworkBufferPool
 
requestNewWorkers(int) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
Plan for some additional workers to be launched.
requestNewWorkers(int) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Requests to allocate a certain number of new workers.
requestNewWorkers(int) - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
 
requestNewWorkers(int) - Method in class org.apache.flink.yarn.YarnFlinkResourceManager
 
requestNextInputSplit(UUID, JobVertexID, ExecutionAttemptID) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
requestNextInputSplit(UUID, JobVertexID, ExecutionAttemptID) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
Requesting next input split for the ExecutionJobVertex.
RequestNextInputSplit(JobID, JobVertexID, ExecutionAttemptID) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RequestNextInputSplit
 
RequestNextInputSplit$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RequestNextInputSplit$
 
RequestNumActiveConnections$() - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages.RequestNumActiveConnections$
 
RequestNumberRegisteredTaskManager$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RequestNumberRegisteredTaskManager$
 
requestPartitionProducerState(JobID, IntermediateDataSetID, ResultPartitionID) - Method in interface org.apache.flink.runtime.io.network.netty.PartitionProducerStateChecker
Requests the execution state of the execution producing a result partition.
RequestPartitionProducerState(JobID, IntermediateDataSetID, ResultPartitionID) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RequestPartitionProducerState
 
requestPartitionProducerState(JobID, IntermediateDataSetID, ResultPartitionID) - Method in class org.apache.flink.runtime.taskexecutor.rpc.RpcPartitionStateChecker
 
requestPartitionProducerState(JobID, IntermediateDataSetID, ResultPartitionID) - Method in class org.apache.flink.runtime.taskmanager.ActorGatewayPartitionProducerStateChecker
 
RequestPartitionProducerState$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RequestPartitionProducerState$
 
requestPartitions() - Method in interface org.apache.flink.runtime.io.network.partition.consumer.InputGate
 
requestPartitions() - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
requestPartitions() - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
 
requestPartitionState(UUID, IntermediateDataSetID, ResultPartitionID) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
requestPartitionState(UUID, IntermediateDataSetID, ResultPartitionID) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
Requests the current state of the partition.
requestQueue - Variable in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
A request queue for submitting asynchronous requests to the corresponding IO worker thread.
RequestQueue<E> - Class in org.apache.flink.runtime.io.disk.iomanager
A LinkedBlockingQueue that is extended with closing methods.
RequestQueue() - Constructor for class org.apache.flink.runtime.io.disk.iomanager.RequestQueue
 
RequestRegisteredTaskManagers$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RequestRegisteredTaskManagers$
 
RequestRunningJobs$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RequestRunningJobs$
 
RequestRunningJobsStatus$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RequestRunningJobsStatus$
 
requestSlot(UUID, UUID, SlotRequest) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
Requests a slot from the resource manager.
requestSlot(UUID, UUID, SlotRequest, Time) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Requests a slot from the resource manager.
requestSlot(SlotID, JobID, AllocationID, String, UUID) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
Requests a slot from the TaskManager
requestSlot(SlotID, JobID, AllocationID, String, UUID, Time) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Requests a slot from the TaskManager
requestsNotReturned - Variable in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
An atomic integer that counts the number of requests that we still wait for to return.
requestStackTrace(Time) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
requestStackTrace(Time) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Request the stack trace from the task manager.
requestStackTrace(Time) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
RequestStackTrace(InstanceID) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RequestStackTrace
 
RequestStackTrace$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RequestStackTrace$
 
requestStackTraceSample(int, int, Time, int, Time) - Method in class org.apache.flink.runtime.executiongraph.Execution
Request a stack trace sample from the task of this execution.
requestStackTraceSample(ExecutionAttemptID, int, int, Time, int, Time) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
requestStackTraceSample(ExecutionAttemptID, int, int, Time, int, Time) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Request a stack trace sample from the given task.
requestStackTraceSample(ExecutionAttemptID, int, int, Time, int, Time) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
RequestStatusOverview - Class in org.apache.flink.runtime.messages.webmonitor
This message requests an overview of the status, such as how many TaskManagers are currently connected, how many slots are available, how many are free, ...
requestSubpartition(ResultPartitionID, int, RemoteInputChannel, int) - Method in class org.apache.flink.runtime.io.network.netty.PartitionRequestClient
Requests a remote intermediate result partition queue.
requestSuccessful(T) - Method in class org.apache.flink.runtime.io.disk.iomanager.QueuingCallback
 
requestSuccessful(T) - Method in interface org.apache.flink.runtime.io.disk.iomanager.RequestDoneCallback
 
RequestTaskManagerInstance(InstanceID) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RequestTaskManagerInstance
 
RequestTaskManagerInstance$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RequestTaskManagerInstance$
 
requestTaskManagerLog(Time) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
requestTaskManagerLog(Time) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Request the task manager log from the task manager.
requestTaskManagerLog(Time) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
RequestTaskManagerLog(TaskManagerMessages.LogTypeRequest) - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages.RequestTaskManagerLog
 
RequestTaskManagerLog$() - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages.RequestTaskManagerLog$
 
requestTaskManagerStdout(Time) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
requestTaskManagerStdout(Time) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Request the task manager stdout from the task manager.
requestTaskManagerStdout(Time) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
requestTermination() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
requestTermination() - Method in class org.apache.flink.runtime.iterative.task.IterationSynchronizationSinkTask
 
requestTermination() - Method in interface org.apache.flink.runtime.iterative.task.Terminable
 
RequestTotalNumberOfSlots$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RequestTotalNumberOfSlots$
 
requestType() - Method in class org.apache.flink.runtime.messages.TaskManagerMessages.RequestTaskManagerLog
 
RequestWebMonitorPort$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RequestWebMonitorPort$
 
require(int) - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
Require makes sure that at least required number of bytes are kept in the buffer.
requireArray(GeneratedExpression) - Method in class org.apache.flink.table.codegen.CodeGenUtils$
 
requireArray(GeneratedExpression) - Static method in class org.apache.flink.table.codegen.CodeGenUtils
 
requireBoolean(GeneratedExpression) - Method in class org.apache.flink.table.codegen.CodeGenUtils$
 
requireBoolean(GeneratedExpression) - Static method in class org.apache.flink.table.codegen.CodeGenUtils
 
requireComparable(GeneratedExpression) - Method in class org.apache.flink.table.codegen.CodeGenUtils$
 
requireComparable(GeneratedExpression) - Static method in class org.apache.flink.table.codegen.CodeGenUtils
 
requiredClasspaths() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.ClassloadingProps
 
requiredJarFiles() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.ClassloadingProps
 
RequiredParameters - Class in org.apache.flink.api.java.utils
Facility to manage required parameters in user defined functions.
RequiredParameters() - Constructor for class org.apache.flink.api.java.utils.RequiredParameters
 
RequiredParametersException - Exception in org.apache.flink.api.java.utils
Exception which is thrown if validation of RequiredParameters fails.
RequiredParametersException() - Constructor for exception org.apache.flink.api.java.utils.RequiredParametersException
 
RequiredParametersException(String, List<String>) - Constructor for exception org.apache.flink.api.java.utils.RequiredParametersException
 
RequiredParametersException(String) - Constructor for exception org.apache.flink.api.java.utils.RequiredParametersException
 
RequiredParametersException(String, Throwable) - Constructor for exception org.apache.flink.api.java.utils.RequiredParametersException
 
RequiredParametersException(Throwable) - Constructor for exception org.apache.flink.api.java.utils.RequiredParametersException
 
requiredProperties() - Method in interface org.apache.flink.table.catalog.TableSourceConverter
Defines the properties that need to be provided by the ExternalCatalogTable to create the TableSource.
requiredProperties() - Method in class org.apache.flink.table.sources.CsvTableSourceConverter
 
requireInteger(GeneratedExpression) - Method in class org.apache.flink.table.codegen.CodeGenUtils$
 
requireInteger(GeneratedExpression) - Static method in class org.apache.flink.table.codegen.CodeGenUtils
 
requireNumeric(GeneratedExpression) - Method in class org.apache.flink.table.codegen.CodeGenUtils$
 
requireNumeric(GeneratedExpression) - Static method in class org.apache.flink.table.codegen.CodeGenUtils
 
requiresComparator() - Method in enum org.apache.flink.runtime.operators.shipping.ShipStrategyType
 
requiresComparator() - Method in enum org.apache.flink.runtime.operators.util.LocalStrategy
 
requiresDecimalExpansion() - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
requiresDecimalExpansion() - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
requiresDecimalExpansion() - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
requiresDecimalExpansion() - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
requiresExternalizedCheckpoints() - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
This method returns whether the completed checkpoint store requires checkpoints to be externalized.
requiresExternalizedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
 
requiresExternalizedCheckpoints() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
 
RequiresLeaderSessionID - Interface in org.apache.flink.runtime.messages
Marks messages to be sent wrapped in a JobManagerMessages.LeaderSessionMessage
requiresMigration(TypeDeserializer<T>) - Static method in class org.apache.flink.api.common.typeutils.CompatibilityResult
Returns a result that signals migration to be performed, and in the case that the preceding serializer cannot be found or restored to read the previous data during migration, a provided convert deserializer can be used.
requiresMigration(TypeSerializer<T>) - Static method in class org.apache.flink.api.common.typeutils.CompatibilityResult
Returns a result that signals migration to be performed, and in the case that the preceding serializer cannot be found or restored to read the previous data during migration, a provided convert serializer can be used.
requiresMigration() - Static method in class org.apache.flink.api.common.typeutils.CompatibilityResult
Returns a result that signals migration to be performed.
requiresOrder() - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
requiresOrder() - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
requiresOrder() - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
requiresOrder() - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
requiresOver() - Method in class org.apache.flink.table.functions.AggregateFunction
whether this aggregate only used in OVER clause
requiresOver() - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
requiresOver() - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
requiresOver() - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
requiresOver() - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
requireString(GeneratedExpression) - Method in class org.apache.flink.table.codegen.CodeGenUtils$
 
requireString(GeneratedExpression) - Static method in class org.apache.flink.table.codegen.CodeGenUtils
 
requireTemporal(GeneratedExpression) - Method in class org.apache.flink.table.codegen.CodeGenUtils$
 
requireTemporal(GeneratedExpression) - Static method in class org.apache.flink.table.codegen.CodeGenUtils
 
requireTimeInterval(GeneratedExpression) - Method in class org.apache.flink.table.codegen.CodeGenUtils$
 
requireTimeInterval(GeneratedExpression) - Static method in class org.apache.flink.table.codegen.CodeGenUtils
 
ReRegistered - Class in org.apache.flink.mesos.scheduler.messages
Message sent by the callback handler to the scheduler actor when the scheduler re-registers with a newly elected Mesos master.
ReRegistered(Protos.MasterInfo) - Constructor for class org.apache.flink.mesos.scheduler.messages.ReRegistered
 
reregistered(SchedulerDriver, Protos.MasterInfo) - Method in class org.apache.flink.mesos.scheduler.SchedulerProxy
 
reregisterStateFromLegacyAlignedWindowOperator() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
reregisterStateFromLegacyWindowOperator() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
rescale() - Method in class org.apache.flink.streaming.api.datastream.DataStream
Sets the partitioning of the DataStream so that the output elements are distributed evenly to a subset of instances of the next operation in a round-robin fashion.
rescale() - Method in class org.apache.flink.streaming.api.scala.DataStream
Sets the partitioning of the DataStream so that the output tuples are distributed evenly to a subset of instances of the downstream operation.
RescalePartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
Partitioner that distributes the data equally by cycling through the output channels.
RescalePartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
 
ReservoirSamplerWithoutReplacement<T> - Class in org.apache.flink.api.java.sampling
A simple in memory implementation of Reservoir Sampling without replacement, and with only one pass through the input iteration whose size is unpredictable.
ReservoirSamplerWithoutReplacement(int, Random) - Constructor for class org.apache.flink.api.java.sampling.ReservoirSamplerWithoutReplacement
Create a new sampler with reservoir size and a supplied random number generator.
ReservoirSamplerWithoutReplacement(int) - Constructor for class org.apache.flink.api.java.sampling.ReservoirSamplerWithoutReplacement
Create a new sampler with reservoir size and a default random number generator.
ReservoirSamplerWithoutReplacement(int, long) - Constructor for class org.apache.flink.api.java.sampling.ReservoirSamplerWithoutReplacement
Create a new sampler with reservoir size and the seed for random number generator.
ReservoirSamplerWithReplacement<T> - Class in org.apache.flink.api.java.sampling
A simple in memory implementation of Reservoir Sampling with replacement and with only one pass through the input iteration whose size is unpredictable.
ReservoirSamplerWithReplacement(int) - Constructor for class org.apache.flink.api.java.sampling.ReservoirSamplerWithReplacement
Create a sampler with fixed sample size and default random number generator.
ReservoirSamplerWithReplacement(int, long) - Constructor for class org.apache.flink.api.java.sampling.ReservoirSamplerWithReplacement
Create a sampler with fixed sample size and random number generator seed.
ReservoirSamplerWithReplacement(int, Random) - Constructor for class org.apache.flink.api.java.sampling.ReservoirSamplerWithReplacement
Create a sampler with fixed sample size and random number generator.
reset() - Method in interface org.apache.flink.api.common.aggregators.Aggregator
Resets the internal state of the aggregator.
reset() - Method in class org.apache.flink.api.common.aggregators.DoubleSumAggregator
 
reset() - Method in class org.apache.flink.api.common.aggregators.LongSumAggregator
 
reset() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregator
 
reset() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Contributors
 
reset() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.CurrentUserRetweet
 
reset(int) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
reset() - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
reset() - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
 
reset() - Method in class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
 
reset() - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
reset() - Method in class org.apache.flink.core.testutils.OneShotLatch
resets the latch to triggered = false
reset() - Method in class org.apache.flink.graph.library.Summarization.VertexGroupItem
Resets the fields to initial values.
reset() - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
 
reset() - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
 
reset() - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
 
reset() - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
 
reset() - Method in interface org.apache.flink.graph.types.valuearray.ValueArray
Restores the array index to when mark() was last called.
reset() - Method in class org.apache.flink.graph.utils.Murmur3_32
Re-initialize the MurmurHash state.
reset() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
This method resets the properties to a state where no properties are given.
reset() - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
This method resets the properties to a state where no properties are given.
reset() - Method in class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
This method resets the local properties to a state where no properties are given.
reset() - Method in class org.apache.flink.python.api.util.SetCache
Resets this SetCache, removing any cached sets.
reset() - Method in class org.apache.flink.runtime.io.disk.SimpleCollectingOutputView
 
reset() - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
 
reset() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
 
reset() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
 
reset() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable.HashBucketIterator
 
reset() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
 
reset() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
 
reset() - Method in class org.apache.flink.runtime.operators.resettable.BlockResettableMutableObjectIterator
 
reset() - Method in class org.apache.flink.runtime.operators.resettable.NonReusingBlockResettableIterator
 
reset() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
reset() - Method in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
reset() - Method in interface org.apache.flink.runtime.operators.ResettableDriver
 
reset() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
Resets the sort buffer back to the state where it is empty.
reset() - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
Resets the sort buffer back to the state where it is empty.
reset() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
Resets the sort buffer back to the state where it is empty.
reset() - Method in class org.apache.flink.runtime.operators.util.BloomFilter
 
reset() - Method in class org.apache.flink.runtime.state.BoundedInputStream
 
reset() - Method in class org.apache.flink.runtime.util.NonClosingStreamDecorator
 
reset() - Method in interface org.apache.flink.runtime.util.ResettableIterator
Resets the iterator.
reset() - Method in interface org.apache.flink.runtime.util.ResettableMutableObjectIterator
Resets the iterator.
reset() - Method in class org.apache.flink.table.runtime.TableFunctionCollector
Resets the flag to indicate whether collect(T) has been called.
resetAccumulator(BigIntegralAvgAccumulator) - Method in class org.apache.flink.table.functions.aggfunctions.BigIntegralAvgAggFunction
 
resetAccumulator(CountAccumulator) - Method in class org.apache.flink.table.functions.aggfunctions.CountAggFunction
 
resetAccumulator(DecimalAvgAccumulator) - Method in class org.apache.flink.table.functions.aggfunctions.DecimalAvgAggFunction
 
resetAccumulator(DecimalSumAccumulator) - Method in class org.apache.flink.table.functions.aggfunctions.DecimalSumAggFunction
 
resetAccumulator(DecimalSumWithRetractAccumulator) - Method in class org.apache.flink.table.functions.aggfunctions.DecimalSumWithRetractAggFunction
 
resetAccumulator(FloatingAvgAccumulator) - Method in class org.apache.flink.table.functions.aggfunctions.FloatingAvgAggFunction
 
resetAccumulator(IntegralAvgAccumulator) - Method in class org.apache.flink.table.functions.aggfunctions.IntegralAvgAggFunction
 
resetAccumulator(MaxAccumulator<T>) - Method in class org.apache.flink.table.functions.aggfunctions.MaxAggFunction
 
resetAccumulator(MaxWithRetractAccumulator<T>) - Method in class org.apache.flink.table.functions.aggfunctions.MaxWithRetractAggFunction
 
resetAccumulator(MinAccumulator<T>) - Method in class org.apache.flink.table.functions.aggfunctions.MinAggFunction
 
resetAccumulator(MinWithRetractAccumulator<T>) - Method in class org.apache.flink.table.functions.aggfunctions.MinWithRetractAggFunction
 
resetAccumulator(SumAccumulator<T>) - Method in class org.apache.flink.table.functions.aggfunctions.SumAggFunction
 
resetAccumulator(SumWithRetractAccumulator<T>) - Method in class org.apache.flink.table.functions.aggfunctions.SumWithRetractAggFunction
 
resetAccumulator(Row) - Method in class org.apache.flink.table.runtime.aggregate.GeneratedAggregations
Resets all the accumulators.
resetAllInputs() - Method in class org.apache.flink.runtime.operators.BatchTask
 
resetConstraints() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationGroup
Resets this co-location group, meaning that future calls to CoLocationGroup.getLocationConstraint(int) will give out new CoLocationConstraints.
resetContextEnvironment() - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Un-sets the context environment factory.
resetContextEnvironment() - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
 
resetContextEnvironments() - Static method in class org.apache.flink.api.java.ScalaShellRemoteEnvironment
 
resetContextEnvironments() - Static method in class org.apache.flink.api.java.ScalaShellRemoteStreamEnvironment
 
resetEndOfSuperstep() - Method in class org.apache.flink.runtime.iterative.task.SyncEventHandler
 
resetErrorStateAndParse(byte[], int, int, byte[], T) - Method in class org.apache.flink.types.parser.FieldParser
Parses the value of a field from the byte array, taking care of properly reset the state of this parser.
resetForNewExecution(long, long) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
resetForNewExecution(long, long) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
Archives the current Execution and creates a new Execution for this vertex.
resetLocal() - Method in interface org.apache.flink.api.common.accumulators.Accumulator
Reset the local value.
resetLocal() - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
 
resetLocal() - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
 
resetLocal() - Method in class org.apache.flink.api.common.accumulators.DoubleMaximum
 
resetLocal() - Method in class org.apache.flink.api.common.accumulators.DoubleMinimum
 
resetLocal() - Method in class org.apache.flink.api.common.accumulators.Histogram
 
resetLocal() - Method in class org.apache.flink.api.common.accumulators.IntCounter
 
resetLocal() - Method in class org.apache.flink.api.common.accumulators.IntMaximum
 
resetLocal() - Method in class org.apache.flink.api.common.accumulators.IntMinimum
 
resetLocal() - Method in class org.apache.flink.api.common.accumulators.ListAccumulator
 
resetLocal() - Method in class org.apache.flink.api.common.accumulators.LongCounter
 
resetLocal() - Method in class org.apache.flink.api.common.accumulators.LongMaximum
 
resetLocal() - Method in class org.apache.flink.api.common.accumulators.LongMinimum
 
resetLocal() - Method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
resetLocal() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
 
resetLocal() - Method in class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator.VectorAccumulator
 
resetLocal() - Method in class org.apache.flink.graph.asm.dataset.ChecksumHashCode.Checksum
 
resetOverflowBuckets() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
resets overflow bucket counters and returns freed memory and should only be used for resizing
resetParameters() - Method in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
Statements to be executed after writing a batch goes here.
resetParameters() - Method in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunctionByMillis
 
resetParserState() - Method in class org.apache.flink.types.parser.FieldParser
Reset the state of the parser.
resetRecordCounter() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
sets record counter to zero and should only be used on compaction partition
resetRWViews() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
resets read and write views and should only be used on compaction partition
resetSplitState() - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
Sets the state of the split to null.
ResettableDriver<S extends Function,OT> - Interface in org.apache.flink.runtime.operators
This interface marks a Driver as resettable, meaning that will reset part of their internal state but otherwise reuse existing data structures.
resettableInputs - Variable in class org.apache.flink.runtime.operators.BatchTask
The resettable inputs in the case where no temp barrier is needed.
ResettableIterator<E> - Interface in org.apache.flink.runtime.util
The resettable iterator is a specialization of the iterator, allowing to reset the iterator and re-retrieve elements.
ResettableMutableObjectIterator<E> - Interface in org.apache.flink.runtime.util
The resettable iterator is a specialization of the iterator, allowing to reset the iterator and re-retrieve elements.
ResettableValue<T extends Value> - Interface in org.apache.flink.types
 
Resolvable<T> - Interface in org.apache.flink.table.plan.logical
A class implementing this interface can resolve the expressions of its parameters and return a new instance with resolved parameters.
resolve(Path) - Method in interface org.apache.flink.mesos.util.MesosArtifactResolver
 
resolve(Path) - Method in class org.apache.flink.mesos.util.MesosArtifactServer
 
resolveClass(ObjectStreamClass) - Method in class org.apache.flink.migration.util.MigrationInstantiationUtil.ClassLoaderObjectInputStream
 
resolveClass(ObjectStreamClass) - Method in class org.apache.flink.util.InstantiationUtil.ClassLoaderObjectInputStream
 
resolveCompatibilityResult(TypeSerializer<?>, Class<?>, TypeSerializerConfigSnapshot, TypeSerializer<T>) - Static method in class org.apache.flink.api.common.typeutils.CompatibilityUtil
Resolves the final compatibility result of two serializers by taking into account compound information, including the preceding serializer, the preceding serializer's configuration snapshot, and the new serializer.
ResolvedFieldReference - Class in org.apache.flink.table.expressions
 
ResolvedFieldReference(String, TypeInformation<?>) - Constructor for class org.apache.flink.table.expressions.ResolvedFieldReference
 
ResolvedFieldReference$ - Class in org.apache.flink.table.expressions
 
ResolvedFieldReference$() - Constructor for class org.apache.flink.table.expressions.ResolvedFieldReference$
 
resolveExpressions(TableEnvironment) - Static method in class org.apache.flink.table.plan.logical.Aggregate
 
resolveExpressions(TableEnvironment) - Method in class org.apache.flink.table.plan.logical.AliasNode
 
resolveExpressions(TableEnvironment) - Static method in class org.apache.flink.table.plan.logical.CatalogNode
 
resolveExpressions(TableEnvironment) - Static method in class org.apache.flink.table.plan.logical.Distinct
 
resolveExpressions(TableEnvironment) - Static method in class org.apache.flink.table.plan.logical.Filter
 
resolveExpressions(TableEnvironment) - Static method in class org.apache.flink.table.plan.logical.Intersect
 
resolveExpressions(TableEnvironment) - Method in class org.apache.flink.table.plan.logical.Join
 
resolveExpressions(TableEnvironment) - Static method in class org.apache.flink.table.plan.logical.Limit
 
resolveExpressions(TableEnvironment) - Method in class org.apache.flink.table.plan.logical.LogicalNode
 
resolveExpressions(TableEnvironment) - Static method in class org.apache.flink.table.plan.logical.LogicalRelNode
 
resolveExpressions(TableEnvironment) - Static method in class org.apache.flink.table.plan.logical.LogicalTableFunctionCall
 
resolveExpressions(Function1<Expression, Expression>) - Method in class org.apache.flink.table.plan.logical.LogicalWindow
 
resolveExpressions(TableEnvironment) - Static method in class org.apache.flink.table.plan.logical.Minus
 
resolveExpressions(TableEnvironment) - Method in class org.apache.flink.table.plan.logical.Project
 
resolveExpressions(Function1<Expression, Expression>) - Method in interface org.apache.flink.table.plan.logical.Resolvable
An implementing class can resolve its expressions by applying the given resolver function on its parameters.
resolveExpressions(Function1<Expression, Expression>) - Method in class org.apache.flink.table.plan.logical.SessionGroupWindow
 
resolveExpressions(Function1<Expression, Expression>) - Method in class org.apache.flink.table.plan.logical.SlidingGroupWindow
 
resolveExpressions(TableEnvironment) - Static method in class org.apache.flink.table.plan.logical.Sort
 
resolveExpressions(Function1<Expression, Expression>) - Method in class org.apache.flink.table.plan.logical.TumblingGroupWindow
 
resolveExpressions(TableEnvironment) - Static method in class org.apache.flink.table.plan.logical.Union
 
resolveExpressions(TableEnvironment) - Static method in class org.apache.flink.table.plan.logical.WindowAggregate
 
resolveOverWindows(Seq<Expression>, OverWindow[], TableEnvironment) - Method in class org.apache.flink.table.plan.ProjectionTranslator$
 
resolveOverWindows(Seq<Expression>, OverWindow[], TableEnvironment) - Static method in class org.apache.flink.table.plan.ProjectionTranslator
 
resolveReference(TableEnvironment, String) - Static method in class org.apache.flink.table.plan.logical.Aggregate
 
resolveReference(TableEnvironment, String) - Static method in class org.apache.flink.table.plan.logical.AliasNode
 
resolveReference(TableEnvironment, String) - Static method in class org.apache.flink.table.plan.logical.CatalogNode
 
resolveReference(TableEnvironment, String) - Static method in class org.apache.flink.table.plan.logical.Distinct
 
resolveReference(TableEnvironment, String) - Static method in class org.apache.flink.table.plan.logical.Filter
 
resolveReference(TableEnvironment, String) - Static method in class org.apache.flink.table.plan.logical.Intersect
 
resolveReference(TableEnvironment, String) - Static method in class org.apache.flink.table.plan.logical.Join
 
resolveReference(TableEnvironment, String) - Static method in class org.apache.flink.table.plan.logical.Limit
 
resolveReference(TableEnvironment, String) - Method in class org.apache.flink.table.plan.logical.LogicalNode
Resolves the given strings to a NamedExpression using the input from all child nodes of this LogicalPlan.
resolveReference(TableEnvironment, String) - Static method in class org.apache.flink.table.plan.logical.LogicalRelNode
 
resolveReference(TableEnvironment, String) - Static method in class org.apache.flink.table.plan.logical.LogicalTableFunctionCall
 
resolveReference(TableEnvironment, String) - Static method in class org.apache.flink.table.plan.logical.Minus
 
resolveReference(TableEnvironment, String) - Static method in class org.apache.flink.table.plan.logical.Project
 
resolveReference(TableEnvironment, String) - Static method in class org.apache.flink.table.plan.logical.Sort
 
resolveReference(TableEnvironment, String) - Static method in class org.apache.flink.table.plan.logical.Union
 
resolveReference(TableEnvironment, String) - Method in class org.apache.flink.table.plan.logical.WindowAggregate
 
RESOURCE_MANAGER_IPC_PORT_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
The config parameter defining the network port to connect to for communication with the resource manager.
RESOURCE_MANAGER_NAME - Static variable in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
The default name of the resource manager actor
RESOURCE_MANAGER_NAME - Static variable in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
RESOURCE_MANAGER_RECONNECT_INTERVAL - Static variable in class org.apache.flink.configuration.JobManagerOptions
This option specifies the interval in order to trigger a resource manager reconnection if the connection to the resource manager has been lost.
resourceID() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
resourceId() - Method in class org.apache.flink.runtime.clusterframework.messages.RemoveResource
Gets the ID under which the resource is registered (for example container ID).
resourceId() - Method in class org.apache.flink.runtime.clusterframework.messages.ResourceRemoved
Gets the ID under which the resource is registered (for example container ID).
ResourceID - Class in org.apache.flink.runtime.clusterframework.types
Class for Resource Ids assigned at the FlinkResourceManager.
ResourceID(String) - Constructor for class org.apache.flink.runtime.clusterframework.types.ResourceID
 
resourceId() - Method in class org.apache.flink.runtime.messages.RegistrationMessages.RegisterTaskManager
 
resourceID() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
 
resourceID() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
ResourceIDRetrievable - Interface in org.apache.flink.runtime.clusterframework.types
An interface to retrieve the ResourceID of an object.
resourceManager() - Method in class org.apache.flink.runtime.clusterframework.messages.ReconnectResourceManager
 
resourceManager() - Method in class org.apache.flink.runtime.clusterframework.messages.RegisterResourceManager
 
ResourceManager<WorkerType extends Serializable> - Class in org.apache.flink.runtime.resourcemanager
ResourceManager implementation.
ResourceManager(RpcService, String, ResourceID, ResourceManagerConfiguration, HighAvailabilityServices, HeartbeatServices, SlotManager, MetricRegistry, JobLeaderIdService, FatalErrorHandler) - Constructor for class org.apache.flink.runtime.resourcemanager.ResourceManager
 
ResourceManagerActions - Interface in org.apache.flink.runtime.resourcemanager.slotmanager
 
resourceManagerActors() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
resourceManagerActorSystems() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
resourceManagerClass() - Method in class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
ResourceManagerConfiguration - Class in org.apache.flink.runtime.resourcemanager
Resource manager configuration
ResourceManagerConfiguration(Time, Time) - Constructor for class org.apache.flink.runtime.resourcemanager.ResourceManagerConfiguration
 
ResourceManagerException - Exception in org.apache.flink.runtime.resourcemanager.exceptions
Base class for ResourceManager exceptions.
ResourceManagerException(String) - Constructor for exception org.apache.flink.runtime.resourcemanager.exceptions.ResourceManagerException
 
ResourceManagerException(String, Throwable) - Constructor for exception org.apache.flink.runtime.resourcemanager.exceptions.ResourceManagerException
 
ResourceManagerException(Throwable) - Constructor for exception org.apache.flink.runtime.resourcemanager.exceptions.ResourceManagerException
 
ResourceManagerGateway - Interface in org.apache.flink.runtime.resourcemanager
The ResourceManager's RPC gateway interface.
ResourceManagerOptions - Class in org.apache.flink.configuration
The set of configuration options relating to the ResourceManager
ResourceManagerRunner - Class in org.apache.flink.runtime.resourcemanager
ResourceManagerRunner(ResourceID, String, Configuration, RpcService, HighAvailabilityServices, HeartbeatServices, MetricRegistry) - Constructor for class org.apache.flink.runtime.resourcemanager.ResourceManagerRunner
 
ResourceManagerRuntimeServices - Class in org.apache.flink.runtime.resourcemanager
Container class for the ResourceManager services.
ResourceManagerRuntimeServices(SlotManager, JobLeaderIdService) - Constructor for class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServices
 
ResourceManagerRuntimeServicesConfiguration - Class in org.apache.flink.runtime.resourcemanager
Configuration class for the ResourceManagerRuntimeServices class.
ResourceManagerRuntimeServicesConfiguration(Time, SlotManagerConfiguration) - Constructor for class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServicesConfiguration
 
ResourceManagerServices - Interface in org.apache.flink.runtime.resourcemanager
Interface which provides access to services of the ResourceManager.
ResourceOffers - Class in org.apache.flink.mesos.scheduler.messages
Message sent by the callback handler to the scheduler actor when resources have been offered to this framework.
ResourceOffers(List<Protos.Offer>) - Constructor for class org.apache.flink.mesos.scheduler.messages.ResourceOffers
 
resourceOffers(SchedulerDriver, List<Protos.Offer>) - Method in class org.apache.flink.mesos.scheduler.SchedulerProxy
 
ResourceProfile - Class in org.apache.flink.runtime.clusterframework.types
Describe the resource profile of the slot, either when requiring or offering it.
ResourceProfile(double, int, int, int) - Constructor for class org.apache.flink.runtime.clusterframework.types.ResourceProfile
Creates a new ResourceProfile.
ResourceProfile(double, int) - Constructor for class org.apache.flink.runtime.clusterframework.types.ResourceProfile
Creates a new simple ResourceProfile used for testing.
ResourceProfile(ResourceProfile) - Constructor for class org.apache.flink.runtime.clusterframework.types.ResourceProfile
Creates a copy of the given ResourceProfile.
ResourceRemoved - Class in org.apache.flink.runtime.clusterframework.messages
Message sent to the JobManager by the Resource Manager to inform about the removal of a resource.
ResourceRemoved(ResourceID, String) - Constructor for class org.apache.flink.runtime.clusterframework.messages.ResourceRemoved
Constructor for a shutdown of a registered resource.
resources() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
resources() - Method in class org.apache.flink.runtime.messages.RegistrationMessages.RegisterTaskManager
 
resources() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
The TaskManager's physical execution resources
resources() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
ResourceSpec - Class in org.apache.flink.api.common.operators
Describe the different resource factors of the operator with UDF.
ResourceSpec(double, int) - Constructor for class org.apache.flink.api.common.operators.ResourceSpec
Creates a new ResourceSpec with basic common resources.
ResourceSpec(double, int, int, int, int) - Constructor for class org.apache.flink.api.common.operators.ResourceSpec
Creates a new ResourceSpec with full resources.
respondAsLeader(ChannelHandlerContext, Routed, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.handlers.TaskManagerLogHandler
Response when running with leading JobManager.
respondAsLeader(ChannelHandlerContext, Routed, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.RuntimeMonitorHandler
 
respondAsLeader(ChannelHandlerContext, Routed, ActorGateway) - Method in class org.apache.flink.runtime.webmonitor.RuntimeMonitorHandlerBase
 
ResponseArchive(ActorRef) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.ResponseArchive
 
ResponseArchive$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.ResponseArchive$
 
ResponseBroadcastVariablesWithReferences(int) - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages.ResponseBroadcastVariablesWithReferences
 
ResponseBroadcastVariablesWithReferences$() - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages.ResponseBroadcastVariablesWithReferences$
 
ResponseLeaderSessionID(UUID) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.ResponseLeaderSessionID
 
ResponseLeaderSessionID$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.ResponseLeaderSessionID$
 
ResponseNumActiveConnections(int) - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages.ResponseNumActiveConnections
 
ResponseNumActiveConnections$() - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages.ResponseNumActiveConnections$
 
ResponseWebMonitorPort(Integer) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.ResponseWebMonitorPort
 
ResponseWebMonitorPort$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.ResponseWebMonitorPort$
 
restart(long) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
restart(RestartCallback, ScheduledExecutor) - Method in class org.apache.flink.runtime.executiongraph.restart.FailureRateRestartStrategy
 
restart(RestartCallback, ScheduledExecutor) - Method in class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
 
restart(RestartCallback, ScheduledExecutor) - Method in class org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy
 
restart(RestartCallback, ScheduledExecutor) - Method in interface org.apache.flink.runtime.executiongraph.restart.RestartStrategy
Called by the ExecutionGraph to eventually trigger a full recovery.
RESTART_STRATEGY - Static variable in class org.apache.flink.configuration.ConfigConstants
Defines the restart strategy to be used.
RESTART_STRATEGY_FAILURE_RATE_DELAY - Static variable in class org.apache.flink.configuration.ConfigConstants
Delay between two consecutive restart attempts in FailureRateRestartStrategy.
RESTART_STRATEGY_FAILURE_RATE_FAILURE_RATE_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
Time interval in which greater amount of failures than ConfigConstants.RESTART_STRATEGY_FAILURE_RATE_MAX_FAILURES_PER_INTERVAL causes job fail in FailureRateRestartStrategy.
RESTART_STRATEGY_FAILURE_RATE_MAX_FAILURES_PER_INTERVAL - Static variable in class org.apache.flink.configuration.ConfigConstants
Maximum number of restarts in given time interval ConfigConstants.RESTART_STRATEGY_FAILURE_RATE_FAILURE_RATE_INTERVAL before failing a job in FailureRateRestartStrategy.
RESTART_STRATEGY_FIXED_DELAY_ATTEMPTS - Static variable in class org.apache.flink.configuration.ConfigConstants
Maximum number of attempts the fixed delay restart strategy will try before failing a job.
RESTART_STRATEGY_FIXED_DELAY_DELAY - Static variable in class org.apache.flink.configuration.ConfigConstants
Delay between two consecutive restart attempts in FixedDelayRestartStrategy.
RestartAllStrategy - Class in org.apache.flink.runtime.executiongraph.failover
Simple failover strategy that triggers a restart of all tasks in the execution graph, via ExecutionGraph.failGlobal(Throwable).
RestartAllStrategy(ExecutionGraph) - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartAllStrategy
Creates a new failover strategy that recovers from failures by restarting all tasks of the execution graph.
RestartAllStrategy.Factory - Class in org.apache.flink.runtime.executiongraph.failover
Factory that instantiates the RestartAllStrategy.
RestartCallback - Interface in org.apache.flink.runtime.executiongraph.restart
A callback to trigger restarts, passed to the RestartStrategy to trigger recovery on the ExecutionGraph.
RestartIndividualStrategy - Class in org.apache.flink.runtime.executiongraph.failover
Simple failover strategy that restarts each task individually.
RestartIndividualStrategy(ExecutionGraph) - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy
Creates a new failover strategy that recovers from failures by restarting only the failed task of the execution graph.
RestartIndividualStrategy(ExecutionGraph, Executor) - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartIndividualStrategy
Creates a new failover strategy that recovers from failures by restarting only the failed task of the execution graph.
RestartIndividualStrategy.Factory - Class in org.apache.flink.runtime.executiongraph.failover
Factory that instantiates the RestartAllStrategy.
RestartPipelinedRegionStrategy - Class in org.apache.flink.runtime.executiongraph.failover
A failover strategy that restarts regions of the ExecutionGraph.
RestartPipelinedRegionStrategy(ExecutionGraph) - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy
Creates a new failover strategy to restart pipelined regions that works on the given execution graph and uses the execution graph's future executor to call restart actions.
RestartPipelinedRegionStrategy(ExecutionGraph, Executor) - Constructor for class org.apache.flink.runtime.executiongraph.failover.RestartPipelinedRegionStrategy
Creates a new failover strategy to restart pipelined regions that works on the given execution graph and uses the given executor to call restart actions.
RestartPipelinedRegionStrategy.Factory - Class in org.apache.flink.runtime.executiongraph.failover
Factory that instantiates the RestartPipelinedRegionStrategy.
RestartStrategies - Class in org.apache.flink.api.common.restartstrategy
This class defines methods to generate RestartStrategyConfigurations.
RestartStrategies() - Constructor for class org.apache.flink.api.common.restartstrategy.RestartStrategies
 
RestartStrategies.FailureRateRestartStrategyConfiguration - Class in org.apache.flink.api.common.restartstrategy
 
RestartStrategies.FallbackRestartStrategyConfiguration - Class in org.apache.flink.api.common.restartstrategy
Restart strategy configuration that could be used by jobs to use cluster level restart strategy.
RestartStrategies.FixedDelayRestartStrategyConfiguration - Class in org.apache.flink.api.common.restartstrategy
 
RestartStrategies.NoRestartStrategyConfiguration - Class in org.apache.flink.api.common.restartstrategy
 
RestartStrategies.RestartStrategyConfiguration - Class in org.apache.flink.api.common.restartstrategy
 
RestartStrategy - Interface in org.apache.flink.runtime.executiongraph.restart
Strategy for ExecutionGraph restarts.
RestartStrategyFactory - Class in org.apache.flink.runtime.executiongraph.restart
 
RestartStrategyFactory() - Constructor for class org.apache.flink.runtime.executiongraph.restart.RestartStrategyFactory
 
restartStrategyFactory() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
restartStrategyFactory - Variable in class org.apache.flink.runtime.jobmaster.JobManagerServices
 
RestartTimeGauge - Class in org.apache.flink.runtime.executiongraph.metrics
Gauge which returns the last restarting time.
RestartTimeGauge(ExecutionGraph) - Constructor for class org.apache.flink.runtime.executiongraph.metrics.RestartTimeGauge
 
restore(Collection<KeyedStateHandle>) - Method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
 
restore(Collection<OperatorStateHandle>) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
 
restore(Collection<KeyedStateHandle>) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
restore(Collection<S>) - Method in interface org.apache.flink.runtime.state.Snapshotable
Restores state that was previously snapshotted from the provided parameters.
restoreCheckpoint(long, T) - Method in interface org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook
This method is called by the checkpoint coordinator prior to restoring the state of a checkpoint.
RestoredCheckpointStats - Class in org.apache.flink.runtime.checkpoint
Statistics for a restored checkpoint.
restoreFunctionState(StateInitializationContext, Function) - Static method in class org.apache.flink.streaming.util.functions.StreamingFunctionUtils
 
restoreLatestCheckpointedState(Map<JobVertexID, ExecutionJobVertex>, boolean, boolean) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Restores the latest checkpointed state.
restoreLatestCheckpointedState(boolean, boolean) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Restores the latest checkpointed state.
restoreMasterHooks(Map<String, MasterTriggerRestoreHook<?>>, Collection<MasterState>, long, boolean, Logger) - Static method in class org.apache.flink.runtime.checkpoint.hooks.MasterHooks
Calls the restore method given checkpoint master hooks and passes the given master state to them where state with a matching name is found.
restoreSavepoint(String, boolean, Map<JobVertexID, ExecutionJobVertex>, ClassLoader) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Restore the state with given savepoint
restoreSavepoint() - Method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
Returns whether to restore from savepoint.
restoreState(FSDataInputStream) - Method in class org.apache.flink.cep.operator.AbstractKeyedCEPPatternOperator
 
restoreState(T) - Method in interface org.apache.flink.streaming.api.checkpoint.CheckpointedRestoring
Deprecated.
Restores the state of the function or operator to that of a previous checkpoint.
restoreState(List<T>) - Method in interface org.apache.flink.streaming.api.checkpoint.ListCheckpointed
Restores the state of the function or operator to that of a previous checkpoint.
restoreState(Long) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
 
restoreState(FSDataInputStream) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
 
restoreState(FSDataInputStream) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
restoreState(FSDataInputStream) - Method in interface org.apache.flink.streaming.api.operators.CheckpointedRestoringOperator
Deprecated.
Restores the operator state, if this operator's execution is recovering from a checkpoint.
restoreState(RollingSink.BucketState) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
 
restoreState(RollingSink.BucketState) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
Deprecated.
 
restoreState(HashMap<KafkaTopicPartition, Long>) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
 
restoreState(FSDataInputStream) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
Deprecated.
 
restoreState(FSDataInputStream) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
restoreTimersForKeyGroup(DataInputViewStreamWrapper, int, ClassLoader) - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
Restore the timers (both processing and event time ones) for a given keyGroupIdx.
result() - Method in interface org.apache.flink.api.java.summarize.aggregation.Aggregator
Provide the final result of the aggregation
result() - Method in class org.apache.flink.api.java.summarize.aggregation.BooleanSummaryAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MaxDoubleAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.MinDoubleAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.SumDoubleAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MaxFloatAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.MinFloatAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.SumFloatAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MaxIntegerAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.MinIntegerAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.SumIntegerAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MaxLongAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.MinLongAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.SumLongAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.NumericSummaryAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.ObjectSummaryAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MaxShortAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.MinShortAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.SumShortAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.StringSummaryAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.TupleSummaryAggregator
 
result() - Method in class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator
 
Result(long, double) - Constructor for class org.apache.flink.graph.library.clustering.directed.AverageClusteringCoefficient.Result
Instantiate an immutable result.
Result(long, long) - Constructor for class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient.Result
Instantiate an immutable result.
Result() - Constructor for class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient.Result
 
Result(BigInteger...) - Constructor for class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
 
Result(long...) - Constructor for class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
 
Result() - Constructor for class org.apache.flink.graph.library.clustering.directed.TriangleListing.Result
No-args constructor.
Result(long, double) - Constructor for class org.apache.flink.graph.library.clustering.undirected.AverageClusteringCoefficient.Result
Instantiate an immutable result.
Result(long, long) - Constructor for class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient.Result
Instantiate an immutable result.
Result() - Constructor for class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient.Result
 
Result(BigInteger...) - Constructor for class org.apache.flink.graph.library.clustering.undirected.TriadicCensus.Result
 
Result(long...) - Constructor for class org.apache.flink.graph.library.clustering.undirected.TriadicCensus.Result
 
Result() - Constructor for class org.apache.flink.graph.library.clustering.undirected.TriangleListing.Result
 
Result() - Constructor for class org.apache.flink.graph.library.link_analysis.HITS.Result
 
Result() - Constructor for class org.apache.flink.graph.library.link_analysis.PageRank.Result
 
Result(long, long, long, long) - Constructor for class org.apache.flink.graph.library.metric.directed.EdgeMetrics.Result
 
Result(long, long, long, long, long, long, long, long) - Constructor for class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
 
Result(long, long, long, long) - Constructor for class org.apache.flink.graph.library.metric.undirected.EdgeMetrics.Result
 
Result(long, long, long, long, long) - Constructor for class org.apache.flink.graph.library.metric.undirected.VertexMetrics.Result
 
Result() - Constructor for class org.apache.flink.graph.library.similarity.AdamicAdar.Result
No-args constructor.
Result() - Constructor for class org.apache.flink.graph.library.similarity.JaccardIndex.Result
 
result() - Method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultsFound
 
result() - Method in class org.apache.flink.runtime.messages.accumulators.AccumulatorResultStringsFound
 
result() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.JobResultSuccess
 
Result(StreamStateHandle, int) - Constructor for class org.apache.flink.runtime.state.SharedStateRegistry.Result
 
RESULTED_NUMBER_OF_TRIANGLES - Static variable in class org.apache.flink.graph.examples.data.TriangleCountData
 
RESULTED_SINGLE_SOURCE_SHORTEST_PATHS - Static variable in class org.apache.flink.graph.examples.data.SingleSourceShortestPathsData
 
RESULTED_VERTICES - Static variable in class org.apache.flink.graph.examples.data.IncrementalSSSPData
 
RESULTED_WEIGHTED_EDGES - Static variable in class org.apache.flink.graph.examples.data.EuclideanGraphData
 
resultHandler - Variable in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousFileIOChannel
Handler for completed requests
resultId() - Method in class org.apache.flink.runtime.messages.TaskMessages.UpdateTaskSinglePartitionInfo
 
ResultPartition - Class in org.apache.flink.runtime.io.network.partition
A result partition for data produced by a single task.
ResultPartition(String, TaskActions, JobID, ResultPartitionID, ResultPartitionType, int, int, ResultPartitionManager, ResultPartitionConsumableNotifier, IOManager, boolean) - Constructor for class org.apache.flink.runtime.io.network.partition.ResultPartition
 
ResultPartitionConsumableNotifier - Interface in org.apache.flink.runtime.io.network.partition
 
ResultPartitionDeploymentDescriptor - Class in org.apache.flink.runtime.deployment
Deployment descriptor for a result partition.
ResultPartitionDeploymentDescriptor(IntermediateDataSetID, IntermediateResultPartitionID, ResultPartitionType, int, int, boolean) - Constructor for class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
 
ResultPartitionID - Class in org.apache.flink.runtime.io.network.partition
Runtime identifier of a produced IntermediateResultPartition.
ResultPartitionID() - Constructor for class org.apache.flink.runtime.io.network.partition.ResultPartitionID
 
ResultPartitionID(IntermediateResultPartitionID, ExecutionAttemptID) - Constructor for class org.apache.flink.runtime.io.network.partition.ResultPartitionID
 
resultPartitionId() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RequestPartitionProducerState
 
ResultPartitionLocation - Class in org.apache.flink.runtime.deployment
Location of a result partition from the perspective of the consuming task.
ResultPartitionManager - Class in org.apache.flink.runtime.io.network.partition
The result partition manager keeps track of all currently produced/consumed partitions of a task manager.
ResultPartitionManager() - Constructor for class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
 
ResultPartitionMetrics - Class in org.apache.flink.runtime.io.network.partition
Collects metrics of a result partition.
ResultPartitionProvider - Interface in org.apache.flink.runtime.io.network.partition
 
ResultPartitionType - Enum in org.apache.flink.runtime.io.network.partition
 
ResultPartitionWriter - Class in org.apache.flink.runtime.io.network.api.writer
A buffer-oriented runtime result writer.
ResultPartitionWriter(ResultPartition) - Constructor for class org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
 
RESULTS - Static variable in class org.apache.flink.streaming.examples.iteration.util.IterateExampleData
 
RESULTS - Static variable in class org.apache.flink.streaming.examples.ml.util.IncrementalLearningSkeletonData
 
resultScanner - Variable in class org.apache.flink.addons.hbase.AbstractTableInputFormat
HBase iterator wrapper
ResultSubpartition - Class in org.apache.flink.runtime.io.network.partition
A single subpartition of a ResultPartition instance.
ResultSubpartition(int, ResultPartition) - Constructor for class org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
ResultSubpartitionView - Interface in org.apache.flink.runtime.io.network.partition
A view to consume a ResultSubpartition instance.
resultTerm() - Method in class org.apache.flink.table.codegen.GeneratedExpression
 
resultType() - Method in class org.apache.flink.table.api.CurrentRange
 
resultType() - Method in class org.apache.flink.table.api.CurrentRow
 
resultType() - Method in class org.apache.flink.table.api.UnboundedRange
 
resultType() - Method in class org.apache.flink.table.api.UnboundedRow
 
resultType() - Method in class org.apache.flink.table.codegen.GeneratedExpression
 
resultType() - Method in class org.apache.flink.table.expressions.Abs
 
resultType() - Method in class org.apache.flink.table.expressions.Acos
 
resultType() - Method in class org.apache.flink.table.expressions.AggFunctionCall
 
resultType() - Method in class org.apache.flink.table.expressions.Alias
 
resultType() - Static method in class org.apache.flink.table.expressions.And
 
resultType() - Method in class org.apache.flink.table.expressions.ArrayCardinality
 
resultType() - Method in class org.apache.flink.table.expressions.ArrayConstructor
 
resultType() - Method in class org.apache.flink.table.expressions.ArrayElement
 
resultType() - Method in class org.apache.flink.table.expressions.ArrayElementAt
 
resultType() - Method in class org.apache.flink.table.expressions.Asc
 
resultType() - Method in class org.apache.flink.table.expressions.Asin
 
resultType() - Method in class org.apache.flink.table.expressions.Atan
 
resultType() - Method in class org.apache.flink.table.expressions.Avg
 
resultType() - Method in class org.apache.flink.table.expressions.BinaryArithmetic
 
resultType() - Method in class org.apache.flink.table.expressions.BinaryComparison
 
resultType() - Method in class org.apache.flink.table.expressions.BinaryPredicate
 
resultType() - Method in class org.apache.flink.table.expressions.Call
 
resultType() - Method in class org.apache.flink.table.expressions.Cast
 
resultType() - Method in class org.apache.flink.table.expressions.Ceil
 
resultType() - Method in class org.apache.flink.table.expressions.CharLength
 
resultType() - Method in class org.apache.flink.table.expressions.Cos
 
resultType() - Method in class org.apache.flink.table.expressions.Cot
 
resultType() - Method in class org.apache.flink.table.expressions.Count
 
resultType() - Static method in class org.apache.flink.table.expressions.CurrentDate
 
resultType() - Static method in class org.apache.flink.table.expressions.CurrentTime
 
resultType() - Method in class org.apache.flink.table.expressions.CurrentTimePoint
 
resultType() - Static method in class org.apache.flink.table.expressions.CurrentTimestamp
 
resultType() - Method in class org.apache.flink.table.expressions.Degrees
 
resultType() - Method in class org.apache.flink.table.expressions.Desc
 
resultType() - Static method in class org.apache.flink.table.expressions.Div
 
resultType() - Static method in class org.apache.flink.table.expressions.EqualTo
 
resultType() - Method in class org.apache.flink.table.expressions.Exp
 
resultType() - Method in class org.apache.flink.table.expressions.Expression
Returns the TypeInformation for evaluating this expression.
resultType() - Method in class org.apache.flink.table.expressions.Extract
 
resultType() - Method in class org.apache.flink.table.expressions.Flattening
 
resultType() - Method in class org.apache.flink.table.expressions.Floor
 
resultType() - Method in class org.apache.flink.table.expressions.GetCompositeField
 
resultType() - Static method in class org.apache.flink.table.expressions.GreaterThan
 
resultType() - Static method in class org.apache.flink.table.expressions.GreaterThanOrEqual
 
resultType() - Method in class org.apache.flink.table.expressions.If
 
resultType() - Method in class org.apache.flink.table.expressions.InitCap
 
resultType() - Method in class org.apache.flink.table.expressions.IsFalse
 
resultType() - Method in class org.apache.flink.table.expressions.IsNotFalse
 
resultType() - Method in class org.apache.flink.table.expressions.IsNotNull
 
resultType() - Method in class org.apache.flink.table.expressions.IsNotTrue
 
resultType() - Method in class org.apache.flink.table.expressions.IsNull
 
resultType() - Method in class org.apache.flink.table.expressions.IsTrue
 
resultType() - Static method in class org.apache.flink.table.expressions.LessThan
 
resultType() - Static method in class org.apache.flink.table.expressions.LessThanOrEqual
 
resultType() - Method in class org.apache.flink.table.expressions.Like
 
resultType() - Method in class org.apache.flink.table.expressions.Literal
 
resultType() - Method in class org.apache.flink.table.expressions.Ln
 
resultType() - Static method in class org.apache.flink.table.expressions.LocalTime
 
resultType() - Static method in class org.apache.flink.table.expressions.LocalTimestamp
 
resultType() - Method in class org.apache.flink.table.expressions.Log10
 
resultType() - Method in class org.apache.flink.table.expressions.Lower
 
resultType() - Method in class org.apache.flink.table.expressions.Max
 
resultType() - Method in class org.apache.flink.table.expressions.Min
 
resultType() - Static method in class org.apache.flink.table.expressions.Minus
 
resultType() - Static method in class org.apache.flink.table.expressions.Mod
 
resultType() - Static method in class org.apache.flink.table.expressions.Mul
 
resultType() - Method in class org.apache.flink.table.expressions.Not
 
resultType() - Static method in class org.apache.flink.table.expressions.NotEqualTo
 
resultType() - Method in class org.apache.flink.table.expressions.Null
 
resultType() - Static method in class org.apache.flink.table.expressions.Or
 
resultType() - Method in class org.apache.flink.table.expressions.OverCall
 
resultType() - Method in class org.apache.flink.table.expressions.Overlay
 
resultType() - Method in class org.apache.flink.table.expressions.Pi
 
resultType() - Static method in class org.apache.flink.table.expressions.Plus
 
resultType() - Method in class org.apache.flink.table.expressions.Position
 
resultType() - Method in class org.apache.flink.table.expressions.Power
 
resultType() - Method in class org.apache.flink.table.expressions.ProctimeAttribute
 
resultType() - Method in class org.apache.flink.table.expressions.Quarter
 
resultType() - Method in class org.apache.flink.table.expressions.Radians
 
resultType() - Method in class org.apache.flink.table.expressions.ResolvedFieldReference
 
resultType() - Method in class org.apache.flink.table.expressions.Round
 
resultType() - Method in class org.apache.flink.table.expressions.RowtimeAttribute
 
resultType() - Method in class org.apache.flink.table.expressions.ScalarFunctionCall
 
resultType() - Method in class org.apache.flink.table.expressions.Sign
 
resultType() - Method in class org.apache.flink.table.expressions.Similar
 
resultType() - Method in class org.apache.flink.table.expressions.Sin
 
resultType() - Method in class org.apache.flink.table.expressions.Sqrt
 
resultType() - Method in class org.apache.flink.table.expressions.StddevPop
 
resultType() - Method in class org.apache.flink.table.expressions.StddevSamp
 
resultType() - Method in class org.apache.flink.table.expressions.Substring
 
resultType() - Method in class org.apache.flink.table.expressions.Sum
 
resultType() - Method in class org.apache.flink.table.expressions.Sum0
 
resultType() - Method in class org.apache.flink.table.expressions.SymbolExpression
 
resultType() - Method in class org.apache.flink.table.expressions.TableFunctionCall
 
resultType() - Method in class org.apache.flink.table.expressions.Tan
 
resultType() - Static method in class org.apache.flink.table.expressions.TemporalCeil
 
resultType() - Method in class org.apache.flink.table.expressions.TemporalCeilFloor
 
resultType() - Static method in class org.apache.flink.table.expressions.TemporalFloor
 
resultType() - Method in class org.apache.flink.table.expressions.TemporalOverlaps
 
resultType() - Method in class org.apache.flink.table.expressions.Trim
 
resultType() - Method in class org.apache.flink.table.expressions.UnaryMinus
 
resultType() - Method in class org.apache.flink.table.expressions.UnresolvedAlias
 
resultType() - Method in class org.apache.flink.table.expressions.UnresolvedFieldReference
 
resultType() - Method in class org.apache.flink.table.expressions.UnresolvedOverCall
 
resultType() - Method in class org.apache.flink.table.expressions.Upper
 
resultType() - Method in class org.apache.flink.table.expressions.VarPop
 
resultType() - Method in class org.apache.flink.table.expressions.VarSamp
 
resultType() - Method in class org.apache.flink.table.expressions.WindowEnd
 
resultType() - Method in interface org.apache.flink.table.expressions.WindowProperty
 
resultType() - Method in class org.apache.flink.table.expressions.WindowReference
 
resultType() - Method in class org.apache.flink.table.expressions.WindowStart
 
resultType() - Method in class org.apache.flink.table.plan.logical.LogicalTableFunctionCall
 
resultTypeConvert(BigInteger) - Method in class org.apache.flink.table.functions.aggfunctions.BigIntegralAvgAggFunction
Convert the intermediate result to the expected aggregation result type
resultTypeConvert(long) - Method in class org.apache.flink.table.functions.aggfunctions.ByteAvgAggFunction
 
resultTypeConvert(double) - Method in class org.apache.flink.table.functions.aggfunctions.DoubleAvgAggFunction
 
resultTypeConvert(double) - Method in class org.apache.flink.table.functions.aggfunctions.FloatAvgAggFunction
 
resultTypeConvert(double) - Method in class org.apache.flink.table.functions.aggfunctions.FloatingAvgAggFunction
Convert the intermediate result to the expected aggregation result type
resultTypeConvert(long) - Method in class org.apache.flink.table.functions.aggfunctions.IntAvgAggFunction
 
resultTypeConvert(long) - Method in class org.apache.flink.table.functions.aggfunctions.IntegralAvgAggFunction
Convert the intermediate result to the expected aggregation result type
resultTypeConvert(BigInteger) - Method in class org.apache.flink.table.functions.aggfunctions.LongAvgAggFunction
 
resultTypeConvert(long) - Method in class org.apache.flink.table.functions.aggfunctions.ShortAvgAggFunction
 
ResultTypeQueryable<T> - Interface in org.apache.flink.api.java.typeutils
This interface can be implemented by functions and input formats to tell the framework about their produced data type.
retain() - Method in class org.apache.flink.runtime.io.network.buffer.Buffer
 
retainAll(Collection<?>) - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
retainAll(Collection<?>) - Method in class org.apache.flink.types.ListValue
 
rethrow(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
Throws the given Throwable in scenarios where the signatures do not allow you to throw an arbitrary Throwable.
rethrow(Throwable, String) - Static method in class org.apache.flink.util.ExceptionUtils
Throws the given Throwable in scenarios where the signatures do not allow you to throw an arbitrary Throwable.
rethrowException(Throwable, String) - Static method in class org.apache.flink.util.ExceptionUtils
Throws the given Throwable in scenarios where the signatures do allow to throw a Exception.
rethrowIfFatalError(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
Rethrows the given Throwable, if it represents an error that is fatal to the JVM.
rethrowIfFatalErrorOrOOM(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
Rethrows the given Throwable, if it represents an error that is fatal to the JVM or an out-of-memory error.
rethrowIOException(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
Re-throws the given Throwable in scenarios where the signatures allows only IOExceptions (and RuntimeException and Error).
retireWindow(W) - Method in class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
Removes the given window from the set of in-flight windows.
retract(BigIntegralAvgAccumulator, Object) - Method in class org.apache.flink.table.functions.aggfunctions.BigIntegralAvgAggFunction
 
retract(CountAccumulator, Object) - Method in class org.apache.flink.table.functions.aggfunctions.CountAggFunction
 
retract(DecimalAvgAccumulator, Object) - Method in class org.apache.flink.table.functions.aggfunctions.DecimalAvgAggFunction
 
retract(DecimalSumWithRetractAccumulator, Object) - Method in class org.apache.flink.table.functions.aggfunctions.DecimalSumWithRetractAggFunction
 
retract(FloatingAvgAccumulator, Object) - Method in class org.apache.flink.table.functions.aggfunctions.FloatingAvgAggFunction
 
retract(IntegralAvgAccumulator, Object) - Method in class org.apache.flink.table.functions.aggfunctions.IntegralAvgAggFunction
 
retract(MaxWithRetractAccumulator<T>, Object) - Method in class org.apache.flink.table.functions.aggfunctions.MaxWithRetractAggFunction
 
retract(MinWithRetractAccumulator<T>, Object) - Method in class org.apache.flink.table.functions.aggfunctions.MinWithRetractAggFunction
 
retract(SumWithRetractAccumulator<T>, Object) - Method in class org.apache.flink.table.functions.aggfunctions.SumWithRetractAggFunction
 
retract(Row, Row) - Method in class org.apache.flink.table.runtime.aggregate.GeneratedAggregations
Retracts the input values from the accumulators.
RetractStreamTableSink<T> - Interface in org.apache.flink.table.sinks
Defines an external TableSink to emit a streaming Table with insert, update, and delete changes.
retries() - Method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator.ReconciliationData
 
RetrievableStateHandle<T extends Serializable> - Interface in org.apache.flink.runtime.state
Handle to state that can be read back again via RetrievableStateHandle.retrieveState().
RetrievableStateStorageHelper<T extends Serializable> - Interface in org.apache.flink.runtime.zookeeper
State storage helper which is used by ZooKeeperStateHandleStore to persist state before the state handle is written to ZooKeeper.
RetrievableStreamStateHandle<T extends Serializable> - Class in org.apache.flink.runtime.state
Wrapper around a StreamStateHandle to make the referenced state object retrievable trough a simple get call.
RetrievableStreamStateHandle(StreamStateHandle) - Constructor for class org.apache.flink.runtime.state.RetrievableStreamStateHandle
 
RetrievableStreamStateHandle(Path, long) - Constructor for class org.apache.flink.runtime.state.RetrievableStreamStateHandle
 
retrieve(String) - Method in interface org.apache.flink.client.deployment.ClusterDescriptor
Retrieves an existing Flink Cluster.
retrieve(String) - Method in class org.apache.flink.client.deployment.StandaloneClusterDescriptor
 
retrieve(String) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
 
retrieveClassLoader(JobID, ActorGateway, Configuration, HighAvailabilityServices) - Static method in class org.apache.flink.runtime.client.JobClient
Reconstructs the class loader by first requesting information about it at the JobManager and then downloading missing jar files.
retrieveClient(CommandLineOptions) - Method in class org.apache.flink.client.CliFrontend
Updates the associated configuration with the given command line options
retrieveCluster(CommandLine, Configuration) - Method in interface org.apache.flink.client.cli.CustomCommandLine
Retrieves a client for a running cluster
retrieveCluster(CommandLine, Configuration) - Method in class org.apache.flink.client.cli.DefaultCLI
 
retrieveCluster(CommandLine, Configuration) - Method in class org.apache.flink.yarn.cli.FlinkYarnCLI
 
retrieveCluster(CommandLine, Configuration) - Method in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
 
retrieveJob(JobID) - Method in class org.apache.flink.client.program.ClusterClient
Reattaches to a running from from the supplied job id
retrieveLeaderConnectionInfo(LeaderRetrievalService, FiniteDuration) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
Retrieves the leader akka url and the current leader session ID.
retrieveLeaderGateway(LeaderRetrievalService, ActorSystem, FiniteDuration) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
Retrieves the current leader gateway using the given LeaderRetrievalService.
retrieveLeaderSessionId(LeaderRetrievalService, FiniteDuration) - Static method in class org.apache.flink.runtime.util.LeaderRetrievalUtils
Retrieves the current leader session id of the component identified by the given leader retrieval service.
retrievePayload() - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatListener
Retrieves the payload value for the next heartbeat message.
retrieveState() - Method in interface org.apache.flink.runtime.state.RetrievableStateHandle
Retrieves the object that was previously written to state.
retrieveState() - Method in class org.apache.flink.runtime.state.RetrievableStreamStateHandle
 
retriggerPartitionRequest(IntermediateResultPartitionID) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
Retriggers a partition request.
retry(Function0<T>, int, ExecutionContext) - Method in class org.apache.flink.runtime.akka.AkkaUtils$
Utility function to construct a future which tries multiple times to execute itself if it fails.
retry(Callable<T>, int, ExecutionContext) - Method in class org.apache.flink.runtime.akka.AkkaUtils$
Utility function to construct a future which tries multiple times to execute itself if it fails.
retry(ActorRef, Object, int, ExecutionContext, FiniteDuration) - Method in class org.apache.flink.runtime.akka.AkkaUtils$
Utility function to construct a future which tries multiple times to execute itself if it fails.
retry(Function0<T>, int, ExecutionContext) - Static method in class org.apache.flink.runtime.akka.AkkaUtils
Utility function to construct a future which tries multiple times to execute itself if it fails.
retry(Callable<T>, int, ExecutionContext) - Static method in class org.apache.flink.runtime.akka.AkkaUtils
Utility function to construct a future which tries multiple times to execute itself if it fails.
retry(ActorRef, Object, int, ExecutionContext, FiniteDuration) - Static method in class org.apache.flink.runtime.akka.AkkaUtils
Utility function to construct a future which tries multiple times to execute itself if it fails.
retry(Callable<Future<T>>, int, Executor) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
Retry the given operation the given number of times in case of a failure.
retry(Object, int, FiniteDuration, ExecutionContext) - Method in interface org.apache.flink.runtime.instance.ActorGateway
Retries to send asynchronously a message up to numberRetries times.
retry(Object, int, FiniteDuration, ExecutionContext) - Method in class org.apache.flink.runtime.instance.AkkaActorGateway
Retries to send asynchronously a message up to numberRetries times.
RETRY_INTERVAL() - Method in class org.apache.flink.mesos.scheduler.TaskMonitor$
 
RETRY_INTERVAL() - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
RetryException(String) - Constructor for exception org.apache.flink.runtime.concurrent.FutureUtils.RetryException
 
RetryException(String, Throwable) - Constructor for exception org.apache.flink.runtime.concurrent.FutureUtils.RetryException
 
RetryException(Throwable) - Constructor for exception org.apache.flink.runtime.concurrent.FutureUtils.RetryException
 
RetryingRegistration<Gateway extends RpcGateway,Success extends RegistrationResponse.Success> - Class in org.apache.flink.runtime.registration
This utility class implements the basis of registering one component at another component, for example registering the TaskExecutor at the ResourceManager.
RetryingRegistration(Logger, RpcService, String, Class<Gateway>, String, UUID) - Constructor for class org.apache.flink.runtime.registration.RetryingRegistration
 
RetryingRegistration(Logger, RpcService, String, Class<Gateway>, String, UUID, long, long, long, long) - Constructor for class org.apache.flink.runtime.registration.RetryingRegistration
 
retryOnBindException(Function0<T>, Function0<Object>, long) - Method in class org.apache.flink.runtime.jobmanager.JobManager$
Retries a function if it fails because of a BindException.
retryOnBindException(Function0<T>, Function0<Object>, long) - Static method in class org.apache.flink.runtime.jobmanager.JobManager
Retries a function if it fails because of a BindException.
RetryOnException - Annotation Type in org.apache.flink.testutils.junit
Annotation to use with RetryRule.
RetryOnFailure - Annotation Type in org.apache.flink.testutils.junit
Annotation to use with RetryRule.
RetryRejectedExecutionFailureHandler - Class in org.apache.flink.streaming.connectors.elasticsearch.util
An ActionRequestFailureHandler that re-adds requests that failed due to temporary EsRejectedExecutionExceptions (which means that Elasticsearch node queues are currently full), and fails for all other failures.
RetryRejectedExecutionFailureHandler() - Constructor for class org.apache.flink.streaming.connectors.elasticsearch.util.RetryRejectedExecutionFailureHandler
 
RetryRule - Class in org.apache.flink.testutils.junit
A rule to retry failed tests for a fixed number of times.
RetryRule() - Constructor for class org.apache.flink.testutils.junit.RetryRule
 
retrySuccessful(Callable<Future<T>>, FilterFunction<T>, Deadline, Executor) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
Retry the given operation the given number of times in case of a failure.
returnAllocatedSlot(Slot) - Method in class org.apache.flink.runtime.instance.Instance
Returns a slot that has been allocated from this instance.
returnAllocatedSlot(Slot) - Method in class org.apache.flink.runtime.instance.SlotPool
 
returnAllocatedSlot(Slot) - Method in interface org.apache.flink.runtime.instance.SlotPoolGateway
 
returnAllocatedSlot(Slot) - Method in interface org.apache.flink.runtime.jobmanager.slots.SlotOwner
 
returnOperation(AbstractInsnNode, BasicValue, BasicValue) - Method in class org.apache.flink.api.java.sca.NestedMethodAnalyzer
 
returns(Class<OUT>) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
Adds a type information hint about the return type of this operator.
returns(TypeHint<OUT>) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
Adds a type information hint about the return type of this operator.
returns(TypeInformation<OUT>) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
Adds a type information hint about the return type of this operator.
returns(String) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
returns(Class<OUT>) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
Adds a type information hint about the return type of this operator.
returns(TypeHint<OUT>) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
Adds a type information hint about the return type of this operator.
returns(TypeInformation<OUT>) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
Adds a type information hint about the return type of this operator.
returns(String) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
returns(Class<T>) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Adds a type information hint about the return type of this operator.
returns(TypeHint<T>) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Adds a type information hint about the return type of this operator.
returns(TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Adds a type information hint about the return type of this operator.
returns(String) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
ReturnStatementFinder - Class in org.apache.flink.api.scala
 
ReturnStatementFinder() - Constructor for class org.apache.flink.api.scala.ReturnStatementFinder
 
returnType() - Method in class org.apache.flink.table.codegen.GeneratedFunction
 
returnType() - Method in class org.apache.flink.table.codegen.GeneratedInput
 
returnType() - Method in class org.apache.flink.table.runtime.CorrelateFlatMapRunner
 
returnType() - Method in class org.apache.flink.table.runtime.CRowCorrelateProcessRunner
 
returnType() - Method in class org.apache.flink.table.runtime.CRowInputJavaTupleOutputMapRunner
 
returnType() - Method in class org.apache.flink.table.runtime.CRowInputMapRunner
 
returnType() - Method in class org.apache.flink.table.runtime.CRowInputScalaTupleOutputMapRunner
 
returnType() - Method in class org.apache.flink.table.runtime.CRowOutputMapRunner
 
returnType() - Method in class org.apache.flink.table.runtime.CRowProcessRunner
 
returnType() - Method in class org.apache.flink.table.runtime.FlatJoinRunner
 
returnType() - Method in class org.apache.flink.table.runtime.FlatMapRunner
 
returnType() - Method in class org.apache.flink.table.runtime.io.CRowValuesInputFormat
 
returnType() - Method in class org.apache.flink.table.runtime.io.ValuesInputFormat
 
returnType() - Method in class org.apache.flink.table.runtime.MapRunner
 
returnType() - Method in class org.apache.flink.table.runtime.MapSideJoinRunner
 
reuse - Variable in class org.apache.flink.contrib.tweetinputformat.io.TweetHandler
 
reuseCloseCode() - Method in class org.apache.flink.table.codegen.CodeGenerator
 
reuseConstructorCode(String) - Method in class org.apache.flink.table.codegen.CodeGenerator
 
reuseInitCode() - Method in class org.apache.flink.table.codegen.CodeGenerator
 
reuseInputMetricsForTask() - Method in class org.apache.flink.runtime.metrics.groups.OperatorIOMetricGroup
Causes the containing task to use this operators input record counter.
reuseInputUnboxingCode() - Method in class org.apache.flink.table.codegen.CodeGenerator
 
reuseMemberCode() - Method in class org.apache.flink.table.codegen.CodeGenerator
 
reuseOpenCode() - Method in class org.apache.flink.table.codegen.CodeGenerator
 
reuseOutputMetricsForTask() - Method in class org.apache.flink.runtime.metrics.groups.OperatorIOMetricGroup
Causes the containing task to use this operators output record counter.
reusePerRecordCode() - Method in class org.apache.flink.table.codegen.CodeGenerator
 
reuseRecordsInputCounter(Counter) - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
reuseRecordsOutputCounter(Counter) - Method in class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
ReusingBlockResettableIterator<T> - Class in org.apache.flink.runtime.operators.resettable
Implementation of an iterator that fetches a block of data into main memory and offers resettable access to the data in that block.
ReusingBlockResettableIterator(MemoryManager, Iterator<T>, TypeSerializer<T>, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.resettable.ReusingBlockResettableIterator
 
ReusingBlockResettableIterator(MemoryManager, TypeSerializer<T>, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.resettable.ReusingBlockResettableIterator
 
ReusingBuildFirstHashJoinIterator<V1,V2,O> - Class in org.apache.flink.runtime.operators.hash
An implementation of the JoinTaskIterator that uses a hybrid-hash-join internally to match the records with equal key.
ReusingBuildFirstHashJoinIterator(MutableObjectIterator<V1>, MutableObjectIterator<V2>, TypeSerializer<V1>, TypeComparator<V1>, TypeSerializer<V2>, TypeComparator<V2>, TypePairComparator<V2, V1>, MemoryManager, IOManager, AbstractInvokable, double, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.ReusingBuildFirstHashJoinIterator
 
ReusingBuildFirstReOpenableHashJoinIterator<V1,V2,O> - Class in org.apache.flink.runtime.operators.hash
 
ReusingBuildFirstReOpenableHashJoinIterator(MutableObjectIterator<V1>, MutableObjectIterator<V2>, TypeSerializer<V1>, TypeComparator<V1>, TypeSerializer<V2>, TypeComparator<V2>, TypePairComparator<V2, V1>, MemoryManager, IOManager, AbstractInvokable, double, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.ReusingBuildFirstReOpenableHashJoinIterator
 
ReusingBuildSecondHashJoinIterator<V1,V2,O> - Class in org.apache.flink.runtime.operators.hash
An implementation of the JoinTaskIterator that uses a hybrid-hash-join internally to match the records with equal key.
ReusingBuildSecondHashJoinIterator(MutableObjectIterator<V1>, MutableObjectIterator<V2>, TypeSerializer<V1>, TypeComparator<V1>, TypeSerializer<V2>, TypeComparator<V2>, TypePairComparator<V1, V2>, MemoryManager, IOManager, AbstractInvokable, double, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.ReusingBuildSecondHashJoinIterator
 
ReusingBuildSecondReOpenableHashJoinIterator<V1,V2,O> - Class in org.apache.flink.runtime.operators.hash
 
ReusingBuildSecondReOpenableHashJoinIterator(MutableObjectIterator<V1>, MutableObjectIterator<V2>, TypeSerializer<V1>, TypeComparator<V1>, TypeSerializer<V2>, TypeComparator<V2>, TypePairComparator<V1, V2>, MemoryManager, IOManager, AbstractInvokable, double, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.hash.ReusingBuildSecondReOpenableHashJoinIterator
 
ReusingDeserializationDelegate<T> - Class in org.apache.flink.runtime.plugable
 
ReusingDeserializationDelegate(TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.plugable.ReusingDeserializationDelegate
 
ReusingKeyGroupedIterator<E> - Class in org.apache.flink.runtime.util
The KeyValueIterator returns a key and all values that belong to the key (share the same key).
ReusingKeyGroupedIterator(MutableObjectIterator<E>, TypeSerializer<E>, TypeComparator<E>) - Constructor for class org.apache.flink.runtime.util.ReusingKeyGroupedIterator
Initializes the KeyGroupedIterator.
ReusingKeyGroupedIterator.ValuesIterator - Class in org.apache.flink.runtime.util
 
ReusingMergeInnerJoinIterator<T1,T2,O> - Class in org.apache.flink.runtime.operators.sort
 
ReusingMergeInnerJoinIterator(MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>, MemoryManager, IOManager, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.sort.ReusingMergeInnerJoinIterator
 
ReusingMergeOuterJoinIterator<T1,T2,O> - Class in org.apache.flink.runtime.operators.sort
 
ReusingMergeOuterJoinIterator(OuterJoinOperatorBase.OuterJoinType, MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>, MemoryManager, IOManager, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.sort.ReusingMergeOuterJoinIterator
 
ReusingMutableToRegularIteratorWrapper<T> - Class in org.apache.flink.runtime.util
This class wraps a MutableObjectIterator into a regular Iterator.
ReusingMutableToRegularIteratorWrapper(MutableObjectIterator<T>, TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.util.ReusingMutableToRegularIteratorWrapper
 
ReusingSortMergeCoGroupIterator<T1,T2> - Class in org.apache.flink.runtime.operators.sort
 
ReusingSortMergeCoGroupIterator(MutableObjectIterator<T1>, MutableObjectIterator<T2>, TypeSerializer<T1>, TypeComparator<T1>, TypeSerializer<T2>, TypeComparator<T2>, TypePairComparator<T1, T2>) - Constructor for class org.apache.flink.runtime.operators.sort.ReusingSortMergeCoGroupIterator
 
revenue() - Method in class org.apache.flink.examples.scala.relational.TPCHQuery3.ShippedItem
 
reverse() - Method in class org.apache.flink.graph.Edge
Reverses the direction of this Edge.
reverse() - Method in class org.apache.flink.graph.Graph
Reverse the direction of the edges in the graph
reverse() - Method in class org.apache.flink.graph.scala.Graph
Reverse the direction of the edges in the graph
RevisionInformation(String, String) - Constructor for class org.apache.flink.runtime.util.EnvironmentInformation.RevisionInformation
 
revokeLeadership() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
revokeLeadership() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
 
revokeLeadership() - Method in interface org.apache.flink.runtime.leaderelection.LeaderContender
Callback method which is called by the LeaderElectionService upon revoking the leadership of a former leader.
revokeLeadership() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
Callback method when current resourceManager loses leadership.
RevokeLeadership$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RevokeLeadership$
 
rewriteCall(SqlValidator, SqlCall) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
rewriteCall(SqlValidator, SqlCall) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
rewriteCall(SqlValidator, SqlCall) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
rewriteCall(SqlValidator, SqlCall) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
rewriteWithFieldProjection(RexProgram, RelDataType, RexBuilder, int[]) - Method in class org.apache.flink.table.plan.util.RexProgramRewriter$
Generates a new RexProgram with used input fields.
rewriteWithFieldProjection(RexProgram, RelDataType, RexBuilder, int[]) - Static method in class org.apache.flink.table.plan.util.RexProgramRewriter
Generates a new RexProgram with used input fields.
rexBuilder - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
 
RexNodeToExpressionConverter - Class in org.apache.flink.table.plan.util
An RexVisitor to convert RexNode to Expression.
RexNodeToExpressionConverter(String[], FunctionCatalog) - Constructor for class org.apache.flink.table.plan.util.RexNodeToExpressionConverter
 
RexProgramExtractor - Class in org.apache.flink.table.plan.util
 
RexProgramExtractor() - Constructor for class org.apache.flink.table.plan.util.RexProgramExtractor
 
RexProgramExtractor$ - Class in org.apache.flink.table.plan.util
 
RexProgramExtractor$() - Constructor for class org.apache.flink.table.plan.util.RexProgramExtractor$
 
RexProgramRewriter - Class in org.apache.flink.table.plan.util
 
RexProgramRewriter() - Constructor for class org.apache.flink.table.plan.util.RexProgramRewriter
 
RexProgramRewriter$ - Class in org.apache.flink.table.plan.util
 
RexProgramRewriter$() - Constructor for class org.apache.flink.table.plan.util.RexProgramRewriter$
 
RexTimeIndicatorMaterializer(RexBuilder, Seq<RelDataType>) - Constructor for class org.apache.flink.table.calcite.RelTimeIndicatorConverter.RexTimeIndicatorMaterializer
 
RichAggregateFunction<IN,ACC,OUT> - Class in org.apache.flink.api.common.functions
Rich variant of the AggregateFunction.
RichAggregateFunction() - Constructor for class org.apache.flink.api.common.functions.RichAggregateFunction
 
RichAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
RichAllWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.RichAllWindowFunction
 
RichAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.api.scala.function
Rich variant of the AllWindowFunction.
RichAllWindowFunction() - Constructor for class org.apache.flink.streaming.api.scala.function.RichAllWindowFunction
 
RichAsyncFunction<IN,OUT> - Class in org.apache.flink.streaming.api.functions.async
Rich variant of the AsyncFunction.
RichAsyncFunction() - Constructor for class org.apache.flink.streaming.api.functions.async.RichAsyncFunction
 
RichCoFlatMapFunction<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.functions.co
A RichCoFlatMapFunction represents a FlatMap transformation with two different input types.
RichCoFlatMapFunction() - Constructor for class org.apache.flink.streaming.api.functions.co.RichCoFlatMapFunction
 
RichCoGroupFunction<IN1,IN2,OUT> - Class in org.apache.flink.api.common.functions
Rich variant of the CoGroupFunction.
RichCoGroupFunction() - Constructor for class org.apache.flink.api.common.functions.RichCoGroupFunction
 
RichCoMapFunction<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.functions.co
A RichCoMapFunction represents a Map transformation with two different input types.
RichCoMapFunction() - Constructor for class org.apache.flink.streaming.api.functions.co.RichCoMapFunction
 
RichCombineToGroupCombineWrapper<IN,OUT,F extends RichGroupReduceFunction<IN,OUT> & CombineFunction<IN,IN>> - Class in org.apache.flink.api.java.operators.translation
A wrapper the wraps a function that implements both CombineFunction and GroupReduceFunction interfaces and makes it look like a function that implements GroupCombineFunction and GroupReduceFunction to the runtime.
RichCombineToGroupCombineWrapper(F) - Constructor for class org.apache.flink.api.java.operators.translation.RichCombineToGroupCombineWrapper
 
RichCrossFunction<IN1,IN2,OUT> - Class in org.apache.flink.api.common.functions
Rich variant of the CrossFunction.
RichCrossFunction() - Constructor for class org.apache.flink.api.common.functions.RichCrossFunction
 
RichFilterFunction<T> - Class in org.apache.flink.api.common.functions
Rich variant of the FilterFunction.
RichFilterFunction() - Constructor for class org.apache.flink.api.common.functions.RichFilterFunction
 
RichFlatJoinFunction<IN1,IN2,OUT> - Class in org.apache.flink.api.common.functions
Rich variant of the FlatJoinFunction.
RichFlatJoinFunction() - Constructor for class org.apache.flink.api.common.functions.RichFlatJoinFunction
 
RichFlatMapFunction<IN,OUT> - Class in org.apache.flink.api.common.functions
Rich variant of the FlatMapFunction.
RichFlatMapFunction() - Constructor for class org.apache.flink.api.common.functions.RichFlatMapFunction
 
RichFoldFunction<O,T> - Class in org.apache.flink.api.common.functions
Deprecated.
RichFoldFunction() - Constructor for class org.apache.flink.api.common.functions.RichFoldFunction
Deprecated.
 
RichFunction - Interface in org.apache.flink.api.common.functions
An base interface for all rich user-defined functions.
RichGroupCombineFunction<IN,OUT> - Class in org.apache.flink.api.common.functions
Rich variant of the GroupCombineFunction.
RichGroupCombineFunction() - Constructor for class org.apache.flink.api.common.functions.RichGroupCombineFunction
 
RichGroupReduceFunction<IN,OUT> - Class in org.apache.flink.api.common.functions
Rich variant of the GroupReduceFunction.
RichGroupReduceFunction() - Constructor for class org.apache.flink.api.common.functions.RichGroupReduceFunction
 
RichInputFormat<OT,T extends InputSplit> - Class in org.apache.flink.api.common.io
An abstract stub implementation for Rich input formats.
RichInputFormat() - Constructor for class org.apache.flink.api.common.io.RichInputFormat
 
RichJoinFunction<IN1,IN2,OUT> - Class in org.apache.flink.api.common.functions
Rich variant of the JoinFunction.
RichJoinFunction() - Constructor for class org.apache.flink.api.common.functions.RichJoinFunction
 
RichMapFunction<IN,OUT> - Class in org.apache.flink.api.common.functions
Rich variant of the MapFunction.
RichMapFunction() - Constructor for class org.apache.flink.api.common.functions.RichMapFunction
 
RichMapPartitionFunction<I,O> - Class in org.apache.flink.api.common.functions
Rich variant of the MapPartitionFunction.
RichMapPartitionFunction() - Constructor for class org.apache.flink.api.common.functions.RichMapPartitionFunction
 
RichOutputFormat<IT> - Class in org.apache.flink.api.common.io
An abstract stub implementation for Rich output formats.
RichOutputFormat() - Constructor for class org.apache.flink.api.common.io.RichOutputFormat
 
RichParallelSourceFunction<OUT> - Class in org.apache.flink.streaming.api.functions.source
Base class for implementing a parallel data source.
RichParallelSourceFunction() - Constructor for class org.apache.flink.streaming.api.functions.source.RichParallelSourceFunction
 
RichProcessAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
Deprecated.
RichProcessAllWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.RichProcessAllWindowFunction
Deprecated.
 
RichProcessAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.api.scala.function
Deprecated.
use [[ProcessAllWindowFunction]] instead. Since .
RichProcessAllWindowFunction() - Constructor for class org.apache.flink.streaming.api.scala.function.RichProcessAllWindowFunction
Deprecated.
 
RichProcessWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
Deprecated.
RichProcessWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.RichProcessWindowFunction
Deprecated.
 
RichProcessWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.api.scala.function
Deprecated.
use [[ProcessWindowFunction]] instead. Since .
RichProcessWindowFunction() - Constructor for class org.apache.flink.streaming.api.scala.function.RichProcessWindowFunction
Deprecated.
 
RichReduceFunction<T> - Class in org.apache.flink.api.common.functions
Rich variant of the ReduceFunction.
RichReduceFunction() - Constructor for class org.apache.flink.api.common.functions.RichReduceFunction
 
RichSinkFunction<IN> - Class in org.apache.flink.streaming.api.functions.sink
RichSinkFunction() - Constructor for class org.apache.flink.streaming.api.functions.sink.RichSinkFunction
 
RichSourceFunction<OUT> - Class in org.apache.flink.streaming.api.functions.source
Base class for implementing a parallel data source that has access to context information (via AbstractRichFunction.getRuntimeContext()) and additional life-cycle methods (AbstractRichFunction.open(org.apache.flink.configuration.Configuration) and AbstractRichFunction.close().
RichSourceFunction() - Constructor for class org.apache.flink.streaming.api.functions.source.RichSourceFunction
 
RichTranslateFunction<IN,OUT> - Class in org.apache.flink.graph.asm.translate
Rich variant of the TranslateFunction.
RichTranslateFunction() - Constructor for class org.apache.flink.graph.asm.translate.RichTranslateFunction
 
RichWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.api.functions.windowing
Rich variant of the WindowFunction.
RichWindowFunction() - Constructor for class org.apache.flink.streaming.api.functions.windowing.RichWindowFunction
 
RichWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.api.scala.function
Rich variant of the WindowFunction.
RichWindowFunction() - Constructor for class org.apache.flink.streaming.api.scala.function.RichWindowFunction
 
right() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.EitherDescriptor
 
right() - Method in class org.apache.flink.ml.pipeline.ChainedTransformer
 
right() - Method in class org.apache.flink.table.expressions.And
 
right() - Method in class org.apache.flink.table.expressions.BinaryExpression
 
right() - Method in class org.apache.flink.table.expressions.Div
 
right() - Method in class org.apache.flink.table.expressions.EqualTo
 
right() - Method in class org.apache.flink.table.expressions.GreaterThan
 
right() - Method in class org.apache.flink.table.expressions.GreaterThanOrEqual
 
right() - Method in class org.apache.flink.table.expressions.LessThan
 
right() - Method in class org.apache.flink.table.expressions.LessThanOrEqual
 
right() - Method in class org.apache.flink.table.expressions.Like
 
right() - Method in class org.apache.flink.table.expressions.Minus
 
right() - Method in class org.apache.flink.table.expressions.Mod
 
right() - Method in class org.apache.flink.table.expressions.Mul
 
right() - Method in class org.apache.flink.table.expressions.NotEqualTo
 
right() - Method in class org.apache.flink.table.expressions.Or
 
right() - Method in class org.apache.flink.table.expressions.Plus
 
right() - Method in class org.apache.flink.table.expressions.Power
 
right() - Method in class org.apache.flink.table.expressions.Round
 
right() - Method in class org.apache.flink.table.expressions.Similar
 
right() - Method in class org.apache.flink.table.plan.logical.BinaryNode
 
right() - Method in class org.apache.flink.table.plan.logical.Intersect
 
right() - Method in class org.apache.flink.table.plan.logical.Join
 
right() - Method in class org.apache.flink.table.plan.logical.Minus
 
right() - Method in class org.apache.flink.table.plan.logical.Union
 
right() - Method in class org.apache.flink.types.Either.Left
 
Right(R) - Static method in class org.apache.flink.types.Either
Create a Right value of Either
right() - Method in class org.apache.flink.types.Either
Retrieve the Right value of Either.
Right(R) - Constructor for class org.apache.flink.types.Either.Right
 
right() - Method in class org.apache.flink.types.Either.Right
 
rightInput() - Method in class org.apache.flink.api.scala.UnfinishedKeyPairOperation
 
rightOuterJoin(DataSet<R>) - Method in class org.apache.flink.api.java.DataSet
Initiates a Right Outer Join transformation.
An Outer Join transformation joins two elements of two DataSets on key equality and provides multiple ways to combine joining elements into one DataSet.
Elements of the right DataSet (i.e.
rightOuterJoin(DataSet<R>, JoinOperatorBase.JoinHint) - Method in class org.apache.flink.api.java.DataSet
Initiates a Right Outer Join transformation.
An Outer Join transformation joins two elements of two DataSets on key equality and provides multiple ways to combine joining elements into one DataSet.
Elements of the right DataSet (i.e.
rightOuterJoin(DataSet<O>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
rightOuterJoin(DataSet<O>, JoinOperatorBase.JoinHint) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
rightOuterJoin(DataSet<O>) - Method in class org.apache.flink.api.scala.DataSet
An outer join on the right side.
rightOuterJoin(DataSet<O>, JoinOperatorBase.JoinHint) - Method in class org.apache.flink.api.scala.DataSet
An outer join on the right side.
rightOuterJoin(Table, String) - Method in class org.apache.flink.table.api.Table
Joins two Tables.
rightOuterJoin(Table, Expression) - Method in class org.apache.flink.table.api.Table
Joins two Tables.
RightOuterJoinDriver<IT1,IT2,OT> - Class in org.apache.flink.runtime.operators
The right outer join driver implements the logic of an outer join operator at runtime.
RightOuterJoinDriver() - Constructor for class org.apache.flink.runtime.operators.RightOuterJoinDriver
 
rightSerializer() - Method in class org.apache.flink.api.scala.typeutils.EitherSerializer
 
rightTemporal() - Method in class org.apache.flink.table.expressions.TemporalOverlaps
 
rightTimePoint() - Method in class org.apache.flink.table.expressions.TemporalOverlaps
 
rightTypeInfo() - Method in class org.apache.flink.api.scala.typeutils.EitherTypeInfo
 
RMatGraph - Class in org.apache.flink.graph.drivers.input
Generate an RMatGraph with IntValue, LongValue, or StringValue keys.
RMatGraph() - Constructor for class org.apache.flink.graph.drivers.input.RMatGraph
 
RMatGraph<T extends org.apache.commons.math3.random.RandomGenerator> - Class in org.apache.flink.graph.generator
 
RMatGraph(ExecutionEnvironment, RandomGenerableFactory<T>, long, long) - Constructor for class org.apache.flink.graph.generator.RMatGraph
A directed power-law multigraph generated using the stochastic Recursive Matrix (R-Mat) model.
RMQConnectionConfig - Class in org.apache.flink.streaming.connectors.rabbitmq.common
Connection Configuration for RMQ.
RMQConnectionConfig.Builder - Class in org.apache.flink.streaming.connectors.rabbitmq.common
The Builder Class for RMQConnectionConfig
RMQSink<IN> - Class in org.apache.flink.streaming.connectors.rabbitmq
A Sink for publishing data into RabbitMQ
RMQSink(RMQConnectionConfig, String, SerializationSchema<IN>) - Constructor for class org.apache.flink.streaming.connectors.rabbitmq.RMQSink
 
RMQSource<OUT> - Class in org.apache.flink.streaming.connectors.rabbitmq
RabbitMQ source (consumer) which reads from a queue and acknowledges messages on checkpoints.
RMQSource(RMQConnectionConfig, String, DeserializationSchema<OUT>) - Constructor for class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
Creates a new RabbitMQ source with at-least-once message processing guarantee when checkpointing is enabled.
RMQSource(RMQConnectionConfig, String, boolean, DeserializationSchema<OUT>) - Constructor for class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
Creates a new RabbitMQ source.
RNG - Static variable in class org.apache.flink.api.java.Utils
 
ROCKSDB_CHECKPOINT_DIRECTORY_URI_CONF_KEY - Static variable in class org.apache.flink.contrib.streaming.state.RocksDBStateBackendFactory
The key under which the config stores the directory where RocksDB should be stored
ROCKSDB_STATE_BACKEND_NAME - Static variable in class org.apache.flink.runtime.state.AbstractStateBackend
The shortcut configuration name for the RocksDB State Backend
RocksDBAggregatingState<K,N,T,ACC,R> - Class in org.apache.flink.contrib.streaming.state
An AggregatingState implementation that stores state in RocksDB.
RocksDBAggregatingState(ColumnFamilyHandle, TypeSerializer<N>, AggregatingStateDescriptor<T, ACC, R>, RocksDBKeyedStateBackend<K>) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBAggregatingState
Creates a new RocksDBFoldingState.
RocksDBFoldingState<K,N,T,ACC> - Class in org.apache.flink.contrib.streaming.state
Deprecated.
will be removed in a future version
RocksDBFoldingState(ColumnFamilyHandle, TypeSerializer<N>, FoldingStateDescriptor<T, ACC>, RocksDBKeyedStateBackend<K>) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBFoldingState
Deprecated.
Creates a new RocksDBFoldingState.
RocksDBKeyedStateBackend<K> - Class in org.apache.flink.contrib.streaming.state
A AbstractKeyedStateBackend that stores its state in RocksDB and will serialize state to streams provided by a CheckpointStreamFactory upon checkpointing.
RocksDBKeyedStateBackend(String, ClassLoader, File, DBOptions, ColumnFamilyOptions, TaskKvStateRegistry, TypeSerializer<K>, int, KeyGroupRange, ExecutionConfig, boolean) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
 
RocksDBListState<K,N,V> - Class in org.apache.flink.contrib.streaming.state
ListState implementation that stores state in RocksDB.
RocksDBListState(ColumnFamilyHandle, TypeSerializer<N>, ListStateDescriptor<V>, RocksDBKeyedStateBackend<K>) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBListState
Creates a new RocksDBListState.
RocksDBMapState<K,N,UK,UV> - Class in org.apache.flink.contrib.streaming.state
MapState implementation that stores state in RocksDB.
RocksDBMapState(ColumnFamilyHandle, TypeSerializer<N>, MapStateDescriptor<UK, UV>, RocksDBKeyedStateBackend<K>) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBMapState
Creates a new RocksDBMapState.
RocksDBReducingState<K,N,V> - Class in org.apache.flink.contrib.streaming.state
ReducingState implementation that stores state in RocksDB.
RocksDBReducingState(ColumnFamilyHandle, TypeSerializer<N>, ReducingStateDescriptor<V>, RocksDBKeyedStateBackend<K>) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBReducingState
Creates a new RocksDBReducingState.
RocksDBStateBackend - Class in org.apache.flink.contrib.streaming.state
A State Backend that stores its state in RocksDB.
RocksDBStateBackend(String) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
Creates a new RocksDBStateBackend that stores its checkpoint data in the file system and location defined by the given URI.
RocksDBStateBackend(String, boolean) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
Creates a new RocksDBStateBackend that stores its checkpoint data in the file system and location defined by the given URI.
RocksDBStateBackend(URI) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
Creates a new RocksDBStateBackend that stores its checkpoint data in the file system and location defined by the given URI.
RocksDBStateBackend(URI, boolean) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
Creates a new RocksDBStateBackend that stores its checkpoint data in the file system and location defined by the given URI.
RocksDBStateBackend(AbstractStateBackend) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
Creates a new RocksDBStateBackend that uses the given state backend to store its checkpoint data streams.
RocksDBStateBackend(AbstractStateBackend, boolean) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
Creates a new RocksDBStateBackend that uses the given state backend to store its checkpoint data streams.
RocksDBStateBackend - Class in org.apache.flink.migration.contrib.streaming.state
Deprecated.
Internal class used for backwards compatibility.
RocksDBStateBackend() - Constructor for class org.apache.flink.migration.contrib.streaming.state.RocksDBStateBackend
Deprecated.
 
RocksDBStateBackend.FinalFullyAsyncSnapshot - Class in org.apache.flink.migration.contrib.streaming.state
Deprecated.
Dummy KvStateSnapshot that holds the state of our one RocksDB data base.
RocksDBStateBackend.FinalSemiAsyncSnapshot - Class in org.apache.flink.migration.contrib.streaming.state
Deprecated.
 
RocksDBStateBackendFactory - Class in org.apache.flink.contrib.streaming.state
A factory that creates an RocksDBStateBackend from a configuration.
RocksDBStateBackendFactory() - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBStateBackendFactory
 
RocksDBValueState<K,N,V> - Class in org.apache.flink.contrib.streaming.state
ValueState implementation that stores state in RocksDB.
RocksDBValueState(ColumnFamilyHandle, TypeSerializer<N>, ValueStateDescriptor<V>, RocksDBKeyedStateBackend<K>) - Constructor for class org.apache.flink.contrib.streaming.state.RocksDBValueState
Creates a new RocksDBValueState.
RollingSink<T> - Class in org.apache.flink.streaming.connectors.fs
Deprecated.
use BucketingSink instead.
RollingSink(String) - Constructor for class org.apache.flink.streaming.connectors.fs.RollingSink
Deprecated.
Creates a new RollingSink that writes files to the given base directory.
RollingSink.BucketState - Class in org.apache.flink.streaming.connectors.fs
Deprecated.
This is used for keeping track of the current in-progress files and files that we mark for moving from pending to final location after we get a checkpoint-complete notification.
rollOver() - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller
Starts a new sequence of spilled buffers and event and returns the current sequence of spilled buffers for reading.
rollOverWithNewBuffer() - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller
Starts a new sequence of spilled buffers and event and returns the current sequence of spilled buffers for reading.
ROLLUP - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
ROLLUP operator, occurs within GROUP BY clause or nested within a GROUPING SETS.
root - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
 
root() - Method in class org.apache.flink.ml.nn.QuadTree
 
root() - Method in class org.apache.flink.table.calcite.FlinkPlannerImpl
 
ROUND - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
round(Expression) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Rounds the given number to integer places right to the decimal point.
Round - Class in org.apache.flink.table.expressions
 
Round(Expression, Expression) - Constructor for class org.apache.flink.table.expressions.Round
 
Round$ - Class in org.apache.flink.table.expressions
 
Round$() - Constructor for class org.apache.flink.table.expressions.Round$
 
ROUND_DEC() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
ROUND_DEC() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
ROUND_DOUBLE() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
ROUND_DOUBLE() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
ROUND_INT() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
ROUND_INT() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
ROUND_LONG() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
ROUND_LONG() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
roundDownToPageSizeMultiple(long) - Method in class org.apache.flink.runtime.memory.MemoryManager
Rounds the given value down to a multiple of the memory manager's page size.
roundDownToPowerOf2(int) - Static method in class org.apache.flink.util.MathUtils
Decrements the given number down to the closest power of two.
RoundRobinChannelSelector<T extends IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.writer
This is the default implementation of the ChannelSelector interface.
RoundRobinChannelSelector() - Constructor for class org.apache.flink.runtime.io.network.api.writer.RoundRobinChannelSelector
Constructs a new default channel selector.
RoundRobinOperatorStateRepartitioner - Class in org.apache.flink.runtime.checkpoint
Current default implementation of OperatorStateRepartitioner that redistributes state in round robin fashion.
RoundRobinOperatorStateRepartitioner() - Constructor for class org.apache.flink.runtime.checkpoint.RoundRobinOperatorStateRepartitioner
 
roundUpToPowerOfTwo(int) - Static method in class org.apache.flink.util.MathUtils
Round the given number to the next power of two
ROW - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
ROW(TypeInformation<?>...) - Static method in class org.apache.flink.api.common.typeinfo.Types
Generates a RowTypeInfo with fields of the given types.
ROW(TypeInformation<?>...) - Method in class org.apache.flink.table.api.Types$
Generates row type information.
ROW(Seq<TypeInformation<?>>) - Method in class org.apache.flink.table.api.Types$
Generates row type information.
ROW(String[], TypeInformation<?>[]) - Method in class org.apache.flink.table.api.Types$
Generates row type information.
ROW(TypeInformation<?>...) - Static method in class org.apache.flink.table.api.Types
Generates row type information.
ROW(Seq<TypeInformation<?>>) - Static method in class org.apache.flink.table.api.Types
Generates row type information.
ROW(String[], TypeInformation<?>[]) - Static method in class org.apache.flink.table.api.Types
Generates row type information.
row() - Method in class org.apache.flink.table.runtime.types.CRow
 
Row - Class in org.apache.flink.types
A Row can have arbitrary number of fields and contain a set of fields, which may all be different types.
Row(int) - Constructor for class org.apache.flink.types.Row
Create a new Row instance.
ROW_NAMED(String[], TypeInformation<?>...) - Static method in class org.apache.flink.api.common.typeinfo.Types
Generates a RowTypeInfo with fields of the given types and with given names.
ROW_NUMBER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
ROW_NUMBER window function.
rowComp() - Method in class org.apache.flink.table.runtime.types.CRowComparator
 
RowComparator - Class in org.apache.flink.api.java.typeutils.runtime
Comparator for Row
RowComparator(int, int[], TypeComparator<Object>[], TypeSerializer<Object>[], boolean[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.RowComparator
General constructor for RowComparator.
rowCount() - Method in class org.apache.flink.table.plan.cost.DataSetCost
 
rowCount() - Method in class org.apache.flink.table.plan.stats.TableStats
 
RowCsvInputFormat - Class in org.apache.flink.api.java.io
 
RowCsvInputFormat(Path, TypeInformation[], String, String, int[], boolean) - Constructor for class org.apache.flink.api.java.io.RowCsvInputFormat
 
RowCsvInputFormat(Path, TypeInformation[], String, String, int[]) - Constructor for class org.apache.flink.api.java.io.RowCsvInputFormat
 
RowCsvInputFormat(Path, TypeInformation[], String, String) - Constructor for class org.apache.flink.api.java.io.RowCsvInputFormat
 
RowCsvInputFormat(Path, TypeInformation[], int[]) - Constructor for class org.apache.flink.api.java.io.RowCsvInputFormat
 
RowCsvInputFormat(Path, TypeInformation[], boolean) - Constructor for class org.apache.flink.api.java.io.RowCsvInputFormat
 
RowCsvInputFormat(Path, TypeInformation[]) - Constructor for class org.apache.flink.api.java.io.RowCsvInputFormat
 
rowIndex() - Method in class org.apache.flink.ml.math.distributed.IndexedRow
 
rowIndices() - Method in class org.apache.flink.ml.math.SparseMatrix
 
RowIntervalTypeInfo - Class in org.apache.flink.table.typeutils
TypeInformation for row intervals.
RowIntervalTypeInfo() - Constructor for class org.apache.flink.table.typeutils.RowIntervalTypeInfo
 
RowIntervalTypeInfo$ - Class in org.apache.flink.table.typeutils
 
RowIntervalTypeInfo$() - Constructor for class org.apache.flink.table.typeutils.RowIntervalTypeInfo$
 
rows() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Creates an interval of rows.
ROWS() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
ROWS() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
RowSchema - Class in org.apache.flink.table.plan.schema
Schema that describes both a logical and physical row.
RowSchema(RelDataType) - Constructor for class org.apache.flink.table.plan.schema.RowSchema
 
RowSerializer - Class in org.apache.flink.api.java.typeutils.runtime
Serializer for Row.
RowSerializer(TypeSerializer<?>[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
rowSerializer() - Method in class org.apache.flink.table.runtime.types.CRowSerializer
 
RowSerializer.RowSerializerConfigSnapshot - Class in org.apache.flink.api.java.typeutils.runtime
 
RowSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
RowSerializerConfigSnapshot(TypeSerializer[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.RowSerializer.RowSerializerConfigSnapshot
 
rowtime() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Declares a field as the rowtime attribute for indicating, accessing, and working in Flink's event time.
ROWTIME() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
rowtime() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
ROWTIME() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
rowtime() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
rowtime() - Method in class org.apache.flink.table.plan.schema.DataStreamTable
 
ROWTIME_INDICATOR() - Method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo$
 
ROWTIME_INDICATOR() - Static method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
 
RowtimeAttribute - Class in org.apache.flink.table.expressions
 
RowtimeAttribute(Expression) - Constructor for class org.apache.flink.table.expressions.RowtimeAttribute
 
RowtimeAttribute$ - Class in org.apache.flink.table.expressions
 
RowtimeAttribute$() - Constructor for class org.apache.flink.table.expressions.RowtimeAttribute$
 
RowTimeBoundedRangeOver - Class in org.apache.flink.table.runtime.aggregate
Process Function for RANGE clause event-time bounded OVER window
RowTimeBoundedRangeOver(GeneratedAggregationsFunction, RowTypeInfo, CRowTypeInfo, long, StreamQueryConfig) - Constructor for class org.apache.flink.table.runtime.aggregate.RowTimeBoundedRangeOver
 
RowTimeBoundedRowsOver - Class in org.apache.flink.table.runtime.aggregate
Process Function for ROWS clause event-time bounded OVER window
RowTimeBoundedRowsOver(GeneratedAggregationsFunction, RowTypeInfo, CRowTypeInfo, long, StreamQueryConfig) - Constructor for class org.apache.flink.table.runtime.aggregate.RowTimeBoundedRowsOver
 
RowTimeUnboundedOver - Class in org.apache.flink.table.runtime.aggregate
A ProcessFunction to support unbounded event-time over-window
RowTimeUnboundedOver(GeneratedAggregationsFunction, TypeInformation<Row>, TypeInformation<CRow>, StreamQueryConfig) - Constructor for class org.apache.flink.table.runtime.aggregate.RowTimeUnboundedOver
 
RowTimeUnboundedRangeOver - Class in org.apache.flink.table.runtime.aggregate
A ProcessFunction to support unbounded RANGE window.
RowTimeUnboundedRangeOver(GeneratedAggregationsFunction, TypeInformation<Row>, TypeInformation<CRow>, StreamQueryConfig) - Constructor for class org.apache.flink.table.runtime.aggregate.RowTimeUnboundedRangeOver
 
RowTimeUnboundedRowsOver - Class in org.apache.flink.table.runtime.aggregate
A ProcessFunction to support unbounded ROWS window.
RowTimeUnboundedRowsOver(GeneratedAggregationsFunction, TypeInformation<Row>, TypeInformation<CRow>, StreamQueryConfig) - Constructor for class org.apache.flink.table.runtime.aggregate.RowTimeUnboundedRowsOver
 
RowTimeWindowPropertyCollector - Class in org.apache.flink.table.runtime.aggregate
 
RowTimeWindowPropertyCollector(Option<Object>, Option<Object>) - Constructor for class org.apache.flink.table.runtime.aggregate.RowTimeWindowPropertyCollector
 
rowType() - Method in class org.apache.flink.table.plan.logical.CatalogNode
 
rowType() - Method in class org.apache.flink.table.runtime.types.CRowTypeInfo
 
RowTypeInfo - Class in org.apache.flink.api.java.typeutils
TypeInformation for Row
RowTypeInfo(TypeInformation<?>...) - Constructor for class org.apache.flink.api.java.typeutils.RowTypeInfo
 
RowTypeInfo(TypeInformation<?>[], String[]) - Constructor for class org.apache.flink.api.java.typeutils.RowTypeInfo
 
rowTypeToString(RelDataType) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetDistinct
 
rpcAskTimeout - Variable in class org.apache.flink.runtime.jobmaster.JobManagerServices
 
RpcCheckpointResponder - Class in org.apache.flink.runtime.taskexecutor.rpc
 
RpcCheckpointResponder(CheckpointCoordinatorGateway) - Constructor for class org.apache.flink.runtime.taskexecutor.rpc.RpcCheckpointResponder
 
RpcConnectionException - Exception in org.apache.flink.runtime.rpc.exceptions
Exception class which is thrown if a rpc connection failed.
RpcConnectionException(String) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.RpcConnectionException
 
RpcConnectionException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.RpcConnectionException
 
RpcConnectionException(Throwable) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.RpcConnectionException
 
RpcEndpoint<C extends RpcGateway> - Class in org.apache.flink.runtime.rpc
Base class for RPC endpoints.
RpcEndpoint(RpcService, String) - Constructor for class org.apache.flink.runtime.rpc.RpcEndpoint
Initializes the RPC endpoint.
RpcEndpoint(RpcService) - Constructor for class org.apache.flink.runtime.rpc.RpcEndpoint
Initializes the RPC endpoint with a random endpoint id.
RpcException - Exception in org.apache.flink.runtime.rpc.exceptions
Base class for RPC related exceptions.
RpcException(String) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.RpcException
 
RpcException(String, Throwable) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.RpcException
 
RpcException(Throwable) - Constructor for exception org.apache.flink.runtime.rpc.exceptions.RpcException
 
RpcGateway - Interface in org.apache.flink.runtime.rpc
Rpc gateway interface which has to be implemented by Rpc gateways.
RpcInputSplitProvider - Class in org.apache.flink.runtime.taskexecutor.rpc
 
RpcInputSplitProvider(UUID, JobMasterGateway, JobID, JobVertexID, ExecutionAttemptID, Time) - Constructor for class org.apache.flink.runtime.taskexecutor.rpc.RpcInputSplitProvider
 
RpcInvocation - Interface in org.apache.flink.runtime.rpc.akka.messages
Interface for rpc invocation messages.
RpcKvStateRegistryListener - Class in org.apache.flink.runtime.taskexecutor.rpc
 
RpcKvStateRegistryListener(KvStateRegistryGateway, KvStateServerAddress) - Constructor for class org.apache.flink.runtime.taskexecutor.rpc.RpcKvStateRegistryListener
 
RpcMethod - Annotation Type in org.apache.flink.runtime.rpc
Annotation for rpc method in a RpcEndpoint implementation.
RpcPartitionStateChecker - Class in org.apache.flink.runtime.taskexecutor.rpc
 
RpcPartitionStateChecker(UUID, JobMasterGateway) - Constructor for class org.apache.flink.runtime.taskexecutor.rpc.RpcPartitionStateChecker
 
RpcResultPartitionConsumableNotifier - Class in org.apache.flink.runtime.taskexecutor.rpc
 
RpcResultPartitionConsumableNotifier(UUID, JobMasterGateway, Executor, Time) - Constructor for class org.apache.flink.runtime.taskexecutor.rpc.RpcResultPartitionConsumableNotifier
 
RpcService - Interface in org.apache.flink.runtime.rpc
Interface for rpc services.
RpcTaskManagerGateway - Class in org.apache.flink.runtime.jobmaster
Implementation of the TaskManagerGateway for Flink's RPC system
RpcTaskManagerGateway(TaskExecutorGateway, UUID) - Constructor for class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
RpcTimeout - Annotation Type in org.apache.flink.runtime.rpc
Annotation for RpcGateway methods to specify an additional timeout parameter for the returned future to be completed.
run() - Method in class org.apache.flink.api.common.io.FileInputFormat.InputSplitOpenThread
 
run(String[]) - Method in class org.apache.flink.client.CliFrontend
Executions the run action.
run(PackagedProgram, int) - Method in class org.apache.flink.client.program.ClusterClient
General purpose method to run a user jar from the CliFrontend in either blocking or detached mode, depending on whether setDetached(true) or setDetached(false).
run(JobWithJars, int) - Method in class org.apache.flink.client.program.ClusterClient
 
run(JobWithJars, int, SavepointRestoreSettings) - Method in class org.apache.flink.client.program.ClusterClient
Runs a program on the Flink cluster to which this client is connected.
run(FlinkPlan, List<URL>, List<URL>, ClassLoader) - Method in class org.apache.flink.client.program.ClusterClient
 
run(FlinkPlan, List<URL>, List<URL>, ClassLoader, SavepointRestoreSettings) - Method in class org.apache.flink.client.program.ClusterClient
 
run(JobGraph, ClassLoader) - Method in class org.apache.flink.client.program.ClusterClient
Submits a JobGraph blocking.
run() - Method in class org.apache.flink.core.testutils.CheckedThread
This method is final - thread work should go into the CheckedThread.go() method instead.
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.AbstractGraphAnalytic
 
run(DataSet<T>) - Method in class org.apache.flink.graph.asm.dataset.AbstractDataSetAnalytic
 
run(DataSet<T>) - Method in class org.apache.flink.graph.asm.dataset.ChecksumHashCode
 
run(DataSet<T>) - Method in class org.apache.flink.graph.asm.dataset.Collect
 
run(DataSet<T>) - Method in class org.apache.flink.graph.asm.dataset.Count
 
run(DataSet<T>) - Method in interface org.apache.flink.graph.asm.dataset.DataSetAnalytic
All DataSetAnalytic processing must be terminated by an OutputFormat and obtained via accumulators rather than returned by a DataSet.
run(Graph<K, Double, Double>) - Method in class org.apache.flink.graph.examples.GSAPageRank
 
run(Graph<K, Double, Double>) - Method in class org.apache.flink.graph.examples.PageRank
 
run(GraphAlgorithm<K, VV, EV, T>) - Method in class org.apache.flink.graph.Graph
 
run(GraphAnalytic<K, VV, EV, T>) - Method in class org.apache.flink.graph.Graph
A GraphAnalytic is similar to a GraphAlgorithm but is terminal and results are retrieved via accumulators.
run(Graph<K, VV, EV>) - Method in interface org.apache.flink.graph.GraphAlgorithm
 
run(Graph<K, VV, EV>) - Method in interface org.apache.flink.graph.GraphAnalytic
All GraphAnalytic processing must be terminated by an OutputFormat.
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.clustering.directed.AverageClusteringCoefficient
 
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient
 
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus
 
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.clustering.undirected.AverageClusteringCoefficient
 
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient
 
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.clustering.undirected.TriadicCensus
 
run(Graph<K, Long, Double>) - Method in class org.apache.flink.graph.library.CommunityDetection
 
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.ConnectedComponents
 
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.GSAConnectedComponents
 
run(Graph<K, VV, Double>) - Method in class org.apache.flink.graph.library.GSASingleSourceShortestPaths
 
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.LabelPropagation
 
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.metric.ChecksumHashCode
 
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.metric.directed.EdgeMetrics
 
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics
 
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.metric.undirected.EdgeMetrics
 
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics
 
run(Graph<K, VV, Double>) - Method in class org.apache.flink.graph.library.SingleSourceShortestPaths
 
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.Summarization
 
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.TriangleEnumerator
 
run(GraphAlgorithm<K, VV, EV, T>, TypeInformation<T>, ClassTag<T>) - Method in class org.apache.flink.graph.scala.Graph
 
run(GraphAnalytic<K, VV, EV, T>, TypeInformation<T>, ClassTag<T>) - Method in class org.apache.flink.graph.scala.Graph
A GraphAnalytic is similar to a GraphAlgorithm but is terminal and results are retrieved via accumulators.
run(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingDataSet
 
run(Graph<IN_K, IN_VV, IN_EV>) - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingGraph
 
run(String[]) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosApplicationMasterRunner
The instance entry point for the Mesos AppMaster.
run() - Method in class org.apache.flink.python.api.streaming.util.StreamPrinter
 
run() - Method in class org.apache.flink.runtime.blob.BlobServer
 
run() - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
Cleans up blobs which are not referenced anymore
run() - Method in class org.apache.flink.runtime.heartbeat.HeartbeatManagerSenderImpl
 
run() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
run() - Method in class org.apache.flink.runtime.iterative.task.IterationHeadTask
 
run() - Method in class org.apache.flink.runtime.iterative.task.IterationIntermediateTask
 
run() - Method in class org.apache.flink.runtime.iterative.task.IterationTailTask
 
run() - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
 
run() - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
run() - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
 
run() - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
 
run() - Method in class org.apache.flink.runtime.operators.AllReduceDriver
 
run() - Method in class org.apache.flink.runtime.operators.BatchTask
 
run() - Method in class org.apache.flink.runtime.operators.CoGroupDriver
 
run() - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
 
run() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
 
run() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
 
run() - Method in class org.apache.flink.runtime.operators.CrossDriver
 
run() - Method in interface org.apache.flink.runtime.operators.Driver
The main operation method of the task.
run() - Method in class org.apache.flink.runtime.operators.FlatMapDriver
 
run() - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
 
run() - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
 
run() - Method in class org.apache.flink.runtime.operators.JoinDriver
 
run() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
 
run() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
 
run() - Method in class org.apache.flink.runtime.operators.MapDriver
 
run() - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
 
run() - Method in class org.apache.flink.runtime.operators.NoOpDriver
 
run() - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
 
run() - Method in class org.apache.flink.runtime.operators.ReduceDriver
 
run() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
Implements exception handling and delegates to go().
run() - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
 
run() - Method in class org.apache.flink.runtime.state.DoneFuture
 
run() - Method in class org.apache.flink.runtime.taskmanager.MemoryLogger
 
run() - Method in class org.apache.flink.runtime.taskmanager.Task
The core work method that bootstraps the task and executes it code
run() - Method in class org.apache.flink.runtime.util.JvmShutdownSafeguard
 
run() - Method in class org.apache.flink.runtime.util.ProcessShutDownThread
 
run() - Method in class org.apache.flink.runtime.webmonitor.history.HistoryServer
 
run(SourceFunction.SourceContext<OUT>) - Method in class org.apache.flink.storm.wrappers.SpoutWrapper
 
run(SourceFunction.SourceContext<TimestampedFileInputSplit>) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
 
run(SourceFunction.SourceContext<Tuple3<String, Long, Long>>) - Method in class org.apache.flink.streaming.api.functions.source.FileMonitoringFunction
Deprecated.
 
run(SourceFunction.SourceContext<T>) - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
 
run(SourceFunction.SourceContext<T>) - Method in class org.apache.flink.streaming.api.functions.source.FromIteratorFunction
 
run(SourceFunction.SourceContext<T>) - Method in class org.apache.flink.streaming.api.functions.source.FromSplittableIteratorFunction
 
run(SourceFunction.SourceContext<OUT>) - Method in class org.apache.flink.streaming.api.functions.source.InputFormatSourceFunction
 
run(SourceFunction.SourceContext<String>) - Method in class org.apache.flink.streaming.api.functions.source.SocketTextStreamFunction
 
run(SourceFunction.SourceContext<T>) - Method in interface org.apache.flink.streaming.api.functions.source.SourceFunction
Starts the source.
run(SourceFunction.SourceContext<Long>) - Method in class org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
 
run() - Method in class org.apache.flink.streaming.api.operators.async.Emitter
 
run(Object, StreamStatusMaintainer) - Method in class org.apache.flink.streaming.api.operators.StreamSource
 
run(Object, StreamStatusMaintainer, Output<StreamRecord<OUT>>) - Method in class org.apache.flink.streaming.api.operators.StreamSource
 
run(SourceFunction.SourceContext<T>) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
 
run() - Method in class org.apache.flink.streaming.connectors.kafka.internal.KafkaConsumerThread
 
run() - Method in class org.apache.flink.streaming.connectors.kafka.internals.PeriodicOffsetCommitter
 
run(SourceFunction.SourceContext<NiFiDataPacket>) - Method in class org.apache.flink.streaming.connectors.nifi.NiFiSource
 
run(SourceFunction.SourceContext<OUT>) - Method in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
 
run(SourceFunction.SourceContext<String>) - Method in class org.apache.flink.streaming.connectors.twitter.TwitterSource
 
run(SourceFunction.SourceContext) - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditsSource
 
run(SourceFunction.SourceContext<Integer>) - Method in class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.FiniteNewDataSource
 
run(SourceFunction.SourceContext<Integer>) - Method in class org.apache.flink.streaming.examples.ml.IncrementalLearningSkeleton.FiniteTrainingDataSource
 
run() - Method in class org.apache.flink.streaming.runtime.tasks.OneInputStreamTask
 
run() - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
 
run() - Method in class org.apache.flink.streaming.runtime.tasks.StoppableSourceStreamTask
 
run() - Method in class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
 
run() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
run() - Method in class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
 
run(SourceFunction.SourceContext<Object>) - Method in class org.apache.flink.streaming.scala.examples.async.SimpleSource
 
run(String[]) - Method in class org.apache.flink.yarn.AbstractYarnFlinkApplicationMasterRunner
The instance entry point for the YARN application master.
run(String[]) - Method in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
 
run(String[]) - Method in class org.apache.flink.yarn.YarnApplicationMasterRunner
The instance entry point for the YARN application master.
run(String[]) - Method in class org.apache.flink.yarn.YarnTaskExecutorRunner
The instance entry point for the YARN task executor.
runApplicationMaster(Configuration) - Method in class org.apache.flink.yarn.AbstractYarnFlinkApplicationMasterRunner
The main work method, must run as a privileged action.
runApplicationMaster(Configuration) - Method in class org.apache.flink.yarn.YarnApplicationMasterRunner
The main work method, must run as a privileged action.
runApplicationMaster(Configuration) - Method in class org.apache.flink.yarn.YarnFlinkApplicationMasterRunner
 
RunAsync - Class in org.apache.flink.runtime.rpc.akka.messages
Message for asynchronous runnable invocations
RunAsync(Runnable, long) - Constructor for class org.apache.flink.runtime.rpc.akka.messages.RunAsync
Creates a new RunAsync message.
runAsync(Runnable) - Method in interface org.apache.flink.runtime.rpc.MainThreadExecutable
Execute the runnable in the main thread of the underlying RPC endpoint.
runAsync(Runnable) - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
Execute the runnable in the main thread of the underlying RPC endpoint.
runDetached(JobGraph, ClassLoader) - Method in class org.apache.flink.client.program.ClusterClient
Submits a JobGraph detached.
runDetached(JobGraph) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
This method executes a job in detached mode.
runDetached(JobGraph) - Method in class org.apache.flink.runtime.minicluster.MiniClusterJobDispatcher
This method executes a job in detached mode.
runFetchLoop() - Method in class org.apache.flink.streaming.connectors.kafka.internal.Kafka09Fetcher
 
runFetchLoop() - Method in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
 
runFetchLoop() - Method in class org.apache.flink.streaming.connectors.kafka.internals.Kafka08Fetcher
 
runFlinkZkQuorumPeer(String, int) - Static method in class org.apache.flink.runtime.zookeeper.FlinkZooKeeperQuorumPeer
Runs a ZooKeeper QuorumPeer if further peers are configured or a single ZooKeeperServer if no further peers are configured.
runGatherSumApplyIteration(GatherFunction<VV, EV, M>, SumFunction<VV, EV, M>, ApplyFunction<K, VV, M>, int) - Method in class org.apache.flink.graph.Graph
Runs a Gather-Sum-Apply iteration on the graph.
runGatherSumApplyIteration(GatherFunction<VV, EV, M>, SumFunction<VV, EV, M>, ApplyFunction<K, VV, M>, int, GSAConfiguration) - Method in class org.apache.flink.graph.Graph
Runs a Gather-Sum-Apply iteration on the graph with configuration options.
runGatherSumApplyIteration(GatherFunction<VV, EV, M>, SumFunction<VV, EV, M>, ApplyFunction<K, VV, M>, int) - Method in class org.apache.flink.graph.scala.Graph
Runs a Gather-Sum-Apply iteration on the graph.
runGatherSumApplyIteration(GatherFunction<VV, EV, M>, SumFunction<VV, EV, M>, ApplyFunction<K, VV, M>, int, GSAConfiguration) - Method in class org.apache.flink.graph.scala.Graph
Runs a Gather-Sum-Apply iteration on the graph with configuration options.
runHepPlanner(HepMatchOrder, RuleSet, RelNode, RelTraitSet) - Method in class org.apache.flink.table.api.TableEnvironment
run HEP planner
runIfNotDoneAndGet(RunnableFuture<T>) - Static method in class org.apache.flink.util.FutureUtil
 
runInteractiveCli(YarnClusterClient, boolean) - Static method in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.EdgeDegreesPair
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.EdgeSourceDegrees
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.EdgeTargetDegrees
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexInDegree
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexOutDegree
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeDegreePair
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeSourceDegree
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeTargetDegree
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.VertexDegree
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.degree.filter.undirected.MaximumDegree
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.simple.directed.Simplify
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.asm.simple.undirected.Simplify
 
runInternal(Graph<K, VV, OLD>) - Method in class org.apache.flink.graph.asm.translate.TranslateEdgeValues
 
runInternal(Graph<OLD, VV, EV>) - Method in class org.apache.flink.graph.asm.translate.TranslateGraphIds
 
runInternal(Graph<K, OLD, EV>) - Method in class org.apache.flink.graph.asm.translate.TranslateVertexValues
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.clustering.directed.TriangleListing
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.clustering.undirected.TriangleListing
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.link_analysis.HITS
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.link_analysis.PageRank
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.similarity.AdamicAdar
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.library.similarity.JaccardIndex
 
runInternal(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingDataSet
The implementation of the algorithm, renamed from GraphAlgorithm.run(Graph).
runInternal(Graph<IN_K, IN_VV, IN_EV>) - Method in class org.apache.flink.graph.utils.proxy.GraphAlgorithmWrappingGraph
The implementation of the algorithm, renamed from GraphAlgorithm.run(Graph).
runJobBlocking(JobGraph) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
This method runs a job in blocking mode.
runJobBlocking(JobGraph) - Method in class org.apache.flink.runtime.minicluster.MiniClusterJobDispatcher
This method runs a job in blocking mode.
runJobManager(Configuration, JobManagerMode, String, int) - Method in class org.apache.flink.runtime.jobmanager.JobManager$
Starts and runs the JobManager with all its components.
runJobManager(Configuration, JobManagerMode, String, Iterator<Integer>) - Method in class org.apache.flink.runtime.jobmanager.JobManager$
Starts and runs the JobManager with all its components trying to bind to a port in the specified range.
runJobManager(Configuration, JobManagerMode, String, int) - Static method in class org.apache.flink.runtime.jobmanager.JobManager
Starts and runs the JobManager with all its components.
runJobManager(Configuration, JobManagerMode, String, Iterator<Integer>) - Static method in class org.apache.flink.runtime.jobmanager.JobManager
Starts and runs the JobManager with all its components trying to bind to a port in the specified range.
Runner - Class in org.apache.flink.graph
This default main class executes Flink drivers.
Runner() - Constructor for class org.apache.flink.graph.Runner
 
RUNNING - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
RUNNING function to be used within MATCH_RECOGNIZE.
running() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
running - Variable in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
running - Variable in class org.apache.flink.runtime.operators.BatchTask
The flag that tags the task as still running.
running - Variable in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
 
running - Variable in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
 
running - Variable in class org.apache.flink.runtime.operators.JoinDriver
 
running - Variable in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
 
running - Variable in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
 
running() - Method in class org.apache.flink.streaming.scala.examples.async.SimpleSource
 
running() - Method in class org.apache.flink.yarn.ApplicationClient
 
Running$() - Constructor for class org.apache.flink.mesos.scheduler.TaskMonitor.Running$
 
RunningJobs(Iterable<ExecutionGraph>) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RunningJobs
 
RunningJobs() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RunningJobs
 
runningJobs() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RunningJobs
 
runningJobs() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RunningJobsStatus
 
RunningJobs$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RunningJobs$
 
RunningJobsRegistry - Interface in org.apache.flink.runtime.highavailability
A simple registry that tracks if a certain job is pending execution, running, or completed.
RunningJobsRegistry.JobSchedulingStatus - Enum in org.apache.flink.runtime.highavailability
The scheduling status of a job, as maintained by the RunningJobsRegistry.
RunningJobsStatus(Iterable<JobStatusMessage>) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RunningJobsStatus
 
RunningJobsStatus() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RunningJobsStatus
 
RunningJobsStatus$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.RunningJobsStatus$
 
runningTasks() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
runningTasks() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
Registry of all tasks currently executed by this TaskManager
runningTasks() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
runOperation(CustomUnaryOperation<T, X>) - Method in class org.apache.flink.api.java.DataSet
Runs a CustomUnaryOperation on the data set.
RunOptions - Class in org.apache.flink.client.cli
Command line options for the RUN command.
RunOptions(CommandLine) - Constructor for class org.apache.flink.client.cli.RunOptions
 
runPrivileged(Configuration, Configuration) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosApplicationMasterRunner
The main work method, must run as a privileged action.
runScatterGatherIteration(ScatterFunction<K, VV, M, EV>, GatherFunction<K, VV, M>, int) - Method in class org.apache.flink.graph.Graph
Runs a ScatterGather iteration on the graph.
runScatterGatherIteration(ScatterFunction<K, VV, M, EV>, GatherFunction<K, VV, M>, int, ScatterGatherConfiguration) - Method in class org.apache.flink.graph.Graph
Runs a ScatterGather iteration on the graph with configuration options.
runScatterGatherIteration(ScatterFunction<K, VV, M, EV>, GatherFunction<K, VV, M>, int) - Method in class org.apache.flink.graph.scala.Graph
Runs a scatter-gather iteration on the graph.
runScatterGatherIteration(ScatterFunction<K, VV, M, EV>, GatherFunction<K, VV, M>, int, ScatterGatherConfiguration) - Method in class org.apache.flink.graph.scala.Graph
Runs a scatter-gather iteration on the graph with configuration options.
runSecured(Callable<T>) - Method in interface org.apache.flink.runtime.security.SecurityContext
 
runTaskExecutor(Configuration) - Method in class org.apache.flink.yarn.YarnTaskExecutorRunner
The main work method, must run as a privileged action.
runTaskManager(String[], Class<? extends TaskManager>) - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerRunner
 
runTaskManager(String, ResourceID, int, Configuration, HighAvailabilityServices) - Method in class org.apache.flink.runtime.taskmanager.TaskManager$
Starts and runs the TaskManager.
runTaskManager(String, ResourceID, int, Configuration, HighAvailabilityServices, Class<? extends TaskManager>) - Method in class org.apache.flink.runtime.taskmanager.TaskManager$
Starts and runs the TaskManager.
runTaskManager(String, ResourceID, int, Configuration, HighAvailabilityServices) - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
Starts and runs the TaskManager.
runTaskManager(String, ResourceID, int, Configuration, HighAvailabilityServices, Class<? extends TaskManager>) - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
Starts and runs the TaskManager.
RUNTIME_FAILURE_RETURN_CODE() - Method in class org.apache.flink.runtime.jobmanager.JobManager$
 
RUNTIME_FAILURE_RETURN_CODE() - Static method in class org.apache.flink.runtime.jobmanager.JobManager
 
RUNTIME_FAILURE_RETURN_CODE() - Method in class org.apache.flink.runtime.taskmanager.TaskManager$
Return code for critical errors during the runtime
RUNTIME_FAILURE_RETURN_CODE() - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
Return code for critical errors during the runtime
RUNTIME_HASH_JOIN_BLOOM_FILTERS_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Parameter to switch hash join bloom filters for spilled partitions on and off.
RuntimeAggregatorRegistry - Class in org.apache.flink.runtime.iterative.task
 
RuntimeAggregatorRegistry(Collection<AggregatorWithName<?>>) - Constructor for class org.apache.flink.runtime.iterative.task.RuntimeAggregatorRegistry
 
RuntimeComparatorFactory<T> - Class in org.apache.flink.api.java.typeutils.runtime
 
RuntimeComparatorFactory() - Constructor for class org.apache.flink.api.java.typeutils.runtime.RuntimeComparatorFactory
 
RuntimeComparatorFactory(TypeComparator<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.RuntimeComparatorFactory
 
RuntimeContext - Interface in org.apache.flink.api.common.functions
A RuntimeContext contains information about the context in which functions are executed.
RuntimeEnvironment - Class in org.apache.flink.runtime.taskmanager
In implementation of the Environment.
RuntimeEnvironment(JobID, JobVertexID, ExecutionAttemptID, ExecutionConfig, TaskInfo, Configuration, Configuration, ClassLoader, MemoryManager, IOManager, BroadcastVariableManager, AccumulatorRegistry, TaskKvStateRegistry, InputSplitProvider, Map<String, Future<Path>>, ResultPartitionWriter[], InputGate[], CheckpointResponder, TaskManagerRuntimeInfo, TaskMetricGroup, Task) - Constructor for class org.apache.flink.runtime.taskmanager.RuntimeEnvironment
 
RuntimeEvent - Class in org.apache.flink.runtime.event
Subclasses of this event are recognized as events exchanged by the core runtime.
RuntimeEvent() - Constructor for class org.apache.flink.runtime.event.RuntimeEvent
 
RuntimeMonitorHandler - Class in org.apache.flink.runtime.webmonitor
The Netty channel handler that processes all HTTP requests.
RuntimeMonitorHandler(WebMonitorConfig, RequestHandler, JobManagerRetriever, Future<String>, FiniteDuration, boolean) - Constructor for class org.apache.flink.runtime.webmonitor.RuntimeMonitorHandler
 
RuntimeMonitorHandlerBase - Class in org.apache.flink.runtime.webmonitor
The Netty channel handler that processes all HTTP requests.
RuntimeMonitorHandlerBase(JobManagerRetriever, Future<String>, FiniteDuration, boolean) - Constructor for class org.apache.flink.runtime.webmonitor.RuntimeMonitorHandlerBase
 
RuntimePairComparatorFactory<T1,T2> - Class in org.apache.flink.api.java.typeutils.runtime
 
RuntimePairComparatorFactory() - Constructor for class org.apache.flink.api.java.typeutils.runtime.RuntimePairComparatorFactory
 
RuntimeSerializerFactory<T> - Class in org.apache.flink.api.java.typeutils.runtime
 
RuntimeSerializerFactory() - Constructor for class org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
 
RuntimeSerializerFactory(TypeSerializer<T>, Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
 
RuntimeUDFContext - Class in org.apache.flink.api.common.functions.util
A standalone implementation of the RuntimeContext, created by runtime UDF operators.
RuntimeUDFContext(TaskInfo, ClassLoader, ExecutionConfig, Map<String, Future<Path>>, Map<String, Accumulator<?, ?>>, MetricGroup) - Constructor for class org.apache.flink.api.common.functions.util.RuntimeUDFContext
 
runtimeUdfContext - Variable in class org.apache.flink.runtime.operators.BatchTask
The udf's runtime context.
runVertexCentricIteration(ComputeFunction<K, VV, EV, M>, MessageCombiner<K, M>, int) - Method in class org.apache.flink.graph.Graph
Runs a VertexCentricIteration on the graph.
runVertexCentricIteration(ComputeFunction<K, VV, EV, M>, MessageCombiner<K, M>, int, VertexCentricConfiguration) - Method in class org.apache.flink.graph.Graph
Runs a VertexCentricIteration on the graph with configuration options.
runVertexCentricIteration(ComputeFunction<K, VV, EV, M>, MessageCombiner<K, M>, int) - Method in class org.apache.flink.graph.scala.Graph
Runs a vertex-centric iteration on the graph.
runVertexCentricIteration(ComputeFunction<K, VV, EV, M>, MessageCombiner<K, M>, int, VertexCentricConfiguration) - Method in class org.apache.flink.graph.scala.Graph
Runs a vertex-centric iteration on the graph with configuration options.
runVolcanoPlanner(RuleSet, RelNode, RelTraitSet) - Method in class org.apache.flink.table.api.TableEnvironment
run VOLCANO planner
runWindowJoin(DataStream<Tuple2<String, Integer>>, DataStream<Tuple2<String, Integer>>, long) - Static method in class org.apache.flink.streaming.examples.join.WindowJoin
 
runYarnTaskManager(String[], Class<? extends YarnTaskManager>) - Static method in class org.apache.flink.yarn.YarnTaskManagerRunner
 

S

SafetyNetCloseableRegistry - Class in org.apache.flink.core.fs
This implementation of an AbstractCloseableRegistry registers WrappingProxyCloseable.
SafetyNetCloseableRegistry() - Constructor for class org.apache.flink.core.fs.SafetyNetCloseableRegistry
 
SafetyNetWrapperFileSystem - Class in org.apache.flink.core.fs
This is a WrappingProxy around FileSystem which (i) wraps all opened streams as ClosingFSDataInputStream or ClosingFSDataOutputStream and (ii) registers them to a SafetyNetCloseableRegistry.
SafetyNetWrapperFileSystem(FileSystem, SafetyNetCloseableRegistry) - Constructor for class org.apache.flink.core.fs.SafetyNetWrapperFileSystem
 
salary() - Method in class org.apache.flink.streaming.scala.examples.join.WindowJoin.Person
 
Salary(String, int) - Constructor for class org.apache.flink.streaming.scala.examples.join.WindowJoin.Salary
 
salary() - Method in class org.apache.flink.streaming.scala.examples.join.WindowJoin.Salary
 
Salary$() - Constructor for class org.apache.flink.streaming.scala.examples.join.WindowJoin.Salary$
 
SALARY_MAX() - Method in class org.apache.flink.streaming.scala.examples.join.WindowJoinSampleData$
 
SALARY_MAX() - Static method in class org.apache.flink.streaming.scala.examples.join.WindowJoinSampleData
 
SalarySource() - Constructor for class org.apache.flink.streaming.examples.join.WindowJoinSampleData.SalarySource
 
SalarySource() - Constructor for class org.apache.flink.streaming.scala.examples.join.WindowJoinSampleData.SalarySource
 
SameTypePairComparator<T> - Class in org.apache.flink.api.common.typeutils
 
SameTypePairComparator(TypeComparator<T>) - Constructor for class org.apache.flink.api.common.typeutils.SameTypePairComparator
 
sameTypeVars(Type, Type) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils
Checks whether two types are type variables describing the same.
sample(Iterator<T>) - Method in class org.apache.flink.api.java.sampling.BernoulliSampler
Sample the input elements, for each input element, take a Bernoulli trail for sampling.
sample(Iterator<T>) - Method in class org.apache.flink.api.java.sampling.DistributedRandomSampler
Combine the first phase and second phase in sequence, implemented for test purpose only.
sample(Iterator<T>) - Method in class org.apache.flink.api.java.sampling.PoissonSampler
Sample the input elements, for each input element, generate its count following a poisson distribution.
sample(Iterator<T>) - Method in class org.apache.flink.api.java.sampling.RandomSampler
Randomly sample the elements from input in sequence, and return the result iterator.
sample(DataSet<T>, boolean, double) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Generate a sample of DataSet by the probability fraction of each element.
sample(DataSet<T>, boolean, double, long) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Generate a sample of DataSet by the probability fraction of each element.
sampleId() - Method in class org.apache.flink.runtime.messages.StackTraceSampleMessages.SampleTaskStackTrace
 
sampleId() - Method in class org.apache.flink.runtime.messages.StackTraceSampleMessages.TriggerStackTraceSample
 
SampleInCoordinator<T> - Class in org.apache.flink.api.java.functions
SampleInCoordinator wraps the sample logic of the coordinator side (the second phase of distributed sample algorithm).
SampleInCoordinator(boolean, int, long) - Constructor for class org.apache.flink.api.java.functions.SampleInCoordinator
Create a function instance of SampleInCoordinator.
sampleInCoordinator(Iterator<IntermediateSampleData<T>>) - Method in class org.apache.flink.api.java.sampling.DistributedRandomSampler
Sample algorithm for the second phase.
SampleInPartition<T> - Class in org.apache.flink.api.java.functions
SampleInPartition wraps the sample logic on the partition side (the first phase of distributed sample algorithm).
SampleInPartition(boolean, int, long) - Constructor for class org.apache.flink.api.java.functions.SampleInPartition
Create a function instance of SampleInPartition.
sampleInPartition(Iterator<T>) - Method in class org.apache.flink.api.java.sampling.DistributedRandomSampler
Sample algorithm for the first phase.
sampleInPartition(Iterator<T>) - Method in class org.apache.flink.api.java.sampling.ReservoirSamplerWithoutReplacement
 
sampleInPartition(Iterator<T>) - Method in class org.apache.flink.api.java.sampling.ReservoirSamplerWithReplacement
 
Sampler() - Constructor for class org.apache.flink.examples.java.misc.PiEstimation.Sampler
 
SampleTaskStackTrace(int, ExecutionAttemptID, Time, int, int, List<StackTraceElement[]>, ActorRef) - Constructor for class org.apache.flink.runtime.messages.StackTraceSampleMessages.SampleTaskStackTrace
 
SampleTaskStackTrace$() - Constructor for class org.apache.flink.runtime.messages.StackTraceSampleMessages.SampleTaskStackTrace$
 
SampleWithFraction<T> - Class in org.apache.flink.api.java.functions
A map partition function wrapper for sampling algorithms with fraction, the sample algorithm takes the partition iterator as input.
SampleWithFraction(boolean, double, long) - Constructor for class org.apache.flink.api.java.functions.SampleWithFraction
Create a function instance of SampleWithFraction.
sampleWithSize(DataSet<T>, boolean, int) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Generate a sample of DataSet which contains fixed size elements.
sampleWithSize(DataSet<T>, boolean, int, long) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Generate a sample of DataSet which contains fixed size elements.
sanityCheck() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraPojoSinkBuilder
 
sanityCheck() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
 
sanityCheck() - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraTupleSinkBuilder
 
satisfies(RelTrait) - Method in class org.apache.flink.table.plan.nodes.datastream.AccModeTrait
 
satisfies(RelTrait) - Method in class org.apache.flink.table.plan.nodes.datastream.UpdateAsRetractionTrait
 
savepoint(String[]) - Method in class org.apache.flink.client.CliFrontend
Executes the SAVEPOINT action.
Savepoint - Interface in org.apache.flink.runtime.checkpoint.savepoint
Savepoints are manually-triggered snapshots from which a program can be resumed on submission.
SAVEPOINT_DIRECTORY_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
The default directory for savepoints.
SAVEPOINT_FS_DIRECTORY_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
This key was used in Flink versions <= 1.1.X with the savepoint backend configuration. We now always use the FileSystem for savepoints. For this, the only relevant config key is ConfigConstants.SAVEPOINT_DIRECTORY_KEY.
savepointDirectory() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.CancelJobWithSavepoint
 
savepointDirectory() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.TriggerSavepoint
 
SavepointLoader - Class in org.apache.flink.runtime.checkpoint.savepoint
The SavepointLoader is a utility to load and verify a Savepoint, and to create a checkpoint from it.
SavepointOptions - Class in org.apache.flink.client.cli
Command line options for the SAVEPOINT command
SavepointOptions(CommandLine) - Constructor for class org.apache.flink.client.cli.SavepointOptions
 
savepointPath() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.CancellationSuccess
 
savepointPath() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.DisposeSavepoint
 
savepointPath() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.TriggerSavepointSuccess
 
SavepointRestoreSettings - Class in org.apache.flink.runtime.jobgraph
Savepoint restore settings.
SavepointSerializer<T extends Savepoint> - Interface in org.apache.flink.runtime.checkpoint.savepoint
Serializer for Savepoint instances.
SavepointSerializers - Class in org.apache.flink.runtime.checkpoint.savepoint
Helper to access SavepointSerializer for a specific savepoint version.
SavepointSerializers() - Constructor for class org.apache.flink.runtime.checkpoint.savepoint.SavepointSerializers
 
savepointSettings - Variable in class org.apache.flink.client.program.ContextEnvironment
 
SavepointStore - Class in org.apache.flink.runtime.checkpoint.savepoint
Utilities for storing and loading savepoint meta data files.
SavepointStore() - Constructor for class org.apache.flink.runtime.checkpoint.savepoint.SavepointStore
 
SavepointV0 - Class in org.apache.flink.migration.runtime.checkpoint.savepoint
Savepoint version 0.
SavepointV0(long, Collection<TaskState>) - Constructor for class org.apache.flink.migration.runtime.checkpoint.savepoint.SavepointV0
 
SavepointV0Serializer - Class in org.apache.flink.migration.runtime.checkpoint.savepoint
SavepointV1 - Class in org.apache.flink.runtime.checkpoint.savepoint
Savepoint version 0.
SavepointV1(long, Collection<TaskState>) - Constructor for class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
 
SavepointV1Serializer - Class in org.apache.flink.runtime.checkpoint.savepoint
Deserializer for checkpoints written in format 1 (Flink 1.2.x format)
SavepointV2 - Class in org.apache.flink.runtime.checkpoint.savepoint
The persistent checkpoint metadata, format version 2.
SavepointV2(long, Collection<TaskState>) - Constructor for class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
Deprecated.
Only kept for backwards-compatibility with versions < 1.3. Will be removed in the future.
SavepointV2(long, Collection<OperatorState>, Collection<MasterState>) - Constructor for class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
 
scal(double, Vector) - Method in class org.apache.flink.ml.math.BLAS$
x = a * x
scal(double, Vector) - Static method in class org.apache.flink.ml.math.BLAS
x = a * x
ScalaAggregateOperator<IN> - Class in org.apache.flink.api.scala.operators
This operator represents the application of a "aggregate" operation on a data set, and the result data set produced by the function.
ScalaAggregateOperator(DataSet<IN>, Aggregations, int) - Constructor for class org.apache.flink.api.scala.operators.ScalaAggregateOperator
Non grouped aggregation
ScalaAggregateOperator(Grouping<IN>, Aggregations, int) - Constructor for class org.apache.flink.api.scala.operators.ScalaAggregateOperator
Grouped aggregation
ScalaAggregateOperator.AggregatingUdf<T extends scala.Product> - Class in org.apache.flink.api.scala.operators
 
ScalaAllWindowFunction<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.api.scala.function.util
A wrapper function that exposes a Scala Function3 as a Java AllWindowFunction.
ScalaAllWindowFunction(Function3<W, Iterable<IN>, Collector<OUT>, BoxedUnit>) - Constructor for class org.apache.flink.streaming.api.scala.function.util.ScalaAllWindowFunction
 
ScalaAllWindowFunctionWrapper<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.api.scala.function.util
A wrapper function that exposes a Scala WindowFunction as a JavaWindow function.
ScalaAllWindowFunctionWrapper(AllWindowFunction<IN, OUT, W>) - Constructor for class org.apache.flink.streaming.api.scala.function.util.ScalaAllWindowFunctionWrapper
 
scalaBenv() - Method in class org.apache.flink.api.scala.FlinkILoop
 
scalaClean(F) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Returns a "closure-cleaned" version of the given function.
ScalaCsvOutputFormat<T extends scala.Product> - Class in org.apache.flink.api.scala.operators
This is an OutputFormat to serialize Scala Tuples to text.
ScalaCsvOutputFormat(Path) - Constructor for class org.apache.flink.api.scala.operators.ScalaCsvOutputFormat
Creates an instance of CsvOutputFormat.
ScalaCsvOutputFormat(Path, String) - Constructor for class org.apache.flink.api.scala.operators.ScalaCsvOutputFormat
Creates an instance of CsvOutputFormat.
ScalaCsvOutputFormat(Path, String, String) - Constructor for class org.apache.flink.api.scala.operators.ScalaCsvOutputFormat
Creates an instance of CsvOutputFormat.
scalaDec2Literal(BigDecimal) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionConversions
 
ScalaEnumSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.scala.typeutils.EnumValueSerializer.ScalaEnumSerializerConfigSnapshot
 
ScalaEnumSerializerConfigSnapshot(E) - Constructor for class org.apache.flink.api.scala.typeutils.EnumValueSerializer.ScalaEnumSerializerConfigSnapshot
 
ScalaEnumSerializerConfigSnapshot$() - Constructor for class org.apache.flink.api.scala.typeutils.EnumValueSerializer.ScalaEnumSerializerConfigSnapshot$
 
ScalaFoldFunction<T,R> - Class in org.apache.flink.streaming.api.scala.function.util
A wrapper function that exposes a Scala Function2 as a FoldFunction.
ScalaFoldFunction(Function2<R, T, R>) - Constructor for class org.apache.flink.streaming.api.scala.function.util.ScalaFoldFunction
 
scalaFuture - Variable in class org.apache.flink.runtime.concurrent.impl.FlinkFuture
 
ScalaGauge<T> - Class in org.apache.flink.api.scala.metrics
This class allows the concise definition of a gauge from Scala using function references.
ScalaGauge(Function0<T>) - Constructor for class org.apache.flink.api.scala.metrics.ScalaGauge
 
ScalaGauge$ - Class in org.apache.flink.api.scala.metrics
 
ScalaGauge$() - Constructor for class org.apache.flink.api.scala.metrics.ScalaGauge$
 
ScalaNothingTypeInfo - Class in org.apache.flink.api.scala.typeutils
 
ScalaNothingTypeInfo() - Constructor for class org.apache.flink.api.scala.typeutils.ScalaNothingTypeInfo
 
ScalaOptionSerializerConfigSnapshot<E> - Class in org.apache.flink.api.scala.typeutils
ScalaOptionSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.scala.typeutils.ScalaOptionSerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
ScalaOptionSerializerConfigSnapshot(TypeSerializer<E>) - Constructor for class org.apache.flink.api.scala.typeutils.ScalaOptionSerializerConfigSnapshot
 
ScalaProcessAllWindowFunctionWrapper<IN,OUT,W extends Window> - Class in org.apache.flink.streaming.api.scala.function.util
A wrapper function that exposes a Scala ProcessWindowFunction as a ProcessWindowFunction function.
ScalaProcessAllWindowFunctionWrapper(ProcessAllWindowFunction<IN, OUT, W>) - Constructor for class org.apache.flink.streaming.api.scala.function.util.ScalaProcessAllWindowFunctionWrapper
 
ScalaProcessWindowFunctionWrapper<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.api.scala.function.util
A wrapper function that exposes a Scala ProcessWindowFunction as a ProcessWindowFunction function.
ScalaProcessWindowFunctionWrapper(ProcessWindowFunction<IN, OUT, KEY, W>) - Constructor for class org.apache.flink.streaming.api.scala.function.util.ScalaProcessWindowFunctionWrapper
 
scalar(String, String, double) - Static method in class org.apache.flink.mesos.Utils
Construct a scalar resource value.
SCALAR_QUERY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The internal "$SCALAR_QUERY" operator returns a scalar value from a record type.
ScalaReduceFunction<T> - Class in org.apache.flink.streaming.api.scala.function.util
A wrapper function that exposes a Scala Function2 as a ReduceFunction.
ScalaReduceFunction(Function2<T, T, T>) - Constructor for class org.apache.flink.streaming.api.scala.function.util.ScalaReduceFunction
 
scalarFunction() - Method in class org.apache.flink.table.expressions.ScalarFunctionCall
 
ScalarFunction - Class in org.apache.flink.table.functions
Base class for a user-defined scalar function.
ScalarFunction() - Constructor for class org.apache.flink.table.functions.ScalarFunction
 
ScalarFunctionCall - Class in org.apache.flink.table.expressions
Expression for calling a user-defined scalar functions.
ScalarFunctionCall(ScalarFunction, Seq<Expression>) - Constructor for class org.apache.flink.table.expressions.ScalarFunctionCall
 
ScalarFunctionCall$ - Class in org.apache.flink.table.expressions
 
ScalarFunctionCall$() - Constructor for class org.apache.flink.table.expressions.ScalarFunctionCall$
 
ScalarFunctionCallGen - Class in org.apache.flink.table.codegen.calls
Generates a call to user-defined ScalarFunction.
ScalarFunctionCallGen(ScalarFunction, Seq<TypeInformation<?>>, TypeInformation<?>) - Constructor for class org.apache.flink.table.codegen.calls.ScalarFunctionCallGen
 
ScalarOperators - Class in org.apache.flink.table.codegen.calls
 
ScalarOperators() - Constructor for class org.apache.flink.table.codegen.calls.ScalarOperators
 
ScalarOperators$ - Class in org.apache.flink.table.codegen.calls
 
ScalarOperators$() - Constructor for class org.apache.flink.table.codegen.calls.ScalarOperators$
 
ScalarSqlFunction - Class in org.apache.flink.table.functions.utils
Calcite wrapper for user-defined scalar functions.
ScalarSqlFunction(String, ScalarFunction, FlinkTypeFactory) - Constructor for class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
ScalarSqlFunction$ - Class in org.apache.flink.table.functions.utils
 
ScalarSqlFunction$() - Constructor for class org.apache.flink.table.functions.utils.ScalarSqlFunction$
 
scalaSenv() - Method in class org.apache.flink.api.scala.FlinkILoop
 
ScalaShellRemoteEnvironment - Class in org.apache.flink.api.java
Special version of RemoteEnvironment that has a reference to a FlinkILoop.
ScalaShellRemoteEnvironment(String, int, FlinkILoop, Configuration, String...) - Constructor for class org.apache.flink.api.java.ScalaShellRemoteEnvironment
Creates new ScalaShellRemoteEnvironment that has a reference to the FlinkILoop
ScalaShellRemoteStreamEnvironment - Class in org.apache.flink.api.java
 
ScalaShellRemoteStreamEnvironment(String, int, FlinkILoop, Configuration, String...) - Constructor for class org.apache.flink.api.java.ScalaShellRemoteStreamEnvironment
Creates a new RemoteStreamEnvironment that points to the master (JobManager) described by the given host name and port.
ScalaTrySerializerConfigSnapshot<E> - Class in org.apache.flink.api.scala.typeutils
ScalaTrySerializerConfigSnapshot() - Constructor for class org.apache.flink.api.scala.typeutils.ScalaTrySerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
ScalaTrySerializerConfigSnapshot(TypeSerializer<E>, TypeSerializer<Throwable>) - Constructor for class org.apache.flink.api.scala.typeutils.ScalaTrySerializerConfigSnapshot
 
ScalaWindowFunction<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.api.scala.function.util
A wrapper function that exposes a Scala Function4 as a Java WindowFunction.
ScalaWindowFunction(Function4<KEY, W, Iterable<IN>, Collector<OUT>, BoxedUnit>) - Constructor for class org.apache.flink.streaming.api.scala.function.util.ScalaWindowFunction
 
ScalaWindowFunctionWrapper<IN,OUT,KEY,W extends Window> - Class in org.apache.flink.streaming.api.scala.function.util
A wrapper function that exposes a Scala WindowFunction as a JavaWindow function.
ScalaWindowFunctionWrapper(WindowFunction<IN, OUT, KEY, W>) - Constructor for class org.apache.flink.streaming.api.scala.function.util.ScalaWindowFunctionWrapper
 
scale(V, Tuple2<Vector<Object>, Vector<Object>>, BreezeVectorConverter<V>) - Method in class org.apache.flink.ml.preprocessing.StandardScaler.StandardScalerTransformOperation
 
scan - Variable in class org.apache.flink.addons.hbase.AbstractTableInputFormat
 
scan(String...) - Method in class org.apache.flink.table.api.TableEnvironment
Scans a registered table and returns the resulting Table.
scan(Seq<String>) - Method in class org.apache.flink.table.api.TableEnvironment
Scans a registered table and returns the resulting Table.
scan(Iterable<String>) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
scan(String[]) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
scannedRows - Variable in class org.apache.flink.addons.hbase.AbstractTableInputFormat
 
ScatterFunction<K,VV,Message,EV> - Class in org.apache.flink.graph.spargel
The base class for functions that produce messages between vertices as a part of a ScatterGatherIteration.
ScatterFunction() - Constructor for class org.apache.flink.graph.spargel.ScatterFunction
 
ScatterGatherConfiguration - Class in org.apache.flink.graph.spargel
A ScatterGatherConfiguration object can be used to set the iteration name and degree of parallelism, to register aggregators and use broadcast sets in the GatherFunction and ScatterFunction The VertexCentricConfiguration object is passed as an argument to ( org.apache.flink.graph.spargel.GatherFunction, org.apache.flink.graph.spargel.ScatterFunction, int, ScatterGatherConfiguration).
ScatterGatherConfiguration() - Constructor for class org.apache.flink.graph.spargel.ScatterGatherConfiguration
 
ScatterGatherIteration<K,VV,Message,EV> - Class in org.apache.flink.graph.spargel
This class represents iterative graph computations, programmed in a scatter-gather perspective.
schedule(Runnable, long, TimeUnit) - Method in interface org.apache.flink.runtime.concurrent.ScheduledExecutor
Executes the given command after the given delay.
schedule(Callable<V>, long, TimeUnit) - Method in interface org.apache.flink.runtime.concurrent.ScheduledExecutor
Executes the given callable after the given delay.
schedule(Runnable, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter
 
schedule(Callable<V>, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter
 
scheduleAll(SlotProvider, boolean) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface org.apache.flink.runtime.concurrent.ScheduledExecutor
Executes the given command periodically.
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter
 
scheduleAtFixedRate(ProcessingTimeCallback, long, long) - Method in class org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
Registers a task to be executed repeatedly at a fixed rate.
scheduleAtFixedRate(ProcessingTimeCallback, long, long) - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
 
scheduleAtFixedRate(ProcessingTimeCallback, long, long) - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
Scheduled - Interface in org.apache.flink.metrics.reporter
Interface for reporters that actively send out data periodically.
ScheduledDropwizardReporter - Class in org.apache.flink.dropwizard
Base class for MetricReporter that wraps a Dropwizard Reporter.
ScheduledDropwizardReporter() - Constructor for class org.apache.flink.dropwizard.ScheduledDropwizardReporter
 
ScheduledExecutor - Interface in org.apache.flink.runtime.concurrent
Extension for the Executor interface which is enriched by method for scheduling tasks in the future.
ScheduledExecutorServiceAdapter - Class in org.apache.flink.runtime.concurrent
Adapter class for a ScheduledExecutorService which shall be used as a ScheduledExecutor.
ScheduledExecutorServiceAdapter(ScheduledExecutorService) - Constructor for class org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter
 
ScheduledUnit - Class in org.apache.flink.runtime.jobmanager.scheduler
 
ScheduledUnit(Execution) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
 
ScheduledUnit(Execution, SlotSharingGroup) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
 
ScheduledUnit(Execution, SlotSharingGroup, CoLocationConstraint) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
 
scheduleForExecution() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
scheduleForExecution(SlotProvider, boolean) - Method in class org.apache.flink.runtime.executiongraph.Execution
NOTE: This method only throws exceptions if it is in an illegal state to be scheduled, or if the tasks needs to be scheduled immediately and no resource is available.
scheduleForExecution() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
scheduleForExecution(SlotProvider, boolean) - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
ScheduleMode - Enum in org.apache.flink.runtime.jobgraph
The ScheduleMode decides how tasks of an execution graph are started.
scheduleOrUpdateConsumers(ResultPartitionID) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Schedule or updates consumers of the given result partition.
scheduleOrUpdateConsumers(UUID, ResultPartitionID) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
scheduleOrUpdateConsumers(UUID, ResultPartitionID, Time) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
Notifies the JobManager about available data for a produced partition.
ScheduleOrUpdateConsumers(JobID, ResultPartitionID) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.ScheduleOrUpdateConsumers
 
ScheduleOrUpdateConsumers$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.ScheduleOrUpdateConsumers$
 
scheduler() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
Scheduler - Class in org.apache.flink.runtime.jobmanager.scheduler
The scheduler is responsible for distributing the ready-to-run tasks among instances and slots.
Scheduler(Executor) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
Creates a new scheduler.
SchedulerProxy - Class in org.apache.flink.mesos.scheduler
This class reacts to callbacks from the Mesos scheduler driver.
SchedulerProxy(ActorRef) - Constructor for class org.apache.flink.mesos.scheduler.SchedulerProxy
 
scheduleRunAsync(Runnable, long) - Method in interface org.apache.flink.runtime.rpc.MainThreadExecutable
Execute the runnable in the main thread of the underlying RPC endpoint, with a delay of the given number of milliseconds.
scheduleRunAsync(Runnable, Time) - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
Execute the runnable in the main thread of the underlying RPC endpoint, with a delay of the given number of milliseconds.
scheduleRunAsync(Runnable, long, TimeUnit) - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
Execute the runnable in the main thread of the underlying RPC endpoint, with a delay of the given number of milliseconds.
scheduleRunnable(Runnable, long, TimeUnit) - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
scheduleRunnable(Runnable, long, TimeUnit) - Method in interface org.apache.flink.runtime.rpc.RpcService
Execute the runnable in the execution context of this RPC Service, as returned by RpcService.getExecutor(), after a scheduled delay.
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in interface org.apache.flink.runtime.concurrent.ScheduledExecutor
Executed the given command repeatedly with the given delay between the end of an execution and the start of the next execution.
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.apache.flink.runtime.concurrent.ScheduledExecutorServiceAdapter
 
schema - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
(Serializable) SerializationSchema for turning objects used with Flink into.
schema - Variable in class org.apache.flink.streaming.connectors.rabbitmq.RMQSink
 
schema - Variable in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
 
schema() - Method in class org.apache.flink.table.catalog.ExternalCatalogTable
 
scope - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
Collection of RelNode objects which correspond to a SELECT statement.
scope - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo
The remaining scope not covered by specific fields
SCOPE_DELIMITER - Static variable in class org.apache.flink.configuration.MetricOptions
The delimiter used to assemble the metric identifier.
SCOPE_HOST - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
 
SCOPE_INHERIT_PARENT - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
If the scope format starts with this character, then the parent components scope format will be used as a prefix.
SCOPE_JOB_ID - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
 
SCOPE_JOB_NAME - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
 
SCOPE_NAMING_JM - Static variable in class org.apache.flink.configuration.MetricOptions
The scope format string that is applied to all metrics scoped to a JobManager.
SCOPE_NAMING_JM_JOB - Static variable in class org.apache.flink.configuration.MetricOptions
The scope format string that is applied to all metrics scoped to a job on a JobManager.
SCOPE_NAMING_OPERATOR - Static variable in class org.apache.flink.configuration.MetricOptions
The scope format string that is applied to all metrics scoped to an operator.
SCOPE_NAMING_TASK - Static variable in class org.apache.flink.configuration.MetricOptions
The scope format string that is applied to all metrics scoped to a task.
SCOPE_NAMING_TM - Static variable in class org.apache.flink.configuration.MetricOptions
The scope format string that is applied to all metrics scoped to a TaskManager.
SCOPE_NAMING_TM_JOB - Static variable in class org.apache.flink.configuration.MetricOptions
The scope format string that is applied to all metrics scoped to a job on a TaskManager.
SCOPE_OPERATOR_NAME - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
 
SCOPE_SEPARATOR - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
 
SCOPE_TASK_ATTEMPT_ID - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
 
SCOPE_TASK_ATTEMPT_NUM - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
 
SCOPE_TASK_NAME - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
 
SCOPE_TASK_SUBTASK_INDEX - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
 
SCOPE_TASK_VERTEX_ID - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
 
SCOPE_TASKMANAGER_ID - Static variable in class org.apache.flink.runtime.metrics.scope.ScopeFormat
 
ScopeFormat - Class in org.apache.flink.runtime.metrics.scope
This class represents the format after which the "scope" (or namespace) of the various component metric groups is built.
ScopeFormat(String, ScopeFormat, String[]) - Constructor for class org.apache.flink.runtime.metrics.scope.ScopeFormat
 
ScopeFormats - Class in org.apache.flink.runtime.metrics.scope
A container for component scope formats.
ScopeFormats() - Constructor for class org.apache.flink.runtime.metrics.scope.ScopeFormats
Creates all default scope formats.
ScopeFormats(String, String, String, String, String, String) - Constructor for class org.apache.flink.runtime.metrics.scope.ScopeFormats
Creates all scope formats, based on the given scope format strings.
ScopeFormats(JobManagerScopeFormat, JobManagerJobScopeFormat, TaskManagerScopeFormat, TaskManagerJobScopeFormat, TaskScopeFormat, OperatorScopeFormat) - Constructor for class org.apache.flink.runtime.metrics.scope.ScopeFormats
Creates a ScopeFormats with the given scope formats.
scopeInfo - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump
The scope information for the stored metric.
searchNeighbors(Vector, double) - Method in class org.apache.flink.ml.nn.QuadTree
Finds all objects within a neighborhood of queryPoint of a specified radius scope is modified from original 2D version in: http://www.cs.trinity.edu/~mlewis/CSCI1321-F11/Code/src/util/Quadtree.scala
searchNeighborsSiblingQueue(Vector) - Method in class org.apache.flink.ml.nn.QuadTree
Used to zoom in on a region near a test point for a fast KNN query.
SECOND - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The SQL SECOND operator.
second() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Creates an interval of the given number of seconds.
SECOND() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
SECOND() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
SECOND() - Method in class org.apache.flink.table.expressions.TimeIntervalUnit$
 
SECOND() - Static method in class org.apache.flink.table.expressions.TimeIntervalUnit
 
SECOND() - Method in class org.apache.flink.table.expressions.TimePointUnit$
 
SECOND() - Static method in class org.apache.flink.table.expressions.TimePointUnit
 
secondBoltId - Static variable in class org.apache.flink.storm.exclamation.ExclamationTopology
 
secondDam() - Method in enum org.apache.flink.runtime.operators.DriverStrategy
 
seconds(long) - Static method in class org.apache.flink.api.common.time.Time
Creates a new Time that represents the given number of seconds.
seconds(long) - Static method in class org.apache.flink.streaming.api.windowing.time.Time
Creates a new Time that represents the given number of seconds.
seconds() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Creates an interval of the given number of seconds.
SECONDS() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
SECONDS() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
SecureAclProvider() - Constructor for class org.apache.flink.runtime.util.ZooKeeperUtils.SecureAclProvider
 
SecureTestEnvironment - Class in org.apache.flink.test.util
Helper SecureTestEnvironment to handle MiniKDC lifecycle.
SecureTestEnvironment() - Constructor for class org.apache.flink.test.util.SecureTestEnvironment
 
SECURITY_SSL_ALGORITHMS - Static variable in class org.apache.flink.configuration.ConfigConstants
The standard SSL algorithms to be supported More options here - http://docs.oracle.com/javase/8/docs/technotes/guides/security/StandardNames.html#ciphersuites
SECURITY_SSL_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
Enable SSL support
SECURITY_SSL_KEY_PASSWORD - Static variable in class org.apache.flink.configuration.ConfigConstants
secret to decrypt the server key
SECURITY_SSL_KEYSTORE - Static variable in class org.apache.flink.configuration.ConfigConstants
The Java keystore file containing the flink endpoint key and certificate
SECURITY_SSL_KEYSTORE_PASSWORD - Static variable in class org.apache.flink.configuration.ConfigConstants
secret to decrypt the keystore file
SECURITY_SSL_PROTOCOL - Static variable in class org.apache.flink.configuration.ConfigConstants
SSL protocol version to be supported
SECURITY_SSL_TRUSTSTORE - Static variable in class org.apache.flink.configuration.ConfigConstants
The truststore file containing the public CA certificates to verify the ssl peers
SECURITY_SSL_TRUSTSTORE_PASSWORD - Static variable in class org.apache.flink.configuration.ConfigConstants
Secret to decrypt the truststore
SECURITY_SSL_VERIFY_HOSTNAME - Static variable in class org.apache.flink.configuration.ConfigConstants
Flag to enable/disable hostname verification for the ssl connections
SecurityConfiguration(Configuration) - Constructor for class org.apache.flink.runtime.security.SecurityUtils.SecurityConfiguration
Create a security configuration from the global configuration.
SecurityConfiguration(Configuration, Configuration) - Constructor for class org.apache.flink.runtime.security.SecurityUtils.SecurityConfiguration
Create a security configuration from the global configuration.
SecurityConfiguration(Configuration, Configuration, List<? extends Class<? extends SecurityModule>>) - Constructor for class org.apache.flink.runtime.security.SecurityUtils.SecurityConfiguration
Create a security configuration from the global configuration.
SecurityContext - Interface in org.apache.flink.runtime.security
A security context with may be required to run a Callable.
SecurityInstallException(String) - Constructor for exception org.apache.flink.runtime.security.modules.SecurityModule.SecurityInstallException
 
SecurityInstallException(String, Throwable) - Constructor for exception org.apache.flink.runtime.security.modules.SecurityModule.SecurityInstallException
 
SecurityModule - Interface in org.apache.flink.runtime.security.modules
An installable security module.
SecurityModule.SecurityInstallException - Exception in org.apache.flink.runtime.security.modules
Indicates a problem with installing or uninstalling a security module.
SecurityOptions - Class in org.apache.flink.configuration
The set of configuration options relating to security.
SecurityOptions() - Constructor for class org.apache.flink.configuration.SecurityOptions
 
SecurityUtils - Class in org.apache.flink.runtime.security
 
SecurityUtils.SecurityConfiguration - Class in org.apache.flink.runtime.security
The global security configuration.
Seed$() - Constructor for class org.apache.flink.ml.classification.SVM.Seed$
 
Seed$() - Constructor for class org.apache.flink.ml.recommendation.ALS.Seed$
 
seek(long) - Method in class org.apache.flink.api.avro.FSDataInputStreamWrapper
 
seek(long) - Method in class org.apache.flink.api.common.io.InputStreamFSInputWrapper
 
seek(long) - Method in class org.apache.flink.core.fs.AbstractMultiFSDataInputStream
 
seek(long) - Method in class org.apache.flink.core.fs.FSDataInputStream
Seek to the given offset from the start of the file.
seek(long) - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
 
seek(long) - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
 
seek(long) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
 
seek(long) - Method in class org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
 
SeekableDataInputView - Interface in org.apache.flink.core.memory
Interface marking a DataInputView as seekable.
SeekableDataOutputView - Interface in org.apache.flink.core.memory
Interface marking a DataOutputView as seekable.
SeekableFileChannelInputView - Class in org.apache.flink.runtime.io.disk
A DataInputView that is backed by a BlockChannelReader, making it effectively a data input stream.
SeekableFileChannelInputView(IOManager, FileIOChannel.ID, MemoryManager, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.io.disk.SeekableFileChannelInputView
 
seekInput(MemorySegment, int, int) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
Sets the internal state of the view such that the next bytes will be read from the given memory segment, starting at the given position.
seekOutput(MemorySegment, int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
Sets the internal state to the given memory segment and the given position within the segment.
seekPartitionToBeginning(KafkaConsumer<?, ?>, TopicPartition) - Method in class org.apache.flink.streaming.connectors.kafka.internal.KafkaConsumerCallBridge
 
seekPartitionToBeginning(KafkaConsumer<?, ?>, TopicPartition) - Method in class org.apache.flink.streaming.connectors.kafka.internal.KafkaConsumerCallBridge010
 
seekPartitionToEnd(KafkaConsumer<?, ?>, TopicPartition) - Method in class org.apache.flink.streaming.connectors.kafka.internal.KafkaConsumerCallBridge
 
seekPartitionToEnd(KafkaConsumer<?, ?>, TopicPartition) - Method in class org.apache.flink.streaming.connectors.kafka.internal.KafkaConsumerCallBridge010
 
seekTo(long) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileSegmentReader
 
seekTo(long) - Method in interface org.apache.flink.runtime.io.disk.iomanager.BufferFileSegmentReader
 
seekToPosition(long) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockReader
 
seekToPosition(long) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileReader
 
seekToPosition(long) - Method in interface org.apache.flink.runtime.io.disk.iomanager.BlockChannelReader
 
seekToPosition(long) - Method in interface org.apache.flink.runtime.io.disk.iomanager.BufferFileReader
 
seekToPosition(long) - Method in class org.apache.flink.runtime.io.disk.iomanager.SynchronousBufferFileReader
 
segmentSize - Variable in class org.apache.flink.runtime.memory.AbstractPagedOutputView
 
segmentSize - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
The size of the segments used by the hash join buckets.
select(Map<String, List<IN>>) - Method in interface org.apache.flink.cep.PatternSelectFunction
Generates a result from the given map of events.
select(PatternSelectFunction<T, R>) - Method in class org.apache.flink.cep.PatternStream
Applies a select function to the detected pattern sequence.
select(PatternSelectFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.cep.PatternStream
Applies a select function to the detected pattern sequence.
select(PatternTimeoutFunction<T, L>, PatternSelectFunction<T, R>) - Method in class org.apache.flink.cep.PatternStream
Applies a select function to the detected pattern sequence.
select(PatternSelectFunction<T, R>, TypeInformation<R>) - Method in class org.apache.flink.cep.scala.PatternStream
Applies a select function to the detected pattern sequence.
select(PatternTimeoutFunction<T, L>, PatternSelectFunction<T, R>, TypeInformation<L>, TypeInformation<R>) - Method in class org.apache.flink.cep.scala.PatternStream
Applies a select function to the detected pattern sequence.
select(Function1<Map<String, Iterable<T>>, R>, TypeInformation<R>) - Method in class org.apache.flink.cep.scala.PatternStream
Applies a select function to the detected pattern sequence.
select(Function2<Map<String, Iterable<T>>, Object, L>, Function1<Map<String, Iterable<T>>, R>, TypeInformation<L>, TypeInformation<R>) - Method in class org.apache.flink.cep.scala.PatternStream
Applies a select function to the detected pattern sequence.
select(ExecutionMode, ShipStrategyType, boolean) - Static method in enum org.apache.flink.runtime.io.network.DataExchangeMode
Computes the mode of data exchange to be used for a given execution mode and ship strategy.
select(SplitStreamType<T>) - Method in class org.apache.flink.storm.util.StormStreamSelector
 
select(Fields) - Method in class org.apache.flink.storm.wrappers.StormTuple
 
select(OUT) - Method in interface org.apache.flink.streaming.api.collector.selector.OutputSelector
Method for selecting output names for the emitted objects when using the DataStream.split(org.apache.flink.streaming.api.collector.selector.OutputSelector<T>) method.
select(String...) - Method in class org.apache.flink.streaming.api.datastream.SplitStream
Sets the output names for which the next operator will receive values.
select(Seq<String>) - Method in class org.apache.flink.streaming.api.scala.SplitStream
Sets the output names for which the next operator will receive values.
select(Tuple5<Integer, Integer, Integer, Integer, Integer>) - Method in class org.apache.flink.streaming.examples.iteration.IterateExample.MySelector
 
select(Seq<Expression>) - Method in class org.apache.flink.table.api.GroupedTable
Performs a selection operation on a grouped table.
select(String) - Method in class org.apache.flink.table.api.GroupedTable
Performs a selection operation on a grouped table.
select(Seq<Expression>) - Method in class org.apache.flink.table.api.OverWindowedTable
 
select(String) - Method in class org.apache.flink.table.api.OverWindowedTable
 
select(Seq<Expression>) - Method in class org.apache.flink.table.api.Table
Performs a selection operation.
select(String) - Method in class org.apache.flink.table.api.Table
Performs a selection operation.
select(Seq<Expression>) - Method in class org.apache.flink.table.api.WindowGroupedTable
Performs a selection operation on a window grouped table.
select(String) - Method in class org.apache.flink.table.api.WindowGroupedTable
Performs a selection operation on a window grouped table.
SELECT_ALL_CHAR - Static variable in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
SELECT_ALL_CHAR_SCALA - Static variable in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
selectAllOutputs - Variable in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
SelectByMaxFunction<T extends Tuple> - Class in org.apache.flink.api.java.functions
 
SelectByMaxFunction(TupleTypeInfo<T>, int...) - Constructor for class org.apache.flink.api.java.functions.SelectByMaxFunction
Constructor which is overwriting the default constructor.
SelectByMaxFunction<T> - Class in org.apache.flink.api.scala
SelectByMaxFunction to work with Scala tuples
SelectByMaxFunction(TupleTypeInfoBase<T>, int[]) - Constructor for class org.apache.flink.api.scala.SelectByMaxFunction
 
SelectByMinFunction<T extends Tuple> - Class in org.apache.flink.api.java.functions
 
SelectByMinFunction(TupleTypeInfo<T>, int...) - Constructor for class org.apache.flink.api.java.functions.SelectByMinFunction
Constructor which is overwriting the default constructor.
SelectByMinFunction<T> - Class in org.apache.flink.api.scala
SelectByMinFunction to work with Scala tuples
SelectByMinFunction(TupleTypeInfoBase<T>, int[]) - Constructor for class org.apache.flink.api.scala.SelectByMinFunction
 
selectChannels(T, int) - Method in interface org.apache.flink.runtime.io.network.api.writer.ChannelSelector
Returns the logical channel indexes, to which the given record should be written.
selectChannels(T, int) - Method in class org.apache.flink.runtime.io.network.api.writer.RoundRobinChannelSelector
 
selectChannels(SerializationDelegate<T>, int) - Method in class org.apache.flink.runtime.operators.shipping.OutputEmitter
 
selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
 
selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
 
selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
 
selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
 
selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
 
selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
 
selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
 
selectChannels(SerializationDelegate<StreamRecord<T>>, int) - Method in class org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
 
SelectEnglishAndTokenizeFlatMap() - Constructor for class org.apache.flink.streaming.examples.twitter.TwitterExample.SelectEnglishAndTokenizeFlatMap
 
selectionToString(RexProgram, Function3<RexNode, List<String>, Option<List<RexNode>>, String>) - Method in interface org.apache.flink.table.plan.nodes.CommonCalc
 
selectionToString(RexProgram, Function3<RexNode, List<String>, Option<List<RexNode>>, String>) - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
SelectNearestCenter() - Constructor for class org.apache.flink.examples.java.clustering.KMeans.SelectNearestCenter
 
SelectNearestCenter() - Constructor for class org.apache.flink.examples.scala.clustering.KMeans.SelectNearestCenter
 
selectNetworkInterfaceAndPort(Configuration, HighAvailabilityServices) - Method in class org.apache.flink.runtime.taskmanager.TaskManager$
 
selectNetworkInterfaceAndPort(Configuration, HighAvailabilityServices) - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
 
selectNetworkInterfaceAndRunTaskManager(Configuration, ResourceID, Class<? extends TaskManager>) - Method in class org.apache.flink.runtime.taskmanager.TaskManager$
Starts and runs the TaskManager.
selectNetworkInterfaceAndRunTaskManager(Configuration, ResourceID, Class<? extends TaskManager>) - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
Starts and runs the TaskManager.
SelectorFunctionKeys(KeySelector<T, K>, TypeInformation<T>, TypeInformation<K>) - Constructor for class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
selectOutputs(StreamRecord<OUT>) - Method in class org.apache.flink.streaming.api.collector.selector.DirectedOutput
 
selectToString(RelDataType) - Method in interface org.apache.flink.table.plan.nodes.CommonCorrelate
 
SelectTransformation<T> - Class in org.apache.flink.streaming.api.transformations
This transformation represents a selection of only certain upstream elements.
SelectTransformation(StreamTransformation<T>, List<String>) - Constructor for class org.apache.flink.streaming.api.transformations.SelectTransformation
Creates a new SelectionTransformation from the given input that only selects the streams with the selected names.
self() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
self() - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
self() - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
self() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
self() - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
self() - Static method in class org.apache.flink.mesos.scheduler.Tasks
 
self() - Static method in class org.apache.flink.runtime.jobmanager.JobManager
 
self() - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
 
self() - Static method in class org.apache.flink.yarn.ApplicationClient
 
self() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
SelfGateway - Interface in org.apache.flink.runtime.rpc
Interface for self gateways
SemanticProperties - Interface in org.apache.flink.api.common.operators
Container for the semantic properties associated to an operator.
SemanticProperties.EmptySemanticProperties - Class in org.apache.flink.api.common.operators
 
SemanticProperties.InvalidSemanticAnnotationException - Exception in org.apache.flink.api.common.operators
 
SemanticPropUtil - Class in org.apache.flink.api.java.functions
Utility class that contains helper methods to work with SemanticProperties.
semiJoin(Iterable<? extends RexNode>) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
semiJoin(RexNode[]) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
send(DatadogHttpReporter.DatadogHttpRequest) - Method in class org.apache.flink.metrics.datadog.DatadogHttpClient
 
send(IN) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraPojoSink
 
send(IN) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSinkBase
 
send(IN) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraTupleSink
 
SEND_RECEIVE_BUFFER_SIZE - Static variable in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
sendBroadCastVariables(Configuration) - Method in class org.apache.flink.python.api.streaming.data.PythonStreamer
Sends all broadcast-variables encoded in the configuration to the external process.
sendBuffer(SingleElementPushBackIterator<IN>, PythonSender.Serializer<IN>) - Method in class org.apache.flink.python.api.streaming.data.PythonSender
Extracts records from an iterator and writes them to the memory-mapped file.
sendBuffer(SingleElementPushBackIterator<IN>) - Method in class org.apache.flink.python.api.streaming.data.PythonSingleInputSender
Extracts records from an iterator and writes them to the memory-mapped file.
sendBuffer1(SingleElementPushBackIterator<IN1>) - Method in class org.apache.flink.python.api.streaming.data.PythonDualInputSender
Extracts records from an iterator and writes them to the memory-mapped file.
sendBuffer2(SingleElementPushBackIterator<IN2>) - Method in class org.apache.flink.python.api.streaming.data.PythonDualInputSender
Extracts records from an iterator and writes them to the memory-mapped file.
sendCombinedMessage(Message) - Method in class org.apache.flink.graph.pregel.MessageCombiner
Sends the combined message to the target vertex.
sender() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
sender() - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
sender() - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
sender() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
sender() - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
sender() - Static method in class org.apache.flink.mesos.scheduler.Tasks
 
sender - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
sender - Variable in class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
 
sender() - Static method in class org.apache.flink.runtime.jobmanager.JobManager
 
sender() - Method in class org.apache.flink.runtime.messages.StackTraceSampleMessages.SampleTaskStackTrace
 
sender() - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
 
sender() - Static method in class org.apache.flink.yarn.ApplicationClient
 
sender() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
sendError(ChannelHandlerContext, HttpResponseStatus) - Static method in class org.apache.flink.runtime.webmonitor.files.StaticFileServerHandler
Writes a simple error response message.
sendError(Exception) - Method in class org.apache.flink.runtime.webmonitor.handlers.JarActionHandler
 
SendHeartbeat$() - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages.SendHeartbeat$
 
sendHeartbeatToJobManager() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
sendHeartbeatToJobManager() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
Sends a heartbeat message to the JobManager (if connected) with the current metrics report.
sendHeartbeatToJobManager() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
sendInfoMessage(String) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
 
sendInfoMessage(String) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
sendMessages(Vertex<Long, Double>) - Method in class org.apache.flink.graph.examples.IncrementalSSSP.InvalidateMessenger
 
sendMessages(Vertex<K, Double>) - Method in class org.apache.flink.graph.examples.PageRank.RankMessenger
 
sendMessages(Vertex<K, Tuple2<Long, Double>>) - Method in class org.apache.flink.graph.library.CommunityDetection.LabelMessenger
 
sendMessages(Vertex<K, VV>) - Method in class org.apache.flink.graph.library.ConnectedComponents.CCMessenger
 
sendMessages(Vertex<K, VV>) - Method in class org.apache.flink.graph.library.LabelPropagation.SendNewLabelToNeighbors
 
sendMessages(Vertex<K, Double>) - Method in class org.apache.flink.graph.library.SingleSourceShortestPaths.MinDistanceMessenger
 
sendMessages(Vertex<K, VV>) - Method in class org.apache.flink.graph.spargel.ScatterFunction
This method is invoked once per superstep for each vertex that was changed in that superstep.
sendMessageTo(K, Message) - Method in class org.apache.flink.graph.pregel.ComputeFunction
Sends the given message to the vertex identified by the given key.
sendMessageTo(K, Message) - Method in class org.apache.flink.graph.spargel.ScatterFunction
Sends the given message to the vertex identified by the given key.
sendMessageToAllNeighbors(Message) - Method in class org.apache.flink.graph.pregel.ComputeFunction
Sends the given message to all vertices that adjacent to the changed vertex.
sendMessageToAllNeighbors(Message) - Method in class org.apache.flink.graph.spargel.ScatterFunction
Sends the given message to all vertices that are targets of an edge of the changed vertex.
SendNewLabelToNeighbors(TypeInformation<VV>) - Constructor for class org.apache.flink.graph.library.LabelPropagation.SendNewLabelToNeighbors
 
sendNotModified(ChannelHandlerContext) - Static method in class org.apache.flink.runtime.webmonitor.files.StaticFileServerHandler
Send the "304 Not Modified" response.
sendReadConfirmation() - Method in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
sendReadRequest(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
Sends a new read requests, if further requests remain.
sendRecord(Object) - Method in class org.apache.flink.python.api.streaming.plan.PythonPlanSender
 
sendRecord(Object) - Method in class org.apache.flink.python.api.streaming.plan.PythonPlanStreamer
 
sendScheduleOrUpdateConsumersMessage() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
 
SendStackTrace$() - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages.SendStackTrace$
 
sendsUpdatesAsRetraction(RelNode) - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamRetractionRules$
Checks if a RelNode ships updates as retractions.
sendsUpdatesAsRetraction(RelNode) - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamRetractionRules
Checks if a RelNode ships updates as retractions.
sendsUpdatesAsRetractions() - Method in class org.apache.flink.table.plan.nodes.datastream.UpdateAsRetractionTrait
 
sendTaskEvent(TaskEvent) - Method in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
 
sendTaskEvent(TaskEvent) - Method in interface org.apache.flink.runtime.io.network.api.reader.ReaderBase
 
sendTaskEvent(ResultPartitionID, TaskEvent, RemoteInputChannel) - Method in class org.apache.flink.runtime.io.network.netty.PartitionRequestClient
Sends a task event backwards to an intermediate result partition producer.
sendTaskEvent(TaskEvent) - Method in interface org.apache.flink.runtime.io.network.partition.consumer.InputGate
 
sendTaskEvent(TaskEvent) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
sendTaskEvent(TaskEvent) - Method in class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
 
sendValues(Iterable<IN>, long, long) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraTupleWriteAheadSink
 
sendValues(Iterable<IN>, long, long) - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
Write the given element into the backend.
sendWriteNotification(int, boolean) - Method in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
Sentence() - Constructor for class org.apache.flink.storm.wordcount.operators.WordCountDataPojos.Sentence
 
Sentence(String) - Constructor for class org.apache.flink.storm.wordcount.operators.WordCountDataPojos.Sentence
 
SENTENCES - Static variable in class org.apache.flink.storm.wordcount.operators.WordCountDataPojos
 
SEPARATOR - Static variable in class org.apache.flink.core.fs.Path
The directory separator, a slash.
SEPARATOR_CHAR - Static variable in class org.apache.flink.core.fs.Path
The directory separator, a slash (character).
SequenceFileWriter<K extends org.apache.hadoop.io.Writable,V extends org.apache.hadoop.io.Writable> - Class in org.apache.flink.streaming.connectors.fs
A Writer that writes the bucket files as Hadoop SequenceFiles.
SequenceFileWriter() - Constructor for class org.apache.flink.streaming.connectors.fs.SequenceFileWriter
Creates a new SequenceFileWriter that writes sequence files without compression.
SequenceFileWriter(String, SequenceFile.CompressionType) - Constructor for class org.apache.flink.streaming.connectors.fs.SequenceFileWriter
Creates a new SequenceFileWriter that writes sequence with the given compression codec and compression type.
SerializableObject - Class in org.apache.flink.runtime.util
A simple object that only implements Serializable, so it can be used in serializable classes.
SerializableObject() - Constructor for class org.apache.flink.runtime.util.SerializableObject
 
SerializableSerializer(T) - Constructor for class org.apache.flink.api.common.ExecutionConfig.SerializableSerializer
 
SerializationDelegate<T> - Class in org.apache.flink.runtime.plugable
The serialization delegate exposes an arbitrary element as a IOReadableWritable for serialization, with the help of a type serializer.
SerializationDelegate(TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.plugable.SerializationDelegate
 
serializationSchema - Variable in class org.apache.flink.streaming.connectors.kafka.KafkaTableSink
 
SerializationSchema<T> - Interface in org.apache.flink.streaming.util.serialization
The serialization schema describes how to turn a data object into a different serialized representation.
SerializationUtils - Class in org.apache.flink.python.api.streaming.util
 
SerializationUtils() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils
 
SerializationUtils.BooleanSerializer - Class in org.apache.flink.python.api.streaming.util
 
SerializationUtils.ByteSerializer - Class in org.apache.flink.python.api.streaming.util
 
SerializationUtils.BytesSerializer - Class in org.apache.flink.python.api.streaming.util
 
SerializationUtils.CustomTypeWrapperSerializer - Class in org.apache.flink.python.api.streaming.util
 
SerializationUtils.DoubleSerializer - Class in org.apache.flink.python.api.streaming.util
 
SerializationUtils.FloatSerializer - Class in org.apache.flink.python.api.streaming.util
 
SerializationUtils.IntSerializer - Class in org.apache.flink.python.api.streaming.util
 
SerializationUtils.LongSerializer - Class in org.apache.flink.python.api.streaming.util
 
SerializationUtils.NullSerializer - Class in org.apache.flink.python.api.streaming.util
 
SerializationUtils.Serializer<IN> - Class in org.apache.flink.python.api.streaming.util
 
SerializationUtils.StringSerializer - Class in org.apache.flink.python.api.streaming.util
 
SerializationUtils.TupleSerializer - Class in org.apache.flink.python.api.streaming.util
 
serialize(T, DataOutputView) - Method in class org.apache.flink.api.common.io.BinaryOutputFormat
 
serialize(T, DataOutputView) - Method in class org.apache.flink.api.common.io.SerializedOutputFormat
 
serialize(boolean[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BooleanPrimitiveArraySerializer
 
serialize(byte[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.BytePrimitiveArraySerializer
 
serialize(char[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.CharPrimitiveArraySerializer
 
serialize(double[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.DoublePrimitiveArraySerializer
 
serialize(float[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.FloatPrimitiveArraySerializer
 
serialize(int[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.IntPrimitiveArraySerializer
 
serialize(long[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.LongPrimitiveArraySerializer
 
serialize(short[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
serialize(String[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
serialize(BigDecimal, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BigDecSerializer
 
serialize(BigInteger, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
serialize(Boolean, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanSerializer
 
serialize(BooleanValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueSerializer
 
serialize(Byte, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteSerializer
 
serialize(ByteValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueSerializer
 
serialize(Character, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.CharSerializer
 
serialize(CharValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.CharValueSerializer
 
serialize(Date, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DateSerializer
 
serialize(Double, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleSerializer
 
serialize(DoubleValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueSerializer
 
serialize(T, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
serialize(Float, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatSerializer
 
serialize(FloatValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueSerializer
 
serialize(C[], DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
serialize(Integer, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.IntSerializer
 
serialize(IntValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.IntValueSerializer
 
serialize(List<T>, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
 
serialize(Long, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LongSerializer
 
serialize(LongValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LongValueSerializer
 
serialize(Map<K, V>, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
serialize(NullValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.NullValueSerializer
 
serialize(Short, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortSerializer
 
serialize(ShortValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
serialize(Date, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
serialize(Time, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
serialize(Timestamp, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
serialize(String, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.StringSerializer
 
serialize(StringValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
serialize(Void, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.VoidSerializer
 
serialize(T, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.TypeDeserializerAdapter
 
serialize(T, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
Serializes the given record to the given target output view.
serialize(T, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.io.TypeSerializerOutputFormat
 
serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
 
serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
serialize(Either<L, R>, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
serialize(Row, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
serialize(Tuple0, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
serialize(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
 
serialize(T, DataOutputView) - Method in class org.apache.flink.api.scala.typeutils.CaseClassSerializer
 
serialize(T, DataOutputView) - Method in class org.apache.flink.api.scala.typeutils.EitherSerializer
 
serialize(Enumeration.Value, DataOutputView) - Method in class org.apache.flink.api.scala.typeutils.EnumValueSerializer
 
serialize(Object, DataOutputView) - Method in class org.apache.flink.api.scala.typeutils.NothingSerializer
 
serialize(Option<A>, DataOutputView) - Method in class org.apache.flink.api.scala.typeutils.OptionSerializer
 
serialize(T, DataOutputView) - Method in class org.apache.flink.api.scala.typeutils.TraversableSerializer
 
serialize(Try<A>, DataOutputView) - Method in class org.apache.flink.api.scala.typeutils.TrySerializer
 
serialize(BoxedUnit, DataOutputView) - Method in class org.apache.flink.api.scala.typeutils.UnitSerializer
 
serialize(DeweyNumber, DataOutputView) - Method in class org.apache.flink.cep.nfa.DeweyNumber.DeweyNumberSerializer
 
serialize(NFA<T>, DataOutputView) - Method in class org.apache.flink.cep.nfa.NFA.NFASerializer
 
serialize(NFA<T>, DataOutputView) - Method in class org.apache.flink.cep.nfa.NFA.Serializer
 
serialize(SharedBuffer, DataOutputView) - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
 
serialize(T, DataOutputView) - Method in class org.apache.flink.cep.NonDuplicatingTypeSerializer
Serializes the given record.
serialize(E) - Method in interface org.apache.flink.core.io.SimpleVersionedSerializer
Serializes the given object.
serialize(IntValueArray, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.IntValueArraySerializer
 
serialize(LongValueArray, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.LongValueArraySerializer
 
serialize(NullValueArray, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.NullValueArraySerializer
 
serialize(StringValueArray, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.StringValueArraySerializer
 
serialize(Object) - Static method in class org.apache.flink.metrics.datadog.DatadogHttpClient
 
serialize(Serializable, DataOutputView) - Method in class org.apache.flink.migration.MigrationNamespaceSerializerProxy
Deprecated.
 
serialize(SavepointV2, DataOutputStream) - Method in class org.apache.flink.migration.runtime.checkpoint.savepoint.SavepointV0Serializer
 
serialize(StreamElement, DataOutputView) - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer
 
serialize(StreamRecord<T>, DataOutputView) - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.StreamRecordSerializer
 
serialize(T) - Method in class org.apache.flink.python.api.streaming.data.PythonSender.Serializer
 
serialize(IN) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.Serializer
 
serialize(T, DataOutputStream) - Method in interface org.apache.flink.runtime.checkpoint.savepoint.SavepointSerializer
Serializes a savepoint to an output stream.
serialize(SavepointV2, DataOutputStream) - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
serialize(Map<Counter, Tuple2<QueryScopeInfo, String>>, Map<Gauge<?>, Tuple2<QueryScopeInfo, String>>, Map<Histogram, Tuple2<QueryScopeInfo, String>>, Map<Meter, Tuple2<QueryScopeInfo, String>>) - Method in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricDumpSerializer
Serializes the given metrics and returns the resulting byte array.
serialize(ArrayList<T>, DataOutputView) - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
serialize(HashMap<K, V>, DataOutputView) - Method in class org.apache.flink.runtime.state.HashMapSerializer
 
serialize(VoidNamespace, DataOutputView) - Method in class org.apache.flink.runtime.state.VoidNamespaceSerializer
 
serialize(InternalTimer<K, N>, DataOutputView) - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
 
serialize(GlobalWindow, DataOutputView) - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
 
serialize(TimeWindow, DataOutputView) - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
serialize(StreamElement, DataOutputView) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
serialize(Row) - Method in class org.apache.flink.streaming.util.serialization.AvroRowSerializationSchema
 
serialize(Row) - Method in class org.apache.flink.streaming.util.serialization.JsonRowSerializationSchema
 
serialize(T) - Method in interface org.apache.flink.streaming.util.serialization.SerializationSchema
Serializes the incoming element to a specified type.
serialize(String) - Method in class org.apache.flink.streaming.util.serialization.SimpleStringSchema
 
serialize(T) - Method in class org.apache.flink.streaming.util.serialization.TypeInformationSerializationSchema
 
serialize(UserDefinedFunction) - Method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils$
 
serialize(UserDefinedFunction) - Static method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils
 
serialize(CRow, DataOutputView) - Method in class org.apache.flink.table.runtime.types.CRowSerializer
 
serialize(DataOutputView) - Method in class org.apache.flink.types.Record
Writes this record to the given output view.
SerializedCheckpointData - Class in org.apache.flink.runtime.state
This class represents serialized checkpoint data for a collection of elements.
SerializedCheckpointData(long, byte[], int) - Constructor for class org.apache.flink.runtime.state.SerializedCheckpointData
Creates a SerializedCheckpointData object for the given serialized data.
SerializedInputFormat<T extends IOReadableWritable> - Class in org.apache.flink.api.common.io
Reads elements by deserializing them with their regular serialization/deserialization functionality.
SerializedInputFormat() - Constructor for class org.apache.flink.api.common.io.SerializedInputFormat
 
SerializedInputSplit - Class in org.apache.flink.runtime.jobmaster
 
SerializedInputSplit(byte[]) - Constructor for class org.apache.flink.runtime.jobmaster.SerializedInputSplit
 
SerializedJobExecutionResult - Class in org.apache.flink.runtime.client
A variant of the JobExecutionResult that holds its accumulator data in serialized form.
SerializedJobExecutionResult(JobID, long, Map<String, SerializedValue<Object>>) - Constructor for class org.apache.flink.runtime.client.SerializedJobExecutionResult
Creates a new SerializedJobExecutionResult.
SerializedListAccumulator<T> - Class in org.apache.flink.api.common.accumulators
This accumulator stores a collection of objects in serialized form, so that the stored objects are not affected by modifications to the original objects.
SerializedListAccumulator() - Constructor for class org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
serializedMetrics - Variable in class org.apache.flink.runtime.metrics.dump.MetricDumpSerialization.MetricSerializationResult
 
SerializedOutputFormat<T extends IOReadableWritable> - Class in org.apache.flink.api.common.io
Stores elements by serializing them with their regular serialization/deserialization functionality.
SerializedOutputFormat() - Constructor for class org.apache.flink.api.common.io.SerializedOutputFormat
 
SerializedStateHandle<T extends Serializable> - Class in org.apache.flink.migration.runtime.state.memory
A state handle that represents its state in serialized form as bytes.
SerializedStateHandle(T) - Constructor for class org.apache.flink.migration.runtime.state.memory.SerializedStateHandle
Creates a new serialized state handle, eagerly serializing the given state object.
SerializedStateHandle(byte[]) - Constructor for class org.apache.flink.migration.runtime.state.memory.SerializedStateHandle
Creates a new serialized state handle, based in the given already serialized data.
SerializedThrowable - Exception in org.apache.flink.runtime.util
Utility class for dealing with user-defined Throwable types that are serialized (for example during RPC/Actor communication), but cannot be resolved with the default class loader.
SerializedThrowable(Throwable) - Constructor for exception org.apache.flink.runtime.util.SerializedThrowable
Create a new SerializedThrowable.
SerializedUpdateBuffer - Class in org.apache.flink.runtime.iterative.io
 
SerializedUpdateBuffer() - Constructor for class org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
 
SerializedUpdateBuffer(List<MemorySegment>, int, IOManager) - Constructor for class org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
 
SerializedValue<T> - Class in org.apache.flink.migration.util
Deprecated.
Only used internally when migrating from previous savepoint versions.
SerializedValue(T) - Constructor for class org.apache.flink.migration.util.SerializedValue
Deprecated.
 
SerializedValue<T> - Class in org.apache.flink.util
This class is used to transfer (via serialization) objects whose classes are not available in the system class loader.
SerializedValue(T) - Constructor for class org.apache.flink.util.SerializedValue
 
serializeField(Field, ObjectOutputStream) - Static method in class org.apache.flink.api.java.typeutils.runtime.FieldSerializer
 
serializeInternal(T) - Method in class org.apache.flink.python.api.streaming.data.PythonSender.Serializer
 
serializeKey(T) - Method in interface org.apache.flink.streaming.util.serialization.KeyedSerializationSchema
Serializes the key of the incoming element to a byte array This method might return null if no key is available.
serializeKey(T) - Method in class org.apache.flink.streaming.util.serialization.KeyedSerializationSchemaWrapper
 
serializeKey(Tuple2<K, V>) - Method in class org.apache.flink.streaming.util.serialization.TypeInformationKeyValueSerializationSchema
 
serializeKeyAndNamespace(K, TypeSerializer<K>, N, TypeSerializer<N>) - Static method in class org.apache.flink.runtime.query.netty.message.KvStateRequestSerializer
Serializes the key and namespace into a ByteBuffer.
serializeKeyedStateHandle(KeyedStateHandle, DataOutputStream) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
serializeKvStateRequest(ByteBufAllocator, long, KvStateID, byte[]) - Static method in class org.apache.flink.runtime.query.netty.message.KvStateRequestSerializer
Allocates a buffer and serializes the KvState request into it.
serializeKvStateRequestFailure(ByteBufAllocator, long, Throwable) - Static method in class org.apache.flink.runtime.query.netty.message.KvStateRequestSerializer
Allocates a buffer and serializes the KvState request failure into it.
serializeKvStateRequestResult(ByteBufAllocator, long, byte[]) - Static method in class org.apache.flink.runtime.query.netty.message.KvStateRequestSerializer
Allocates a buffer and serializes the KvState request result into it.
serializeMap(Iterable<Map.Entry<UK, UV>>, TypeSerializer<UK>, TypeSerializer<UV>) - Static method in class org.apache.flink.runtime.query.netty.message.KvStateRequestSerializer
Serializes all values of the Iterable with the given serializer.
serializeObject(Object) - Static method in class org.apache.flink.util.InstantiationUtil
 
serializeObject(OutputStream, Object) - Static method in class org.apache.flink.util.InstantiationUtil
 
serializeOld(SavepointV0, DataOutputStream) - Method in class org.apache.flink.migration.runtime.checkpoint.savepoint.SavepointV0Serializer
 
serializeOld(SavepointV1, DataOutputStream) - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
serializeOperatorStateHandle(OperatorStateHandle, DataOutputStream) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
serializer - Variable in class org.apache.flink.api.common.state.StateDescriptor
The serializer for the type.
Serializer() - Constructor for class org.apache.flink.cep.nfa.NFA.Serializer
 
Serializer() - Constructor for class org.apache.flink.python.api.streaming.data.PythonSender.Serializer
 
Serializer() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.Serializer
 
serializer - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
serializer - Variable in class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
serializer - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 
Serializer() - Constructor for class org.apache.flink.streaming.api.windowing.windows.GlobalWindow.Serializer
 
Serializer() - Constructor for class org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
 
serializer - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
 
serializer - Variable in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
 
serializer() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
 
serializer1 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
serializer2 - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
SerializerMap<IN> - Class in org.apache.flink.python.api.functions.util
 
SerializerMap() - Constructor for class org.apache.flink.python.api.functions.util.SerializerMap
 
Serializers - Class in org.apache.flink.api.java.typeutils.runtime.kryo
Class containing utilities for the serializers of the Flink Runtime.
Serializers() - Constructor for class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers
 
serializers - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
serializers to deserialize the first n fields for comparison
Serializers.AvroSchemaSerializer - Class in org.apache.flink.api.java.typeutils.runtime.kryo
Slow serialization approach for Avro schemas.
Serializers.SpecificInstanceCollectionSerializer<T extends Collection> - Class in org.apache.flink.api.java.typeutils.runtime.kryo
Special serializer for Java collections enforcing certain instance types.
Serializers.SpecificInstanceCollectionSerializerForArrayList - Class in org.apache.flink.api.java.typeutils.runtime.kryo
 
serializeServerFailure(ByteBufAllocator, Throwable) - Static method in class org.apache.flink.runtime.query.netty.message.KvStateRequestSerializer
Allocates a buffer and serializes the server failure into it.
serializeStreamStateHandle(StreamStateHandle, DataOutputStream) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1Serializer
 
serializeToByteArray(TypeSerializer<T>, T) - Static method in class org.apache.flink.util.InstantiationUtil
 
serializeValue(T, TypeSerializer<T>) - Static method in class org.apache.flink.runtime.query.netty.message.KvStateRequestSerializer
Serializes the value with the given serializer.
serializeValue(T) - Method in interface org.apache.flink.streaming.util.serialization.KeyedSerializationSchema
Serializes the value of the incoming element to a byte array
serializeValue(T) - Method in class org.apache.flink.streaming.util.serialization.KeyedSerializationSchemaWrapper
 
serializeValue(Tuple2<K, V>) - Method in class org.apache.flink.streaming.util.serialization.TypeInformationKeyValueSerializationSchema
 
serializeWithoutTypeInfo(Boolean) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.BooleanSerializer
 
serializeWithoutTypeInfo(Byte) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.ByteSerializer
 
serializeWithoutTypeInfo(byte[]) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.BytesSerializer
 
serializeWithoutTypeInfo(CustomTypeWrapper) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.CustomTypeWrapperSerializer
 
serializeWithoutTypeInfo(Double) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.DoubleSerializer
 
serializeWithoutTypeInfo(Float) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.FloatSerializer
 
serializeWithoutTypeInfo(Integer) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.IntSerializer
 
serializeWithoutTypeInfo(Long) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.LongSerializer
 
serializeWithoutTypeInfo(Object) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.NullSerializer
 
serializeWithoutTypeInfo(IN) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.Serializer
 
serializeWithoutTypeInfo(String) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.StringSerializer
 
serializeWithoutTypeInfo(Tuple) - Method in class org.apache.flink.python.api.streaming.util.SerializationUtils.TupleSerializer
 
SerialUIDMismatchTolerantInputStream(InputStream, ClassLoader) - Constructor for class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil.SerialUIDMismatchTolerantInputStream
 
server - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
SERVER_ASYNC_QUERY_THREADS - Static variable in class org.apache.flink.configuration.QueryableStateOptions
Number of async query threads for the KvStateServerHandler (0 => #slots).
SERVER_ENABLE - Static variable in class org.apache.flink.configuration.QueryableStateOptions
Flag to indicate whether to start the queryable state server.
SERVER_NETWORK_THREADS - Static variable in class org.apache.flink.configuration.QueryableStateOptions
Number of network (event loop) threads for the KvState server (0 => #slots).
SERVER_PORT - Static variable in class org.apache.flink.configuration.QueryableStateOptions
Port to bind KvState server to (0 => pick random available port).
ServicesThreadFactory - Class in org.apache.flink.runtime.highavailability
 
ServicesThreadFactory() - Constructor for class org.apache.flink.runtime.highavailability.ServicesThreadFactory
 
SESSION - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The SESSION group function.
session - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraSinkBase
 
session - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraTupleWriteAheadSink
 
Session - Class in org.apache.flink.table.api.java
Helper class for creating a session window.
Session() - Constructor for class org.apache.flink.table.api.java.Session
 
Session - Class in org.apache.flink.table.api.scala
Helper object for creating a session window.
Session() - Constructor for class org.apache.flink.table.api.scala.Session
 
Session$ - Class in org.apache.flink.table.api.java
Helper class for creating a session window.
Session$() - Constructor for class org.apache.flink.table.api.java.Session$
 
Session$ - Class in org.apache.flink.table.api.scala
Helper object for creating a session window.
Session$() - Constructor for class org.apache.flink.table.api.scala.Session$
 
SESSION_END - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The SESSION_END auxiliary function of the SESSION group function.
SESSION_START - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The SESSION_START auxiliary function of the SESSION group function.
SESSION_USER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The SESSION_USER function.
sessionAlive() - Method in class org.apache.flink.runtime.jobmanager.JobInfo
 
SessionGroupWindow - Class in org.apache.flink.table.plan.logical
 
SessionGroupWindow(Expression, Expression, Expression) - Constructor for class org.apache.flink.table.plan.logical.SessionGroupWindow
 
SessionGroupWindow$ - Class in org.apache.flink.table.plan.logical
 
SessionGroupWindow$() - Constructor for class org.apache.flink.table.plan.logical.SessionGroupWindow$
 
sessionIds - Variable in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
 
sessionIdsPerSnapshot - Variable in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
 
sessionTimeout - Variable in class org.apache.flink.api.java.ExecutionEnvironment
The session timeout in seconds
sessionTimeout() - Method in class org.apache.flink.runtime.jobmanager.JobInfo
 
sessionTimeout - Variable in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
 
sessionTimeout - Variable in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
 
SessionWindowing - Class in org.apache.flink.streaming.examples.windowing
 
SessionWindowing() - Constructor for class org.apache.flink.streaming.examples.windowing.SessionWindowing
 
SessionWindowingData - Class in org.apache.flink.streaming.examples.windowing.util
 
SessionWithGap - Class in org.apache.flink.table.api
Session window.
SessionWithGap(Expression) - Constructor for class org.apache.flink.table.api.SessionWithGap
 
SessionWithGap(String) - Constructor for class org.apache.flink.table.api.SessionWithGap
Session window.
SessionWithGapOnTime - Class in org.apache.flink.table.api
Session window on time.
SessionWithGapOnTime(Expression, Expression) - Constructor for class org.apache.flink.table.api.SessionWithGapOnTime
 
SessionWithGapOnTimeWithAlias - Class in org.apache.flink.table.api
Session window on time with alias.
SessionWithGapOnTimeWithAlias(Expression, Expression, Expression) - Constructor for class org.apache.flink.table.api.SessionWithGapOnTimeWithAlias
 
set(Iterator<Tuple3<K1, K2, T>>) - Method in class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
 
set(Collector<Tuple3<K1, K2, IN>>) - Method in class org.apache.flink.api.java.operators.translation.Tuple3WrappingCollector
 
set(Iterator<Tuple2<K, T>>) - Method in class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
 
set(Collector<Tuple2<K, IN>>) - Method in class org.apache.flink.api.java.operators.translation.TupleWrappingCollector
 
set(boolean) - Method in class org.apache.flink.graph.utils.proxy.OptionalBoolean
Set the boolean state.
set(Iterator<Tuple2<KEY, VALUE>>) - Method in class org.apache.flink.hadoopcompatibility.mapred.wrapper.HadoopTupleUnwrappingIterator
Set the Flink iterator to wrap.
set(int) - Method in class org.apache.flink.runtime.operators.util.BitSet
Sets the bit at specified index.
set(int) - Method in class org.apache.flink.runtime.operators.util.BloomFilter.BitSet
Sets the bit at specified index.
set(int, T) - Method in class org.apache.flink.runtime.util.EvictingBoundedList
 
set(E) - Method in class org.apache.flink.runtime.util.SingleElementIterator
Resets the element.
set(T, F) - Method in class org.apache.flink.streaming.util.typeutils.FieldAccessor
Sets the field (specified in the constructor) of the given record to the given value.
set(boolean) - Method in class org.apache.flink.types.BooleanValue
 
set(int, V) - Method in class org.apache.flink.types.ListValue
 
setAbsoluteTimestamp(long) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
 
SetAccModeRule() - Constructor for class org.apache.flink.table.plan.rules.datastream.DataStreamRetractionRules.SetAccModeRule
 
setAccRetract(RelNode) - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamRetractionRules.SetAccModeRule
Set AccMode.AccRetract to a RelNode.
setAccumulatedRecordCount(long) - Method in class org.apache.flink.api.common.io.BlockInfo
Sets the accumulatedRecordCount to the specified value.
setAccumulators(Map<String, Accumulator<?, ?>>) - Method in class org.apache.flink.runtime.executiongraph.Execution
Update accumulators (discarded when the Execution has already been terminated).
setAggregationResults(Row, Row) - Method in class org.apache.flink.table.runtime.aggregate.GeneratedAggregations
Sets the results of the aggregations (partial or final) to the output row.
setAlignmentDurationNanos(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
setAllocationId(AllocationID) - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
setAllowNullValues(boolean) - Method in class org.apache.flink.api.java.io.CsvOutputFormat
Configures the format to either allow null values (writing an empty field), or to throw an exception when encountering a null field.
setAllowNullValues(boolean) - Method in class org.apache.flink.api.scala.operators.ScalaCsvOutputFormat
Configures the format to either allow null values (writing an empty field), or to throw an exception when encountering a null field.
setAllowQueuedScheduling(boolean) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
 
setAnalyzedUdfSemanticsFlag() - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
 
setAnalyzedUdfSemanticsFlag() - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
 
setAnyDistribution() - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
 
setAnyPartitioning(FieldList) - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
 
setAnyPartitioning(FieldSet) - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
Sets these properties to request some partitioning on the given fields.
setAppId(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Attributes
 
setAsContext() - Method in class org.apache.flink.api.java.ScalaShellRemoteStreamEnvironment
 
setAsContext() - Method in class org.apache.flink.client.program.PreviewPlanEnvironment
 
setAsContext(LocalFlinkMiniCluster, int, Collection<Path>, Collection<URL>) - Static method in class org.apache.flink.streaming.util.TestStreamEnvironment
Sets the streaming context environment to a TestStreamEnvironment that runs its programs on the given cluster with the given default parallelism and the specified jar files and class paths.
setAsContext(LocalFlinkMiniCluster, int) - Static method in class org.apache.flink.streaming.util.TestStreamEnvironment
Sets the streaming context environment to a TestStreamEnvironment that runs its programs on the given cluster with the given default parallelism.
setAsContext() - Method in class org.apache.flink.test.util.CollectionTestEnvironment
 
setAsContext() - Method in class org.apache.flink.test.util.TestEnvironment
 
setAsContext(LocalFlinkMiniCluster, int, Collection<Path>, Collection<URL>) - Static method in class org.apache.flink.test.util.TestEnvironment
Sets the current ExecutionEnvironment to be a TestEnvironment.
setAsContext(LocalFlinkMiniCluster, int) - Static method in class org.apache.flink.test.util.TestEnvironment
Sets the current ExecutionEnvironment to be a TestEnvironment.
setAssignedSlotRequest(PendingSlotRequest) - Method in class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
setAsyncDurationMillis(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
setAsyncTimeout(long) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
Sets the default timeout for asynchronous operations such as recoverLease and truncate.
setAsyncTimeout(long) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
Deprecated.
Sets the default timeout for asynchronous operations such as recoverLease and truncate.
setAttributes(Attributes) - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Places
 
setAutomaticRecovery(boolean) - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
Enables or disables automatic connection recovery
setAutoWatermarkInterval(long) - Method in class org.apache.flink.api.common.ExecutionConfig
Sets the interval of the automatic watermark emission.
setAvgOutputRecordSize(float) - Method in class org.apache.flink.api.common.operators.CompilerHints
 
setBackoffType(ElasticsearchSinkBase.FlushBackoffType) - Method in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase.BulkFlushBackoffPolicy
 
setBatchInterval(int) - Method in class org.apache.flink.api.java.io.jdbc.JDBCOutputFormat.JDBCOutputFormatBuilder
 
setBatchSize(long) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
Sets the maximum bucket size in bytes.
setBatchSize(long) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
Deprecated.
Sets the maximum bucket size in bytes.
setBitsLocation(MemorySegment, int) - Method in class org.apache.flink.runtime.operators.util.BloomFilter
 
setBlocks(int) - Method in class org.apache.flink.ml.classification.SVM
Sets the number of data blocks/partitions
setBlocks(int) - Method in class org.apache.flink.ml.nn.KNN
Sets the number of data blocks/partitions
setBlocks(int) - Method in class org.apache.flink.ml.recommendation.ALS
Sets the number of blocks into which the user and item matrix shall be partitioned
setBlockSize(long) - Method in class org.apache.flink.api.common.io.BinaryInputFormat
 
setBoolean(String, boolean) - Method in class org.apache.flink.configuration.Configuration
Adds the given key/value pair to the configuration object.
setBoolean(ConfigOption<Boolean>, boolean) - Method in class org.apache.flink.configuration.Configuration
Adds the given value to the configuration object.
setBoolean(String, boolean) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
setBoolean(ConfigOption<Boolean>, boolean) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
setBottomId(KB) - Method in class org.apache.flink.graph.bipartite.BipartiteEdge
 
setBounding_box(BoundingBox) - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Places
 
setBroadcastGateIterativeWithNumberOfEventsUntilInterrupt(int, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setBroadcastHighDegreeVertices(boolean) - Method in class org.apache.flink.graph.asm.degree.filter.undirected.MaximumDegree
After filtering high-degree vertices this algorithm must perform joins on the original graph's vertex set and on both the source and target IDs of the edge set.
setBroadcastInputName(String, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setBroadcastInputs(Map<Operator<?>, OptimizerNode>, ExecutionMode) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
This function connects the operators that produce the broadcast inputs to this operator.
setBroadcastInputs(List<NamedChannel>) - Method in class org.apache.flink.optimizer.plan.PlanNode
Sets a list of all broadcast inputs attached to this node.
setBroadcastInputSerializer(TypeSerializerFactory<?>, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setBroadcastVariable(String, List<?>) - Method in class org.apache.flink.api.common.functions.util.RuntimeUDFContext
 
setBroadcastVariable(String, Operator<?>) - Method in class org.apache.flink.api.common.operators.AbstractUdfOperator
Binds the result produced by a plan rooted at root to a variable used by the UDF wrapped in this operator.
setBroadcastVariable(String, Operator<?>) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
The BulkIteration meta operator cannot have broadcast inputs.
setBroadcastVariable(String, Operator<?>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
The DeltaIteration meta operator cannot have broadcast inputs.
setBroadcastVariable(String, BroadcastVariableMaterialization<?, ?>) - Method in class org.apache.flink.runtime.operators.util.DistributedRuntimeUDFContext
 
setBroadcastVariables(Map<String, Operator<T>>) - Method in class org.apache.flink.api.common.operators.AbstractUdfOperator
Clears all previous broadcast inputs and binds the given inputs as broadcast variables of this operator.
setBroadcastVariables(Map<String, Operator<X>>) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
The BulkIteration meta operator cannot have broadcast inputs.
setBroadcastVariables(Map<String, Operator<X>>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
The DeltaIteration meta operator cannot have broadcast inputs.
setBucketer(Bucketer<T>) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
Sets the Bucketer to use for determining the bucket files to write to.
setBucketer(Bucketer) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
Deprecated.
Sets the Bucketer to use for determining the bucket files to write to.
setBuffer(ByteBuffer) - Method in class org.apache.flink.runtime.util.DataInputDeserializer
 
setBuffer(byte[], int, int) - Method in class org.apache.flink.runtime.util.DataInputDeserializer
 
setBufferPool(BufferPool) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
setBufferPoolOwner(BufferPoolOwner) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
The owner of this buffer pool to be called when memory needs to be released to avoid back pressure.
setBufferSize(int) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
setBufferTimeout(long) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Sets the maximum time frequency (ms) for the flushing of the output buffer.
setBufferTimeout(long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Sets the maximum time frequency (milliseconds) for the flushing of the output buffers.
setBufferTimeout(long) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setBufferTimeout(Integer, long) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
setBufferTimeout(Long) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
setBufferTimeout(long) - Method in class org.apache.flink.streaming.api.scala.DataStream
Sets the maximum time frequency (ms) for the flushing of the output buffer.
setBufferTimeout(long) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Sets the maximum time frequency (milliseconds) for the flushing of the output buffers.
setBufferTimeout(long) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
Set the buffer timeout of this StreamTransformation.
setBytes(String, byte[]) - Method in class org.apache.flink.configuration.Configuration
Adds the given byte array to the configuration object.
setBytes(String, byte[]) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
setBytesBufferedInAlignment(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
setCachable(boolean) - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
SetCache - Class in org.apache.flink.python.api.util
A container holding DataSets, sorted andunsorted groupings.
SetCache() - Constructor for class org.apache.flink.python.api.util.SetCache
 
setCalciteConfig(CalciteConfig) - Method in class org.apache.flink.table.api.TableConfig
Sets the configuration of Calcite for Table API and SQL queries.
setCancellerHandle(ScheduledFuture<?>) - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
Sets the handle for the canceller to this pending checkpoint.
setCandidateProperties(GlobalProperties, LocalProperties, Channel) - Method in class org.apache.flink.optimizer.dag.BulkPartialSolutionNode
 
setCandidateProperties(GlobalProperties, LocalProperties, Channel) - Method in class org.apache.flink.optimizer.dag.SolutionSetNode
 
setCandidateProperties(GlobalProperties, LocalProperties, Channel) - Method in class org.apache.flink.optimizer.dag.WorksetNode
 
setChainedOutputs(List<StreamEdge>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setChainEnd() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setChainIndex(int) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setChaining(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
setChainingStrategy(ChainingStrategy) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
 
setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.CoFeedbackTransformation
 
setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.FeedbackTransformation
 
setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
 
setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.PartitionTransformation
 
setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.SelectTransformation
 
setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.SideOutputTransformation
 
setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
 
setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.SourceTransformation
 
setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.SplitTransformation
 
setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
Sets the chaining strategy of this StreamTransformation.
setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
 
setChainingStrategy(ChainingStrategy) - Method in class org.apache.flink.streaming.api.transformations.UnionTransformation
 
setChainStart() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setChange(boolean) - Method in class org.apache.flink.table.runtime.CRowWrappingCollector
 
setChannelIndex(int) - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
setCharset(String) - Method in class org.apache.flink.addons.hbase.HBaseTableSource
Specifies the charset to parse Strings to HBase byte[] keys and String values.
setCharset(String) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
Set the name of the character set used for the row delimiter.
setCharset(String) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
setCharset(String) - Method in class org.apache.flink.api.java.io.CsvReader
Sets the charset of the reader
setCharset(Charset) - Method in class org.apache.flink.types.parser.FieldParser
Sets the character set used for this parser.
setCharsetName(String) - Method in class org.apache.flink.api.java.io.CsvOutputFormat
Sets the charset with which the CSV strings are written to the file.
setCharsetName(String) - Method in class org.apache.flink.api.java.io.TextInputFormat
 
setCharsetName(String) - Method in class org.apache.flink.api.java.io.TextOutputFormat
 
setCharsetName(String) - Method in class org.apache.flink.api.java.io.TextValueInputFormat
 
setCharsetName(String) - Method in class org.apache.flink.api.scala.operators.ScalaCsvOutputFormat
Sets the charset with which the CSV strings are written to the file.
setCheckpointingEnabled(boolean) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setCheckpointingMode(CheckpointingMode) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
Sets the checkpointing mode (exactly-once vs.
setCheckpointInterval(long) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
Sets the interval in which checkpoints are periodically scheduled.
setCheckpointMode(CheckpointingMode) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setCheckpointStatsTracker(CheckpointStatsTracker) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Sets the checkpoint stats tracker.
setCheckpointTimeout(long) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
Sets the maximum time that a checkpoint may take before being discarded.
setCheckpointTrigger(ExternallyInducedSource.CheckpointTrigger) - Method in interface org.apache.flink.streaming.api.checkpoint.ExternallyInducedSource
Sets the checkpoint trigger through which the source can trigger the checkpoint.
setClass(String, Class<?>) - Method in class org.apache.flink.configuration.Configuration
Adds the given key/value pair to the configuration object.
setClass(String, Class<?>) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
setClasspaths(List<URL>) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Sets the classpaths required to run the job on a task manager.
setClock(Clock) - Static method in class org.apache.flink.streaming.connectors.fs.DateTimeBucketer
Deprecated.
This sets the internal Clock implementation.
setClusterBuilder(ClusterBuilder) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
Sets the ClusterBuilder for this sink.
setCodeAnalysisMode(CodeAnalysisMode) - Method in class org.apache.flink.api.common.ExecutionConfig
Sets the CodeAnalysisMode of the program.
setCodec(AvroOutputFormat.Codec) - Method in class org.apache.flink.api.java.io.AvroOutputFormat
Set avro codec for compression.
setCollector(Collector<T>) - Method in class org.apache.flink.table.functions.TableFunction
Internal use.
setCollector(Collector<?>) - Method in class org.apache.flink.table.runtime.TableFunctionCollector
Sets the current collector, which used to emit the final row.
setCombinable(boolean) - Method in class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
Marks the group reduce operation as combinable.
setCombinable(boolean) - Method in class org.apache.flink.api.java.operators.GroupReduceOperator
 
setCombinableFirst(boolean) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
setCombinableFirst(boolean) - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
 
setCombinableSecond(boolean) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
setCombinableSecond(boolean) - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
 
setCombineHint(ReduceOperatorBase.CombineHint) - Method in class org.apache.flink.api.common.operators.base.ReduceOperatorBase
 
setCombineHint(ReduceOperatorBase.CombineHint) - Method in class org.apache.flink.api.java.operators.DistinctOperator
Sets the strategy to use for the combine phase of the reduce.
setCombineHint(ReduceOperatorBase.CombineHint) - Method in class org.apache.flink.api.java.operators.ReduceOperator
Sets the strategy to use for the combine phase of the reduce.
setCommentPrefix(String) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
setCommitOffsetsOnCheckpoints(boolean) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
Specifies whether or not the consumer should commit offsets back to Kafka on checkpoints.
setCommittedOffset(long) - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionState
 
setCommonRpcBindAddress(String) - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
setComparator(TypeComparatorFactory<?>, int) - Method in class org.apache.flink.optimizer.plan.SingleInputPlanNode
Sets the specified comparator for this PlanNode.
setComparator1(TypeComparatorFactory<?>) - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
 
setComparator2(TypeComparatorFactory<?>) - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
 
setConfigDir(String) - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
 
setConfigDir(String) - Method in class org.apache.flink.runtime.taskmanager.TaskManagerCliOptions
 
setConfigurationDirectory(String) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
 
setConfigurationFilePath(Path) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
 
setConnectionTimeout(int) - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
Set the connection timeout.
setConnectionType(StreamPartitioner<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Internal function for setting the partitioner for the DataStream.
setConnectionType(StreamPartitioner<T>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
 
setConnectionType(StreamPartitioner<T>) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
 
setConstantFlags(Row) - Method in class org.apache.flink.table.runtime.aggregate.GeneratedAggregations
Sets constant flags (boolean fields) to an output row.
setConstants(float, float, float) - Method in class org.apache.flink.graph.generator.RMatGraph
The parameters for recursively subdividing the adjacency matrix.
setContainingIterationNode(BulkIterationPlanNode) - Method in class org.apache.flink.optimizer.plan.BulkPartialSolutionPlanNode
 
setContainingIterationNode(WorksetIterationPlanNode) - Method in class org.apache.flink.optimizer.plan.SolutionSetPlanNode
 
setContainingIterationNode(WorksetIterationPlanNode) - Method in class org.apache.flink.optimizer.plan.WorksetPlanNode
 
setContentTypeHeader(HttpResponse, File) - Static method in class org.apache.flink.runtime.webmonitor.files.StaticFileServerHandler
Sets the content type header for the HTTP Response.
setContributors(List<Contributors>) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
setContributors_enabled(boolean) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setConvergenceCriterion(String, ConvergenceCriterion<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setConvergenceThreshold(double) - Static method in class org.apache.flink.ml.optimization.GradientDescent
 
setConvergenceThreshold(double) - Method in class org.apache.flink.ml.optimization.IterativeSolver
 
setConvergenceThreshold(double) - Method in class org.apache.flink.ml.regression.MultipleLinearRegression
 
setCoordinates(List<List<double[]>>) - Method in class org.apache.flink.contrib.tweetinputformat.model.places.BoundingBox
 
setCoordinates(double[]) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Coordinates
 
setCoordinates(double, double) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Coordinates
 
setCoordinates(Coordinates) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
setCosts(Costs) - Method in class org.apache.flink.optimizer.plan.BulkIterationPlanNode
 
setCosts(Costs) - Method in class org.apache.flink.optimizer.plan.PlanNode
Sets the basic cost for this node to the given value, and sets the cumulative costs to those costs plus the cost shares of all inputs (regular and broadcast).
setCosts(Costs) - Method in class org.apache.flink.optimizer.plan.SinkJoinerPlanNode
 
setCosts(Costs) - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
 
setCount(long) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointIDCounter
Sets the current checkpoint ID.
setCount(long) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
 
setCount(long) - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
 
setCountry(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Places
 
setCountry_code(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Places
 
setCpuCost(double) - Method in class org.apache.flink.optimizer.costs.Costs
Sets the cost for the CPU.
setCreated_at(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
setCreated_at(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setCrossHint(CrossOperatorBase.CrossHint) - Method in class org.apache.flink.api.common.operators.base.CrossOperatorBase
 
setCurrentKey(K) - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
setCurrentKey(K) - Method in interface org.apache.flink.runtime.state.KeyedStateBackend
Sets the current key that is used for partitioned state.
setCurrentKey(Object) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
setCurrentKey(Object) - Method in interface org.apache.flink.streaming.api.operators.KeyContext
 
setCurrentNamespace(N) - Method in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
 
setCurrentNamespace(N) - Method in class org.apache.flink.runtime.state.heap.AbstractHeapState
 
setCurrentNamespace(N) - Method in interface org.apache.flink.runtime.state.internal.InternalKvState
Sets the current namespace, which will be used when using the state access methods.
setCurrentProgress(float) - Method in class org.apache.flink.yarn.YarnResourceManagerCallbackHandler
Sets the current progress.
setCurrentTime(long) - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
setCurrentUserRetweet(CurrentUserRetweet) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
setCustomEndpointInitializer(TwitterSource.EndpointInitializer) - Method in class org.apache.flink.streaming.connectors.twitter.TwitterSource
Set a custom endpoint initializer.
setCustomPartitioned(FieldList, Partitioner<?>) - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
 
setCustomPartitioned(FieldSet, Partitioner<?>) - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
Sets these properties to request a custom partitioning with the given Partitioner instance.
setCustomPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
 
setCustomPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
 
setCustomPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.common.operators.base.JoinOperatorBase
 
setCustomPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
setCustomPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.common.operators.base.ReduceOperatorBase
 
setCustomPartitioner(Partitioner<?>) - Method in class org.apache.flink.optimizer.operators.AbstractJoinDescriptor
 
setCustomPartitioner(Partitioner<?>) - Method in class org.apache.flink.optimizer.operators.CoGroupDescriptor
 
setDataDistribution(DataDistribution) - Method in class org.apache.flink.optimizer.plan.Channel
 
setDataExchangeMode(DataExchangeMode) - Method in class org.apache.flink.optimizer.plan.Channel
Sets the data exchange mode (batch / pipelined) to use for the data exchange of this channel.
setDataset(String) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
Notifies this Blackboard that the root just set using SqlToRelConverter.Blackboard.setRoot(RelNode, boolean) was derived using dataset substitution.
setDateAndCacheHeaders(HttpResponse, File) - Static method in class org.apache.flink.runtime.webmonitor.files.StaticFileServerHandler
Sets the "date" and "cache" headers for the HTTP Response.
setDateHeader(FullHttpResponse) - Static method in class org.apache.flink.runtime.webmonitor.files.StaticFileServerHandler
Sets the "date" header for the HTTP response.
setDbStoragePath(String) - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
Sets the path where the RocksDB local database files should be stored on the local file system.
setDbStoragePaths(String...) - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
Sets the paths across which the local RocksDB database files are distributed on the local file system.
setDBUrl(String) - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat.JDBCInputFormatBuilder
 
setDBUrl(String) - Method in class org.apache.flink.api.java.io.jdbc.JDBCOutputFormat.JDBCOutputFormatBuilder
 
setDefault_profile(boolean) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setDefault_profile_image(boolean) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setDefaultCiConfig(Configuration) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
Sets CI environment (Travis) specific config defaults.
setDefaultLocalParallelism(int) - Static method in class org.apache.flink.api.java.ExecutionEnvironment
Sets the default parallelism that will be used for the local execution environment created by ExecutionEnvironment.createLocalEnvironment().
setDefaultLocalParallelism(int) - Method in class org.apache.flink.api.scala.ExecutionEnvironment$
Sets the default parallelism that will be used for the local execution environment created by createLocalEnvironment().
setDefaultLocalParallelism(int) - Static method in class org.apache.flink.api.scala.ExecutionEnvironment
Sets the default parallelism that will be used for the local execution environment created by createLocalEnvironment().
setDefaultLocalParallelism(int) - Static method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Sets the default parallelism that will be used for the local execution environment created by StreamExecutionEnvironment.createLocalEnvironment().
setDefaultLocalParallelism(int) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment$
Sets the default parallelism that will be used for the local execution environment created by createLocalEnvironment().
setDefaultLocalParallelism(int) - Static method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Sets the default parallelism that will be used for the local execution environment created by createLocalEnvironment().
setDefaultOverwriteFiles(boolean) - Method in class org.apache.flink.client.LocalExecutor
 
setDefaultParallelism(int) - Method in class org.apache.flink.api.common.Plan
Sets the default parallelism for this plan.
setDefaultParallelism(int) - Method in class org.apache.flink.client.RemoteExecutor
Sets the parallelism that will be used when neither the program does not define any parallelism at all.
setDefaultParallelism(int) - Method in class org.apache.flink.optimizer.Optimizer
 
setDefaultScheme(Configuration) - Static method in class org.apache.flink.core.fs.FileSystem
Sets the default filesystem scheme based on the user-specified configuration parameter fs.default-scheme.
setDefaultValue(String) - Method in class org.apache.flink.graph.drivers.parameter.ChoiceParameter
Set the default value and add to the list of choices.
setDefaultValue(double) - Method in class org.apache.flink.graph.drivers.parameter.DoubleParameter
Set the default value.
setDefaultValue(long) - Method in class org.apache.flink.graph.drivers.parameter.LongParameter
Set the default value.
setDefaultValue(T) - Method in class org.apache.flink.graph.drivers.parameter.SimpleParameter
Set the default value, used if no value is set by the command-line configuration.
setDefaultValue(String) - Method in class org.apache.flink.graph.drivers.parameter.StringParameter
Set the default value.
setDegree(int) - Method in class org.apache.flink.ml.preprocessing.PolynomialFeatures
 
setDelayMillis(long) - Method in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase.BulkFlushBackoffPolicy
 
setDelimiter(byte[]) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
setDelimiter(char) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
setDelimiter(String) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
setDescription(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setDest(Path) - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
setDetached(boolean) - Method in class org.apache.flink.client.program.ClusterClient
Set the mode of this client (detached or blocking job execution).
setDetachedMode(boolean) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
 
setDetachedPlan(FlinkPlan) - Method in class org.apache.flink.client.program.DetachedEnvironment
 
setDirection(EdgeDirection) - Method in class org.apache.flink.graph.gsa.GSAConfiguration
Sets the direction in which neighbors are to be selected By default the neighbors who are target of the edges are selected
setDirection(EdgeDirection) - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
Sets the direction in which messages are sent in the ScatterFunction.
setDiskCost(double) - Method in class org.apache.flink.optimizer.costs.Costs
Sets the costs for disk for this Costs object.
setDisplay_url(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Media
 
setDisplay_url(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.URL
 
setDistanceMetric(DistanceMetric) - Method in class org.apache.flink.ml.nn.KNN
Sets the distance metric
setDistribution(DataDistribution) - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
setDouble(String, double) - Method in class org.apache.flink.configuration.Configuration
Adds the given key/value pair to the configuration object.
setDouble(ConfigOption<Double>, double) - Method in class org.apache.flink.configuration.Configuration
Adds the given value to the configuration object.
setDouble(String, double) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
setDouble(ConfigOption<Double>, double) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
setDriver(Class<? extends Driver>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setDriverComparator(TypeComparatorFactory<?>, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setDriverKeyInfo(FieldList, int) - Method in class org.apache.flink.optimizer.plan.SingleInputPlanNode
Sets the key field indexes for the specified driver comparator.
setDriverKeyInfo(FieldList, boolean[], int) - Method in class org.apache.flink.optimizer.plan.SingleInputPlanNode
Sets the key field information for the specified driver comparator.
setDrivername(String) - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat.JDBCInputFormatBuilder
 
setDrivername(String) - Method in class org.apache.flink.api.java.io.jdbc.JDBCOutputFormat.JDBCOutputFormatBuilder
 
setDriverPairComparator(TypePairComparatorFactory<?, ?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setDriverStrategy(DriverStrategy) - Method in class org.apache.flink.optimizer.plan.PlanNode
Sets the driver strategy for this node.
setDriverStrategy(DriverStrategy) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setDynamicParamCountInExplain(int) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Sets the number of dynamic parameters in the current EXPLAIN PLAN statement.
setDynamicProperties(Configuration) - Static method in class org.apache.flink.configuration.GlobalConfiguration
Set the process-wide dynamic properties to be merged with the loaded configuration.
setDynamicPropertiesEncoded(String) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
 
setEdgeGroupCount(Long) - Method in class org.apache.flink.graph.library.Summarization.EdgeValue
 
setEdgeGroupValue(EV) - Method in class org.apache.flink.graph.library.Summarization.EdgeValue
 
setElement(T) - Method in class org.apache.flink.table.runtime.aggregate.SingleElementIterable
 
setEncodeForHTML(boolean) - Method in class org.apache.flink.optimizer.plandump.PlanJSONDumpGenerator
 
setEndOffsetExclusive(long) - Method in class org.apache.flink.runtime.state.BoundedInputStream
 
setEntities(Entities) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
setEntities(Entities) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setEnv(Map<String, String>) - Static method in class org.apache.flink.core.testutils.CommonTestUtils
 
setEnv(Map<String, String>, boolean) - Static method in class org.apache.flink.core.testutils.CommonTestUtils
 
setEnv(Map<String, String>) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
setEnvironment(Environment) - Method in class org.apache.flink.runtime.jobgraph.tasks.AbstractInvokable
Sets the environment of this task.
setError(Throwable) - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannel
Atomically sets an error for this channel and notifies the input gate about available data to trigger querying this channel by the task thread.
setErrorState(FieldParser.ParseErrorState) - Method in class org.apache.flink.types.parser.FieldParser
Sets the error state of the parser.
setErrorTolerance(double) - Method in class org.apache.flink.ml.outlier.StochasticOutlierSelection
The accepted error tolerance to reduce computational time when approximating the affinity.
setEstimatedNumRecords(long) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
setEstimatedOutputSize(long) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
setExecutable(boolean) - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
setExecutedVertex(Execution) - Method in class org.apache.flink.runtime.instance.SimpleSlot
Atomically sets the executed vertex, if no vertex has been assigned to this slot so far.
setExecutionConfig(ExecutionConfig) - Method in class org.apache.flink.api.common.Plan
Sets the runtime config object defining execution parameters.
setExecutionConfig(ExecutionConfig) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Sets the execution config.
setExecutionMode(ExecutionMode) - Method in class org.apache.flink.api.common.ExecutionConfig
Sets the execution mode to execute the program.
setExecutionRetryDelay(long) - Method in class org.apache.flink.api.common.ExecutionConfig
Deprecated.
This method will be replaced by ExecutionConfig.setRestartStrategy(org.apache.flink.api.common.restartstrategy.RestartStrategies.RestartStrategyConfiguration). The RestartStrategies.FixedDelayRestartStrategyConfiguration contains the delay between successive execution attempts.
setExpanded_url(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Media
 
setExpanded_url(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.URL
 
setExtract(boolean) - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
setFailOnMissingField(boolean) - Method in class org.apache.flink.streaming.connectors.kafka.KafkaJsonTableSource
Configures the failure behaviour if a JSON field is missing.
setFailOnMissingField(boolean) - Method in class org.apache.flink.streaming.util.serialization.JsonRowDeserializationSchema
Configures the failure behaviour if a JSON field is missing.
setFavorite_count(long) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
setFavorited(boolean) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
setFavourites_count(long) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple
Sets the field at the specified position.
setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple0
 
setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple1
 
setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple10
 
setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple11
 
setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple12
 
setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple13
 
setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple14
 
setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple15
 
setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple16
 
setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple17
 
setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple18
 
setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple19
 
setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple2
 
setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple20
 
setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple21
 
setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple22
 
setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple23
 
setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple24
 
setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple25
 
setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple3
 
setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple4
 
setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple5
 
setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple6
 
setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple7
 
setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple8
 
setField(T, int) - Method in class org.apache.flink.api.java.tuple.Tuple9
 
setField(int, Value) - Method in class org.apache.flink.types.Record
Sets the field at the given position to the given value.
setField(int, Object) - Method in class org.apache.flink.types.Row
Sets the field at the specified position.
setFieldDelimiter(String) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
setFields(T0) - Method in class org.apache.flink.api.java.tuple.Tuple1
Sets new values to all fields of the tuple.
setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in class org.apache.flink.api.java.tuple.Tuple10
Sets new values to all fields of the tuple.
setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Method in class org.apache.flink.api.java.tuple.Tuple11
Sets new values to all fields of the tuple.
setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Method in class org.apache.flink.api.java.tuple.Tuple12
Sets new values to all fields of the tuple.
setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Method in class org.apache.flink.api.java.tuple.Tuple13
Sets new values to all fields of the tuple.
setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - Method in class org.apache.flink.api.java.tuple.Tuple14
Sets new values to all fields of the tuple.
setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - Method in class org.apache.flink.api.java.tuple.Tuple15
Sets new values to all fields of the tuple.
setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15) - Method in class org.apache.flink.api.java.tuple.Tuple16
Sets new values to all fields of the tuple.
setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16) - Method in class org.apache.flink.api.java.tuple.Tuple17
Sets new values to all fields of the tuple.
setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17) - Method in class org.apache.flink.api.java.tuple.Tuple18
Sets new values to all fields of the tuple.
setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18) - Method in class org.apache.flink.api.java.tuple.Tuple19
Sets new values to all fields of the tuple.
setFields(T0, T1) - Method in class org.apache.flink.api.java.tuple.Tuple2
Sets new values to all fields of the tuple.
setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19) - Method in class org.apache.flink.api.java.tuple.Tuple20
Sets new values to all fields of the tuple.
setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20) - Method in class org.apache.flink.api.java.tuple.Tuple21
Sets new values to all fields of the tuple.
setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21) - Method in class org.apache.flink.api.java.tuple.Tuple22
Sets new values to all fields of the tuple.
setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22) - Method in class org.apache.flink.api.java.tuple.Tuple23
Sets new values to all fields of the tuple.
setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22, T23) - Method in class org.apache.flink.api.java.tuple.Tuple24
Sets new values to all fields of the tuple.
setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22, T23, T24) - Method in class org.apache.flink.api.java.tuple.Tuple25
Sets new values to all fields of the tuple.
setFields(T0, T1, T2) - Method in class org.apache.flink.api.java.tuple.Tuple3
Sets new values to all fields of the tuple.
setFields(T0, T1, T2, T3) - Method in class org.apache.flink.api.java.tuple.Tuple4
Sets new values to all fields of the tuple.
setFields(T0, T1, T2, T3, T4) - Method in class org.apache.flink.api.java.tuple.Tuple5
Sets new values to all fields of the tuple.
setFields(T0, T1, T2, T3, T4, T5) - Method in class org.apache.flink.api.java.tuple.Tuple6
Sets new values to all fields of the tuple.
setFields(T0, T1, T2, T3, T4, T5, T6) - Method in class org.apache.flink.api.java.tuple.Tuple7
Sets new values to all fields of the tuple.
setFields(T0, T1, T2, T3, T4, T5, T6, T7) - Method in class org.apache.flink.api.java.tuple.Tuple8
Sets new values to all fields of the tuple.
setFields(T0, T1, T2, T3, T4, T5, T6, T7, T8) - Method in class org.apache.flink.api.java.tuple.Tuple9
Sets new values to all fields of the tuple.
setFieldsGeneric(int[], Class<?>[]) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
setFieldsGeneric(boolean[], Class<?>[]) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
setFieldTypesGeneric(Class<?>...) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
setFilehandlesDriver(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setFilehandlesInput(int, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setFilePath(String) - Method in class org.apache.flink.api.common.io.FileInputFormat
 
setFilePath(Path) - Method in class org.apache.flink.api.common.io.FileInputFormat
 
setFilesFilter(FilePathFilter) - Method in class org.apache.flink.api.common.io.FileInputFormat
 
setFilter_level(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
setFilterFactor(float) - Method in class org.apache.flink.api.common.operators.CompilerHints
 
setFirstDegree(Integer) - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.EdgeWithDegrees
 
setFirstDegree(Integer) - Method in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
 
setFirstInput(Operator<IN1>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
Clears all previous connections and connects the first input to the task wrapped in this contract
setFirstInput(Operator<IN1>...) - Method in class org.apache.flink.api.common.operators.DualInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
setFirstInputs(List<Operator<IN1>>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
setFirstRecordStart(long) - Method in class org.apache.flink.api.common.io.BlockInfo
Sets the firstRecordStart to the specified value.
setFirstVertex(Integer) - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Edge
 
setFirstVertex(Integer) - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.EdgeWithDegrees
 
setFirstVertex(Integer) - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Triad
 
setFirstVertex(K) - Method in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
 
setFirstVertex(K) - Method in class org.apache.flink.graph.library.TriangleEnumerator.Triad
 
setFlinkCollector(Collector<Tuple2<KEY, VALUE>>) - Method in class org.apache.flink.hadoopcompatibility.mapred.wrapper.HadoopOutputCollector
Set the wrapped Flink collector.
setFlinkConfiguration(Configuration) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
 
setFloat(String, float) - Method in class org.apache.flink.configuration.Configuration
Adds the given key/value pair to the configuration object.
setFloat(ConfigOption<Float>, float) - Method in class org.apache.flink.configuration.Configuration
Adds the given value to the configuration object.
setFloat(String, float) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
setFloat(ConfigOption<Float>, float) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
setFlushOnCheckpoint(boolean) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010.FlinkKafkaProducer010Configuration
If set to true, the Flink producer will wait for all outstanding messages in the Kafka buffers to be acknowledged by the Kafka producer on a checkpoint.
setFlushOnCheckpoint(boolean) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
If set to true, the Flink producer will wait for all outstanding messages in the Kafka buffers to be acknowledged by the Kafka producer on a checkpoint.
setFlushOnCheckpoint(boolean) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
If set to true, the Flink producer will wait for all outstanding messages in the Kafka buffers to be acknowledged by the Kafka producer on a checkpoint.
setFollow_request_sent(boolean) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setFollowers_count(long) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setFollowing(boolean) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setForceCheckpointing(boolean) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
Deprecated.
This will be removed once iterations properly participate in checkpointing.
setForcedRebalanced() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
 
setForceRebalancing() - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
 
setFormatDescription(String) - Method in class org.apache.flink.runtime.jobgraph.InputFormatVertex
 
setFormatDescription(String) - Method in class org.apache.flink.runtime.jobgraph.OutputFormatVertex
 
setForwardedFields(Row, Row) - Method in class org.apache.flink.table.runtime.aggregate.GeneratedAggregations
Copies forwarded fields, such as grouping keys, from input row to output row.
setFrameworkID(Option<Protos.FrameworkID>) - Method in interface org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore
Set the stored Mesos framework ID.
setFrameworkID(Option<Protos.FrameworkID>) - Method in class org.apache.flink.mesos.runtime.clusterframework.store.StandaloneMesosWorkerStore
 
setFrameworkID(Option<Protos.FrameworkID>) - Method in class org.apache.flink.mesos.runtime.clusterframework.store.ZooKeeperMesosWorkerStore
Update the persisted framework ID.
setFrequency(int) - Method in class org.apache.flink.examples.java.wordcount.WordCountPojo.Word
 
setFrequency(Integer) - Method in class org.apache.flink.streaming.examples.wordcount.PojoExample.Word
 
setFriends_count(long) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setFSConfig(Configuration) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
Specify a custom Configuration that will be used when creating the FileSystem for writing.
setFSConfig(Configuration) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
Specify a custom Configuration that will be used when creating the FileSystem for writing.
setFSConfig(Configuration) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
Deprecated.
Specify a custom Configuration that will be used when creating the FileSystem for writing.
setFSConfig(Configuration) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
Deprecated.
Specify a custom Configuration that will be used when creating the FileSystem for writing.
setFull_name(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Places
 
setFullyReplicated() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
 
setFullyReplicated() - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
 
setFunctionRuntimeContext(Function, RuntimeContext) - Static method in class org.apache.flink.api.common.functions.util.FunctionUtils
 
setFunctionState(StateHandle<Serializable>) - Method in class org.apache.flink.migration.streaming.runtime.tasks.StreamTaskState
Deprecated.
 
setFurtherPatitioning(boolean) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
 
setGateIterativeWithNumberOfEventsUntilInterrupt(int, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setGeo_enabled(boolean) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setGlobalJobParameters(ExecutionConfig.GlobalJobParameters) - Method in class org.apache.flink.api.common.ExecutionConfig
Register a custom, serializable user configuration object.
setGroupedFields(FieldSet) - Method in class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
Sets the fields that are grouped in these data properties.
setGroupOrder(int, Ordering) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
Sets the order of the elements within a group for the given input.
setGroupOrder(int, Ordering) - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
Sets the order of the elements within a group for the given input.
setGroupOrder(Ordering) - Method in class org.apache.flink.api.common.operators.base.GroupCombineOperatorBase
Sets the order of the elements within a reduce group.
setGroupOrder(Ordering) - Method in class org.apache.flink.api.common.operators.base.GroupReduceOperatorBase
Sets the order of the elements within a reduce group.
setGroupOrderForInputOne(Ordering) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
Sets the order of the elements within a group for the first input.
setGroupOrderForInputOne(Ordering) - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
Sets the order of the elements within a group for the first input.
setGroupOrderForInputTwo(Ordering) - Method in class org.apache.flink.api.common.operators.base.CoGroupOperatorBase
Sets the order of the elements within a group for the second input.
setGroupOrderForInputTwo(Ordering) - Method in class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase
Sets the order of the elements within a group for the second input.
setGroupRepresentativeId(K) - Method in class org.apache.flink.graph.library.Summarization.VertexGroupItem
 
setGroupRepresentativeId(K) - Method in class org.apache.flink.graph.library.Summarization.VertexWithRepresentative
 
setGroupSize(int) - Method in class org.apache.flink.graph.library.similarity.JaccardIndex
Override the default group size for the quadratic expansion of neighbor pairs.
setHashPartitioned(FieldList) - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
Sets this global properties to represent a hash partitioning.
setHashPartitioned(FieldSet) - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
Sets these properties to request a hash partitioning on the given fields.
setHashtags(List<HashTags>) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Entities
 
setHeight(long) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Size
 
setHeuristicCpuCost(double) - Method in class org.apache.flink.optimizer.costs.Costs
Sets the heuristic cost for the CPU.
setHeuristicDiskCost(double) - Method in class org.apache.flink.optimizer.costs.Costs
Sets the heuristic costs for disk for this Costs object.
setHeuristicNetworkCost(double) - Method in class org.apache.flink.optimizer.costs.Costs
Sets the heuristic network cost for this Costs object.
setHost(String) - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
 
setHost(String) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
Sets the cassandra host to connect to.
setHost(String, int) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
Sets the cassandra host/port to connect to.
setHost(String) - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
 
setId(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Places
 
setId(long) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Contributors
 
setId(long) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.CurrentUserRetweet
 
setId(long) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Media
 
setId(long) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.UserMention
 
setId(long) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
setId(long) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setId(K) - Method in class org.apache.flink.graph.Vertex
 
setID - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
setId_str(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Contributors
 
setId_str() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.CurrentUserRetweet
 
setId_str(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Media
 
setId_str() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.UserMention
 
setId_str(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
setId_str(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setImmediateSolutionSetUpdate(boolean) - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
 
setImplicitConvergenceCriterion(String, ConvergenceCriterion<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
Sets the default convergence criterion of a DeltaIteration
setIn(DataInput) - Method in class org.apache.flink.api.avro.DataInputDecoder
 
setIn(DataInput) - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
setIn_reply_to_screen_name(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
setIn_reply_to_status_id(long) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
setIn_reply_to_status_id_str(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
setIn_reply_to_user_id(long) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
setIn_reply_to_user_id_str(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
setInactiveBucketCheckInterval(long) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
Sets the default time between checks for inactive buckets.
setInactiveBucketThreshold(long) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
Sets the default threshold for marking a bucket as inactive and closing its part files.
setIncludeZeroDegreeVertices(boolean) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees
By default only the edge set is processed for the computation of degree.
setIncludeZeroDegreeVertices(boolean) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexInDegree
By default only the edge set is processed for the computation of degree.
setIncludeZeroDegreeVertices(boolean) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexOutDegree
By default only the edge set is processed for the computation of degree.
setIncludeZeroDegreeVertices(boolean) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.VertexDegree
By default only the edge set is processed for the computation of degree.
setIncludeZeroDegreeVertices(boolean) - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient
By default the vertex set is checked for zero degree vertices.
setIncludeZeroDegreeVertices(boolean) - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient
By default the vertex set is checked for zero degree vertices.
setIncludeZeroDegreeVertices(boolean) - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics
By default only the edge set is processed for the computation of degree.
setIncludeZeroDegreeVertices(boolean) - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics
By default only the edge set is processed for the computation of degree.
setIncomingConnection(DagConnection) - Method in class org.apache.flink.optimizer.dag.SingleInputNode
Sets the connection through which this node receives its input.
setIndices(long[]) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.HashTags
 
setIndices(long, long) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.HashTags
 
setIndices(long[]) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Media
 
setIndices(long[]) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Symbol
 
setIndices(long[]) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.URL
 
setIndices(long[]) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.UserMention
 
setInitialSolutionSet(Operator<ST>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
Sets the given input as the initial solution set.
setInitialState(TaskStateHandles) - Method in class org.apache.flink.runtime.executiongraph.Execution
Sets the initial state for the execution.
setInitialState(TaskStateHandles) - Method in interface org.apache.flink.runtime.jobgraph.tasks.StatefulTask
Sets the initial state of the operator, upon recovery.
setInitialState(TaskStateHandles) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
setInitialWorkset(Operator<WT>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
Sets the given input as the initial workset.
setInPhysicalEdges(List<StreamEdge>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setInProgressPrefix(String) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
Sets the prefix of in-progress part files.
setInProgressPrefix(String) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
Deprecated.
Sets the prefix of in-progress part files.
setInProgressSuffix(String) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
Sets the suffix of in-progress part files.
setInProgressSuffix(String) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
Deprecated.
Sets the suffix of in-progress part files.
setInput(Operator<IN>) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
Sets the given operator as the input to this operator.
setInput(Operator<IN>) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
Sets the given operator as the input to this operator.
setInput(Operator<IN>...) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
setInput(DataSet<IN>) - Method in interface org.apache.flink.api.java.operators.CustomUnaryOperation
 
setInput(DataSet<IN>) - Method in class org.apache.flink.api.java.operators.NoOpOperator
 
setInput(DataSet<Vertex<K, VV>>) - Method in class org.apache.flink.graph.gsa.GatherSumApplyIteration
Sets the input data set for this operator.
setInput(DataSet<Vertex<K, VV>>) - Method in class org.apache.flink.graph.pregel.VertexCentricIteration
Sets the input data set for this operator.
setInput(DataSet<Vertex<K, VV>>) - Method in class org.apache.flink.graph.spargel.ScatterGatherIteration
Sets the input data set for this operator.
setInput(Map<Operator<?>, OptimizerNode>, ExecutionMode) - Method in class org.apache.flink.optimizer.dag.AbstractPartialSolutionNode
 
setInput(Map<Operator<?>, OptimizerNode>, ExecutionMode) - Method in class org.apache.flink.optimizer.dag.DataSinkNode
 
setInput(Map<Operator<?>, OptimizerNode>, ExecutionMode) - Method in class org.apache.flink.optimizer.dag.DataSourceNode
 
setInput(Map<Operator<?>, OptimizerNode>, ExecutionMode) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
This function connects the predecessors to this operator.
setInput(Map<Operator<?>, OptimizerNode>, ExecutionMode) - Method in class org.apache.flink.optimizer.dag.SingleInputNode
 
setInput(Map<Operator<?>, OptimizerNode>, ExecutionMode) - Method in class org.apache.flink.optimizer.dag.TwoInputNode
 
setInput(Object) - Method in class org.apache.flink.table.runtime.TableFunctionCollector
Sets the input row from left table, which will be used to cross join with the result of table function.
setInputAsynchronouslyMaterialized(int, boolean) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setInputCached(int, boolean) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setInputChannel(IntermediateResultPartitionID, InputChannel) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
setInputComparator(TypeComparatorFactory<?>, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setInputFormat(Integer, InputFormat<?, ?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
setInputFormat(InputFormat<?, ?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
setInputLocalStrategy(int, LocalStrategy) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setInputs(Operator<IN>...) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
setInputs(List<Operator<IN>>) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
setInputs(List<Operator<IN>>) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
setInputs(DagConnection, DagConnection) - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode.SingleRootJoiner
 
setInputSerializer(TypeSerializerFactory<?>, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setInputSplitSource(InputSplitSource<?>) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.api.java.io.CsvOutputFormat
The purpose of this method is solely to check whether the data type to be processed is in fact a tuple type.
setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.api.java.io.LocalCollectionOutputFormat
 
setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.api.java.io.TypeSerializerOutputFormat
 
setInputType(TypeInformation<?>, ExecutionConfig) - Method in interface org.apache.flink.api.java.typeutils.InputTypeConfigurable
Method that is called on an OutputFormat when it is passed to the DataSet's output method.
setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.api.scala.operators.ScalaCsvOutputFormat
The purpose of this method is solely to check whether the data type to be processed is in fact a tuple type.
setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
 
setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter
 
setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
 
setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
Deprecated.
 
setInputType(TypeInformation<?>, ExecutionConfig) - Method in class org.apache.flink.streaming.connectors.fs.SequenceFileWriter
 
setInstance(T) - Method in interface org.apache.flink.runtime.plugable.DeserializationDelegate
 
setInstance(T) - Method in class org.apache.flink.runtime.plugable.NonReusingDeserializationDelegate
 
setInstance(T) - Method in class org.apache.flink.runtime.plugable.ReusingDeserializationDelegate
 
setInstance(T) - Method in class org.apache.flink.runtime.plugable.SerializationDelegate
 
setInteger(String, int) - Method in class org.apache.flink.configuration.Configuration
Adds the given key/value pair to the configuration object.
setInteger(ConfigOption<Integer>, int) - Method in class org.apache.flink.configuration.Configuration
Adds the given value to the configuration object.
setInteger(String, int) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
setInteger(ConfigOption<Integer>, int) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
setInterestingProperties(InterestingProperties) - Method in class org.apache.flink.optimizer.dag.DagConnection
Sets the interesting properties for this pact connection.
setInvokableClass(Class<? extends AbstractInvokable>) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
setIs_translator(boolean) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setIsAppendOnly(Boolean) - Method in interface org.apache.flink.table.sinks.UpsertStreamTableSink
Specifies whether the Table to write is append-only or not.
setIsCompacted(boolean) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
sets compaction status (should only be set true directly after compaction and false when garbage was created)
setIso3(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Attributes
 
setIsSolutionSetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setIsSolutionSetUpdateWithoutReprobe() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setIsWorksetIteration() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setIsWorksetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setItemCount(long) - Method in class org.apache.flink.api.avro.DataOutputEncoder
 
setItemCount(long) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
setIterationHeadFinalOutputConfig(TaskConfig) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setIterationHeadIndexOfSyncOutput(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setIterationHeadPartialSolutionOrWorksetInputIndex(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setIterationHeadSolutionSetInputIndex(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setIterationId(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setIterationId(String) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setIterations(int) - Method in class org.apache.flink.ml.classification.SVM
Sets the number of outer iterations
setIterations(int) - Static method in class org.apache.flink.ml.optimization.GradientDescent
 
setIterations(int) - Method in class org.apache.flink.ml.optimization.IterativeSolver
 
setIterations(int) - Method in class org.apache.flink.ml.recommendation.ALS
Sets the number of iterations of the ALS algorithm
setIterations(int) - Method in class org.apache.flink.ml.regression.MultipleLinearRegression
 
setIterationWaitTime(long) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setIterativeReader() - Method in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
 
setIterativeReader() - Method in interface org.apache.flink.runtime.io.network.api.reader.ReaderBase
 
setJobFinished(JobID) - Method in class org.apache.flink.runtime.highavailability.FsNegativeRunningJobsRegistry
 
setJobFinished(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneRunningJobsRegistry
 
setJobFinished(JobID) - Method in interface org.apache.flink.runtime.highavailability.RunningJobsRegistry
Marks a job as completed.
setJobFinished(JobID) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperRunningJobsRegistry
 
setJobId(JobID) - Method in class org.apache.flink.api.common.Plan
Sets the ID of the job that the dataflow plan belongs to.
setJobId(String) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraCommitter
Internally used to set the job ID after instantiation.
setJobId(String) - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
Internally used to set the job ID after instantiation.
setJobManagerAddressInConfig(Configuration, InetSocketAddress) - Static method in class org.apache.flink.client.CliFrontend
Writes the given job manager address to the associated configuration object
setJobManagerMemory(int) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
 
setJobManagerMode(String) - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
 
setJobName(String) - Method in class org.apache.flink.api.common.Plan
Sets the jobName for this Plan.
setJobName(String) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
setJobRunning(JobID) - Method in class org.apache.flink.runtime.highavailability.FsNegativeRunningJobsRegistry
 
setJobRunning(JobID) - Method in class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneRunningJobsRegistry
 
setJobRunning(JobID) - Method in interface org.apache.flink.runtime.highavailability.RunningJobsRegistry
Marks a job as running.
setJobRunning(JobID) - Method in class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperRunningJobsRegistry
 
setJoinHint(JoinOperatorBase.JoinHint) - Method in class org.apache.flink.api.common.operators.base.JoinOperatorBase
 
setJsonPlan(String) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
setK(int) - Method in class org.apache.flink.ml.nn.KNN
Sets K
setKey(K) - Method in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter.AvroKeyValue
 
setKeyContextElement1(StreamRecord) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
setKeyContextElement1(StreamRecord<?>) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
 
setKeyContextElement2(StreamRecord) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
setKeyContextElement2(StreamRecord<?>) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
 
setKeyedStateManagedFuture(RunnableFuture<KeyedStateHandle>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotResult
 
setKeyedStateRawFuture(RunnableFuture<KeyedStateHandle>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotResult
 
setKeyFields(String[]) - Method in interface org.apache.flink.table.sinks.UpsertStreamTableSink
Configures the unique key fields of the Table to write.
setKeyGroupOffset(int, long) - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
Sets the offset for the given key-group.
setKvStates(HashMap<String, KvStateSnapshot<?, ?, ?, ?>>) - Method in class org.apache.flink.migration.streaming.runtime.tasks.StreamTaskState
Deprecated.
 
setLambda(double) - Method in class org.apache.flink.ml.recommendation.ALS
Sets the regularization coefficient lambda
setLang(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
setLang(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setLastActive() - Method in class org.apache.flink.runtime.jobmanager.JobInfo
 
setLastOutputCollector(Collector<OT>) - Method in class org.apache.flink.runtime.operators.BatchTask
Sets the last output Collector of the collector chain of this BatchTask.
setLatencyTrackingInterval(long) - Method in class org.apache.flink.api.common.ExecutionConfig
Interval for sending latency tracking marks from the sources to the sinks.
setLearningRateMethod(LearningRateMethod.LearningRateMethodTrait) - Static method in class org.apache.flink.ml.optimization.GradientDescent
 
setLearningRateMethod(LearningRateMethod.LearningRateMethodTrait) - Method in class org.apache.flink.ml.optimization.IterativeSolver
 
setLearningRateMethod(LearningRateMethod.LearningRateMethodTrait) - Method in class org.apache.flink.ml.regression.MultipleLinearRegression
 
setLength(int) - Method in class org.apache.flink.types.StringValue
Sets a new length for the string.
setLenient(boolean) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
setLineLengthLimit(int) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
setListed_count(long) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setLittleParallelism(int) - Method in class org.apache.flink.graph.library.clustering.directed.AverageClusteringCoefficient
Override the parallelism of operators processing small amounts of data.
setLittleParallelism(int) - Method in class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient
Override the parallelism of operators processing small amounts of data.
setLittleParallelism(int) - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient
Override the parallelism of operators processing small amounts of data.
setLittleParallelism(int) - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus
Override the parallelism of operators processing small amounts of data.
setLittleParallelism(int) - Method in class org.apache.flink.graph.library.clustering.directed.TriangleListing
Override the parallelism of operators processing small amounts of data.
setLittleParallelism(int) - Method in class org.apache.flink.graph.library.clustering.undirected.AverageClusteringCoefficient
Override the parallelism of operators processing small amounts of data.
setLittleParallelism(int) - Method in class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient
Override the parallelism of operators processing small amounts of data.
setLittleParallelism(int) - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient
Override the parallelism of operators processing small amounts of data.
setLittleParallelism(int) - Method in class org.apache.flink.graph.library.clustering.undirected.TriadicCensus
Override the parallelism of operators processing small amounts of data.
setLittleParallelism(int) - Method in class org.apache.flink.graph.library.clustering.undirected.TriangleListing
Override the parallelism of operators processing small amounts of data.
setLittleParallelism(int) - Method in class org.apache.flink.graph.library.similarity.AdamicAdar
Override the parallelism of operators processing small amounts of data.
setLittleParallelism(int) - Method in class org.apache.flink.graph.library.similarity.JaccardIndex
Override the parallelism of operators processing small amounts of data.
setLocalIterations(int) - Method in class org.apache.flink.ml.classification.SVM
Sets the number of local SDCA iterations
setLocality(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Attributes
 
setLocality(Locality) - Method in class org.apache.flink.runtime.instance.SimpleSlot
Attached locality information to this slot.
setLocalJarPath(Path) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
 
setLocalOrder(Ordering) - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
Sets the order in which the sink must write its data within each fragment in the distributed file system.
setLocalStrategy(LocalStrategy) - Method in class org.apache.flink.optimizer.plan.Channel
 
setLocalStrategy(LocalStrategy, FieldList, boolean[]) - Method in class org.apache.flink.optimizer.plan.Channel
 
setLocalStrategyComparator(TypeComparatorFactory<?>) - Method in class org.apache.flink.optimizer.plan.Channel
Sets the local strategy comparator for this Channel.
setLocation(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setLogFailuresOnly(boolean) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010.FlinkKafkaProducer010Configuration
Defines whether the producer should fail on errors, or only log them.
setLogFailuresOnly(boolean) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
Defines whether the producer should fail on errors, or only log them.
setLogFailuresOnly(boolean) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
Defines whether the producer should fail on errors, or only log them.
setLogFailuresOnly(boolean) - Method in class org.apache.flink.streaming.connectors.rabbitmq.RMQSink
Defines whether the producer should fail on errors, or only log them.
setLong(String, long) - Method in class org.apache.flink.configuration.Configuration
Adds the given key/value pair to the configuration object.
setLong(ConfigOption<Long>, long) - Method in class org.apache.flink.configuration.Configuration
Adds the given value to the configuration object.
setLong(String, long) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
setLong(ConfigOption<Long>, long) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
setLossFunction(LossFunction) - Static method in class org.apache.flink.ml.optimization.GradientDescent
 
setLossFunction(LossFunction) - Static method in class org.apache.flink.ml.optimization.IterativeSolver
 
setLossFunction(LossFunction) - Method in class org.apache.flink.ml.optimization.Solver
 
setManagedMemoryPerTaskManager(long) - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
setMaterializationMode(TempMode) - Method in class org.apache.flink.optimizer.dag.DagConnection
 
setMax(double) - Method in class org.apache.flink.ml.preprocessing.MinMaxScaler
Sets the maximum for the range of the transformed data
setMaxConcurrentCheckpoints(int) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
Sets the maximum number of checkpoint attempts that may be in progress at the same time.
setMaximumNumberOfIterations(int) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
 
setMaximumNumberOfIterations(int) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
 
setMaximumScore(int, int) - Method in class org.apache.flink.graph.library.similarity.JaccardIndex
Filter out Jaccard Index scores greater than the given maximum fraction.
setMaximumValue(double, boolean) - Method in class org.apache.flink.graph.drivers.parameter.DoubleParameter
Set the maximum value.
setMaximumValue(long) - Method in class org.apache.flink.graph.drivers.parameter.LongParameter
Set the maximum value.
setMaxIterations(int) - Method in class org.apache.flink.ml.outlier.StochasticOutlierSelection
The maximum number of iterations to approximate the affinity of the algorithm.
setMaxParallelism(int) - Method in class org.apache.flink.api.common.ExecutionConfig
Sets the maximum degree of parallelism defined for the program.
setMaxParallelism(int) - Method in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
setMaxParallelism(int) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
Sets the maximum parallelism for the task.
setMaxParallelism(int) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Sets the maximum parallelism of this operator.
setMaxParallelism(int) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Sets the maximum degree of parallelism defined for the program.
setMaxParallelism(int, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
setMaxParallelism(int) - Method in class org.apache.flink.streaming.api.scala.DataStream
 
setMaxParallelism(int) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Sets the maximum degree of parallelism defined for the program.
setMaxParallelism(int) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
Sets the maximum parallelism for this stream transformation.
setMaxRetryCount(int) - Method in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase.BulkFlushBackoffPolicy
 
setMean(double) - Method in class org.apache.flink.ml.preprocessing.StandardScaler
Sets the target mean of the transformed data
setMedia(List<Media>) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Entities
 
setMedia_url(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Media
 
setMedia_url_https(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Media
 
setMemory(Configuration) - Method in class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
setMemorySegment(MemorySegment, int) - Method in class org.apache.flink.runtime.operators.util.BitSet
 
setMemorySegment(MemorySegment, int) - Method in class org.apache.flink.runtime.operators.util.BloomFilter.BitSet
 
setMetaInfo(RegisteredKeyedBackendStateMetaInfo<N, S>) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
setMetaInfo(RegisteredKeyedBackendStateMetaInfo<N, S>) - Method in class org.apache.flink.runtime.state.heap.StateTable
 
setMetricGroup(TaskIOMetricGroup) - Method in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
Sets the metric group for this RecordWriter.
setMetricGroup(TaskIOMetricGroup) - Method in class org.apache.flink.streaming.runtime.io.StreamInputProcessor
Sets the metric group for this StreamInputProcessor.
setMetricGroup(TaskIOMetricGroup) - Method in class org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor
Sets the metric group for this StreamTwoInputProcessor.
setMin(double) - Method in class org.apache.flink.ml.preprocessing.MinMaxScaler
Sets the minimum for the range of the transformed data
setMinimumRatio(float) - Method in class org.apache.flink.graph.library.similarity.AdamicAdar
Filter out Adamic-Adar scores less than the given ratio times the average score.
setMinimumScore(float) - Method in class org.apache.flink.graph.library.similarity.AdamicAdar
Filter out Adamic-Adar scores less than the given minimum.
setMinimumScore(int, int) - Method in class org.apache.flink.graph.library.similarity.JaccardIndex
Filter out Jaccard Index scores less than the given minimum fraction.
setMinimumValue(double, boolean) - Method in class org.apache.flink.graph.drivers.parameter.DoubleParameter
Set the minimum value.
setMinimumValue(long) - Method in class org.apache.flink.graph.drivers.parameter.LongParameter
Set the minimum value.
setMinPauseBetweenCheckpoints(long) - Method in class org.apache.flink.streaming.api.environment.CheckpointConfig
Sets the minimal pause between checkpointing attempts.
setMinSplitSize(long) - Method in class org.apache.flink.api.common.io.FileInputFormat
 
setMirrorResults(boolean) - Method in class org.apache.flink.graph.library.similarity.JaccardIndex
By default only one result is output for each pair of vertices.
setMutableObjectMode(boolean) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setName(String) - Method in class org.apache.flink.api.common.operators.Operator
Sets the name of the contract instance.
setName(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Places
 
setName(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.UserMention
 
setName(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setName(String) - Method in class org.apache.flink.graph.IterationConfiguration
Sets the name for the iteration.
setName(String) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
Sets the name of the vertex
setName(String) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
Changes the name of this StreamTransformation.
setName(String) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
 
setNestedFileEnumeration(boolean) - Method in class org.apache.flink.api.common.io.FileInputFormat
 
setNetworkCost(double) - Method in class org.apache.flink.optimizer.costs.Costs
Sets the network cost for this Costs object.
setNetworkRecoveryInterval(int) - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
Sets connection recovery interval.
setNewVertexValue(VV) - Method in class org.apache.flink.graph.pregel.ComputeFunction
Sets the new value of this vertex.
setNewVertexValue(VV) - Method in class org.apache.flink.graph.spargel.GatherFunction
Sets the new value of this vertex.
setNextBuffer(Buffer) - Method in class org.apache.flink.runtime.io.network.api.serialization.AdaptiveSpanningRecordDeserializer
 
setNextBuffer(Buffer) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
 
setNextBuffer(Buffer) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordSerializer
Sets a (next) target buffer to use and continues writing remaining data to it until it is full.
setNextBuffer(Buffer) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
 
setNextBuffer(Buffer) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
 
setNextMemorySegment(MemorySegment, int) - Method in class org.apache.flink.runtime.io.network.api.serialization.AdaptiveSpanningRecordDeserializer
 
setNextMemorySegment(MemorySegment, int) - Method in interface org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer
 
setNextMemorySegment(MemorySegment, int) - Method in class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
 
setNextPartialSolution(Operator<T>) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
 
setNextPartialSolution(OptimizerNode, OptimizerNode) - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
Sets the nextPartialSolution for this BulkIterationNode.
setNextPartialSolution(OptimizerNode, OptimizerNode, ExecutionMode) - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
 
setNextWorkset(Operator<WT>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
Sets the contract of the step function that represents the next workset.
setNoise(boolean, float) - Method in class org.apache.flink.graph.generator.RMatGraph
Enable and configure noise.
setNonChainedOutputs(List<StreamEdge>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setNotifications(boolean) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setNull(int) - Method in class org.apache.flink.types.Record
Sets the field at the given position to null.
setNull(long) - Method in class org.apache.flink.types.Record
Sets the fields to null using the given bit mask.
setNull(long[]) - Method in class org.apache.flink.types.Record
Sets the fields to null using the given bit mask.
setNullCheck(boolean) - Method in class org.apache.flink.table.api.TableConfig
Sets the NULL check.
setNumberOfExecutionRetries(int) - Method in class org.apache.flink.api.common.ExecutionConfig
Deprecated.
This method will be replaced by ExecutionConfig.setRestartStrategy(org.apache.flink.api.common.restartstrategy.RestartStrategies.RestartStrategyConfiguration). The RestartStrategies.FixedDelayRestartStrategyConfiguration contains the number of execution retries.
setNumberOfExecutionRetries(int) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Deprecated.
This method will be replaced by ExecutionEnvironment.setRestartStrategy(org.apache.flink.api.common.restartstrategy.RestartStrategies.RestartStrategyConfiguration). The RestartStrategies.FixedDelayRestartStrategyConfiguration contains the number of execution retries.
setNumberOfExecutionRetries(int) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Deprecated.
This method will be replaced by setRestartStrategy(). The FixedDelayRestartStrategyConfiguration contains the number of execution retries.
setNumberOfExecutionRetries(int) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
setNumberOfExecutionRetries(int) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Deprecated.
This method will be replaced by setRestartStrategy(). The FixedDelayRestartStrategyConfiguration contains the number of execution retries.
setNumberOfInputs(int) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setNumberOfIterations(int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setNumberOfOutputs(int) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setNumberOfTestRepetitions(int) - Method in class org.apache.flink.test.util.JavaProgramTestBase
 
setNumBuffers(int) - Method in interface org.apache.flink.runtime.io.network.buffer.BufferPool
Sets the current size of this buffer pool.
setNumFactors(int) - Method in class org.apache.flink.ml.recommendation.ALS
Sets the number of latent factors/row dimension of the latent model
setNumFields(int) - Method in class org.apache.flink.types.Record
Sets the number of fields in the record.
setNumJobManagers(int) - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
setNumLineSamples(int) - Method in class org.apache.flink.api.common.io.DelimitedInputFormat
 
setNumResourceManagers(int) - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
setNumSplits(int) - Method in class org.apache.flink.api.common.io.FileInputFormat
 
setNumTaskManagers(int) - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
setNumTaskManagers(int) - Method in class org.apache.flink.test.util.AbstractTestBase
 
setNumTaskManagerSlots(int) - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
setOffset(long) - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionState
 
setOffsetInZooKeeper(CuratorFramework, String, String, int, long) - Static method in class org.apache.flink.streaming.connectors.kafka.internals.ZookeeperOffsetHandler
 
setOneInputStateKey(Integer, KeySelector<?, ?>, TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
setOpenTimeout(long) - Method in class org.apache.flink.api.common.io.FileInputFormat
 
setOperator(Integer, StreamOperator<OUT>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
setOperator(StreamOperator<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
setOperatorDescription(String) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
setOperatorId(String) - Method in class org.apache.flink.streaming.runtime.operators.CheckpointCommitter
Internally used to set the operator ID after instantiation.
setOperatorLevelCachingDescription(String) - Method in class org.apache.flink.runtime.jobgraph.JobEdge
Sets the operator-level caching description for this input.
setOperatorName(String) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
setOperatorName(String) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setOperatorPrettyName(String) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
setOperatorState(StateHandle<?>) - Method in class org.apache.flink.migration.streaming.runtime.tasks.StreamTaskState
Deprecated.
 
setOperatorStateManagedFuture(RunnableFuture<OperatorStateHandle>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotResult
 
setOperatorStateRawFuture(RunnableFuture<OperatorStateHandle>) - Method in class org.apache.flink.streaming.api.operators.OperatorSnapshotResult
 
setOptDegrees(boolean) - Method in class org.apache.flink.graph.spargel.ScatterGatherConfiguration
Sets the degree option.
setOptions(OptionsFactory) - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
Sets Options for the RocksDB instances.
setOptNumVertices(boolean) - Method in class org.apache.flink.graph.IterationConfiguration
Sets the number of vertices option.
setOrdering(Ordering) - Method in class org.apache.flink.api.common.operators.base.PartitionOperatorBase
 
setOrdering(Ordering) - Method in class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
Sets the order for these interesting local properties.
setOrderkey(Long) - Method in class org.apache.flink.examples.java.relational.TPCHQuery3.ShippingPriorityItem
 
setOut(DataOutput) - Method in class org.apache.flink.api.avro.DataOutputEncoder
 
setOut(DataOutput) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
setOutEdges(List<StreamEdge>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setOutEdgesInOrder(List<StreamEdge>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setOuterJoinType(OuterJoinOperatorBase.OuterJoinType) - Method in class org.apache.flink.api.common.operators.base.OuterJoinOperatorBase
 
setOutput(Vertex<K, VV>, Collector<Vertex<K, VV>>) - Method in class org.apache.flink.graph.gsa.ApplyFunction
 
setOutputCardinality(long) - Method in class org.apache.flink.api.common.operators.CompilerHints
 
setOutputCollector(Collector<?>) - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
setOutputComparator(TypeComparatorFactory<?>, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setOutputDataDistribution(DataDistribution, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setOutputDecisionFunction(boolean) - Method in class org.apache.flink.ml.classification.SVM
Sets whether the predictions should return the raw decision function value or the thresholded binary value.
setOutputDirectoryMode(FileOutputFormat.OutputDirectoryMode) - Method in class org.apache.flink.api.common.io.FileOutputFormat
 
setOutputFilePath(Path) - Method in class org.apache.flink.api.common.io.FileOutputFormat
 
setOutputPartitioner(Partitioner<?>, int) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setOutputSelectors(List<OutputSelector<?>>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setOutputSerializer(TypeSerializerFactory<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setOutputSize(long) - Method in class org.apache.flink.api.common.operators.CompilerHints
 
setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
 
setOutputType(TypeInformation<R>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyAllWindowFunction
Deprecated.
 
setOutputType(TypeInformation<R>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessAllWindowFunction
Deprecated.
 
setOutputType(TypeInformation<R>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessWindowFunction
Deprecated.
 
setOutputType(TypeInformation<R>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyWindowFunction
Deprecated.
 
setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in interface org.apache.flink.streaming.api.operators.OutputTypeConfigurable
setOutputType(TypeInformation<OUT>, ExecutionConfig) - Method in class org.apache.flink.streaming.api.operators.StreamGroupedFold
Deprecated.
 
setOutputType(TypeInformation<T>) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
Tries to fill in the type information.
setOutputType(Function, TypeInformation<T>, ExecutionConfig) - Static method in class org.apache.flink.streaming.util.functions.StreamingFunctionUtils
 
setOutType(Integer, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
setPairComparator(TypePairComparatorFactory<?, ?>) - Method in class org.apache.flink.optimizer.plan.DualInputPlanNode
 
setParallelism(int) - Method in class org.apache.flink.api.common.ExecutionConfig
Sets the parallelism for operations executed through this environment.
setParallelism(int) - Method in class org.apache.flink.api.common.operators.Operator
Sets the parallelism for this contract instance.
setParallelism(int) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Sets the parallelism for operations executed through this environment.
setParallelism(int) - Method in class org.apache.flink.api.java.operators.DataSink
Sets the parallelism for this data sink.
setParallelism(int) - Method in class org.apache.flink.api.java.operators.Operator
Sets the parallelism for this operator.
setParallelism(int) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
setParallelism(int) - Method in class org.apache.flink.api.scala.DataSet
Sets the parallelism of this operation.
setParallelism(int) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Sets the parallelism (parallelism) for operations executed through this environment.
setParallelism(int) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.EdgeDegreesPair
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.EdgeSourceDegrees
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.EdgeTargetDegrees
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexInDegree
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.degree.annotate.directed.VertexOutDegree
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeDegreePair
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeSourceDegree
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeTargetDegree
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.VertexDegree
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.degree.filter.undirected.MaximumDegree
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.simple.directed.Simplify
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.simple.undirected.Simplify
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.translate.TranslateEdgeValues
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.translate.TranslateGraphIds
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.asm.translate.TranslateVertexValues
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.generator.AbstractGraphGenerator
 
setParallelism(int) - Method in interface org.apache.flink.graph.generator.GraphGenerator
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.IterationConfiguration
Sets the parallelism for the iteration.
setParallelism(int) - Method in class org.apache.flink.graph.library.link_analysis.HITS
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.library.link_analysis.PageRank
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.library.metric.directed.EdgeMetrics
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.library.metric.undirected.EdgeMetrics
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics
Override the operator parallelism.
setParallelism(int) - Method in class org.apache.flink.optimizer.dag.DataSourceNode
 
setParallelism(int) - Method in class org.apache.flink.optimizer.dag.OptimizerNode
Sets the parallelism for this optimizer node.
setParallelism(int) - Method in class org.apache.flink.optimizer.plan.PlanNode
 
setParallelism(int) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
Sets the parallelism for the task.
setParallelism(int) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
Sets the parallelism for this sink.
setParallelism(int) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSource
 
setParallelism(int) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Sets the parallelism for this operator.
setParallelism(int) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Sets the parallelism for operations executed through this environment.
setParallelism(Integer, int) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
setParallelism(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
setParallelism(int) - Method in class org.apache.flink.streaming.api.scala.DataStream
Sets the parallelism of this operation.
setParallelism(int) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Sets the parallelism for operations executed through this environment.
setParallelism(int) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
Sets the parallelism of this StreamTransformation.
setParallelism(int) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink
Sets the parallelism for this sink.
setParallelism(int) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010.FlinkKafkaProducer010Configuration
 
setParallelism(int) - Method in class org.apache.flink.streaming.util.StreamingProgramTestBase
 
setParallelism(int) - Method in class org.apache.flink.test.util.JavaProgramTestBase
 
setParameter(String, String) - Method in class org.apache.flink.api.common.operators.Operator
Sets a stub parameters in the configuration of this contract.
setParameter(String, int) - Method in class org.apache.flink.api.common.operators.Operator
Sets a stub parameters in the configuration of this contract.
setParameter(String, boolean) - Method in class org.apache.flink.api.common.operators.Operator
Sets a stub parameters in the configuration of this contract.
setParametersProvider(ParameterValuesProvider) - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat.JDBCInputFormatBuilder
 
setPartialSolution(BulkPartialSolutionNode) - Method in class org.apache.flink.optimizer.dag.BulkIterationNode
Sets the partialSolution for this BulkIterationNode.
setPartialSolution(SolutionSetNode, WorksetNode) - Method in class org.apache.flink.optimizer.dag.WorksetIterationNode
 
setPartition(int, IntermediateResultPartition) - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
 
setPartitioner(StreamPartitioner<?>) - Method in class org.apache.flink.streaming.api.graph.StreamEdge
 
setPartitionNumber(int) - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
overwrites partition number and should only be used on compaction partition
setPartitions(int[]) - Method in class org.apache.flink.streaming.connectors.kafka.partitioner.FlinkKafkaDelegatePartitioner
Deprecated.
 
setPartPrefix(String) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
Sets the prefix of part files.
setPartPrefix(String) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
Deprecated.
Sets the prefix of part files.
setPassword(String) - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat.JDBCInputFormatBuilder
 
setPassword(String) - Method in class org.apache.flink.api.java.io.jdbc.JDBCOutputFormat.JDBCOutputFormatBuilder
 
setPassword(String) - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
Set the password.
setPatternVarRef(boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
 
setPendingPrefix(String) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
Sets the prefix of pending part files.
setPendingPrefix(String) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
Deprecated.
Sets the prefix of pending part files.
setPendingSuffix(String) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
Sets the suffix of pending part files.
setPendingSuffix(String) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
Deprecated.
Sets the suffix of pending part files.
setPerplexity(double) - Method in class org.apache.flink.ml.outlier.StochasticOutlierSelection
Sets the perplexity of the outlier selection algorithm, can be seen as the k of kNN For more information, please read the Stochastic Outlier Selection algorithm technical paper.
setPhone(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Attributes
 
setPlace(Places) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
setPlace_type(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Places
 
setPlan(FlinkPlan) - Method in class org.apache.flink.client.program.OptimizerPlanEnvironment
 
setPort(int) - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
Set the target port.
setPosition(int) - Method in class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
 
setPosition(int) - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
setPossibly_sensitive(boolean) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
setPostal_code(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Attributes
 
setPredefinedOptions(PredefinedOptions) - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
Sets the predefined options for RocksDB.
setPreProcessingOperationName(String) - Method in class org.apache.flink.runtime.jobgraph.JobEdge
Sets the name of the pre-processing operation for this input.
setPreview(String) - Method in class org.apache.flink.client.program.PreviewPlanEnvironment
 
setPrintStatusDuringExecution(boolean) - Method in class org.apache.flink.api.common.PlanExecutor
Sets whether the executor should print progress results to "standard out" (System.out).
setPrintStatusDuringExecution(boolean) - Method in class org.apache.flink.client.program.ClusterClient
Configures whether the client should print progress updates during the execution to System.out.
setProcessingTimeService(ProcessingTimeService) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
Allows the user to specify his own TimerServiceProvider.
setProfile_background_color(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setProfile_background_image_url(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setProfile_background_image_url_https(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setProfile_background_tile(boolean) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setProfile_banner_url(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setProfile_image_url(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setProfile_image_url_https(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setProfile_link_color(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setProfile_sidebar_border_color(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setProfile_sidebar_fill_color(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setProfile_text_color(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setProfile_use_background_image(boolean) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setPropagateParentSchemaDown(boolean) - Method in class org.apache.flink.optimizer.postpass.GenericFlatTypePostPass
 
setProtected_tweet(boolean) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setProvidedUserJarFiles(List<URL>) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
Sets the user jar which is included in the system classloader of all nodes.
setPruningMarker() - Method in class org.apache.flink.optimizer.plan.PlanNode
Sets the pruning marker to true.
setQuery(String) - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat.JDBCInputFormatBuilder
 
setQuery(String) - Method in class org.apache.flink.api.java.io.jdbc.JDBCOutputFormat.JDBCOutputFormatBuilder
 
setQuery(String) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
Sets the query that is to be executed for every record.
setQueryable(String) - Method in class org.apache.flink.api.common.state.StateDescriptor
Sets the name for queries of state created from this descriptor.
SetQueue<E> - Class in org.apache.flink.runtime.jobmanager.scheduler
A queue that maintains set characteristics, i.e., elements that are already in the queue may not be added another time.
SetQueue() - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
setQueue(String) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
 
setQueuedSchedulingAllowed(boolean) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
setQuoteStrings(boolean) - Method in class org.apache.flink.api.java.io.CsvOutputFormat
Configures whether the output format should quote string values.
setQuoteStrings(boolean) - Method in class org.apache.flink.api.scala.operators.ScalaCsvOutputFormat
Configures whether the output format should quote string values.
setRandomPartitioned() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
 
setRandomPartitioning() - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
 
setRangePartitioned(Ordering) - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
Set the parameters for range partition.
setRangePartitioned(Ordering, DataDistribution) - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
Set the parameters for range partition.
setRangePartitioned(Ordering) - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
 
setRangePartitioned(Ordering, DataDistribution) - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
 
setReadPosition(long) - Method in interface org.apache.flink.core.memory.SeekableDataInputView
Sets the read pointer to the given position.
setReadPosition(long) - Method in class org.apache.flink.runtime.io.disk.RandomAccessInputView
 
setReadPosition(long) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
 
setRecordCount(long) - Method in class org.apache.flink.api.common.io.BlockInfo
Sets the recordCount to the specified value.
setReduceOnSourceId(boolean) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeTargetDegree
The degree can be counted from either the edge source or target IDs.
setReduceOnTargetId(boolean) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeDegreePair
The degree can be counted from either the edge source or target IDs.
setReduceOnTargetId(boolean) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.EdgeSourceDegree
The degree can be counted from either the edge source or target IDs.
setReduceOnTargetId(boolean) - Method in class org.apache.flink.graph.asm.degree.annotate.undirected.VertexDegree
The degree can be counted from either the edge source or target IDs.
setReduceOnTargetId(boolean) - Method in class org.apache.flink.graph.asm.degree.filter.undirected.MaximumDegree
The degree can be counted from either the edge source or target IDs.
setReduceOnTargetId(boolean) - Method in class org.apache.flink.graph.library.metric.undirected.EdgeMetrics
The degree can be counted from either the edge source or target IDs.
setReduceOnTargetId(boolean) - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics
The degree can be counted from either the edge source or target IDs.
setReference(T) - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
setReference(T) - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
setReference(BooleanValue) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
setReference(ByteValue) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
setReference(CharValue) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
setReference(DoubleValue) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
setReference(FloatValue) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
setReference(IntValue) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
setReference(LongValue) - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
setReference(NullValue) - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
setReference(ShortValue) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
setReference(StringValue) - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
setReference(T1) - Method in class org.apache.flink.api.common.typeutils.GenericPairComparator
 
setReference(T) - Method in class org.apache.flink.api.common.typeutils.SameTypePairComparator
 
setReference(T) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Sets the given element as the comparison reference for future calls to TypeComparator.equalToReference(Object) and TypeComparator.compareToReference(TypeComparator).
setReference(T1) - Method in class org.apache.flink.api.common.typeutils.TypePairComparator
Sets the reference for comparisons.
setReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
setReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
setReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
setReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
setReference(Row) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
 
setReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparator
 
setReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
setReference(T) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
 
setReference(T) - Method in class org.apache.flink.api.scala.typeutils.CaseClassComparator
 
setReference(Enumeration.Value) - Method in class org.apache.flink.api.scala.typeutils.EnumValueComparator
 
setReference(Option<A>) - Method in class org.apache.flink.api.scala.typeutils.OptionTypeComparator
 
setReference(IntValueArray) - Method in class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
 
setReference(LongValueArray) - Method in class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
 
setReference(NullValueArray) - Method in class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
 
setReference(StringValueArray) - Method in class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
 
setReference(CRow) - Method in class org.apache.flink.table.runtime.types.CRowComparator
 
setRegion(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Attributes
 
setRegularization(double) - Method in class org.apache.flink.ml.classification.SVM
Sets the regularization constant
setRegularizationConstant(double) - Static method in class org.apache.flink.ml.optimization.GradientDescent
 
setRegularizationConstant(double) - Static method in class org.apache.flink.ml.optimization.IterativeSolver
 
setRegularizationConstant(double) - Method in class org.apache.flink.ml.optimization.Solver
 
setRegularizationPenalty(RegularizationPenalty) - Static method in class org.apache.flink.ml.optimization.GradientDescent
 
setRegularizationPenalty(RegularizationPenalty) - Static method in class org.apache.flink.ml.optimization.IterativeSolver
 
setRegularizationPenalty(RegularizationPenalty) - Method in class org.apache.flink.ml.optimization.Solver
 
setRelativeBackChannelMemory(double) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setRelativeInputMaterializationMemory(int, double) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setRelativeMemoryDriver(double) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setRelativeMemoryInput(int, double) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setRelativeMemoryLocalStrategy(double) - Method in class org.apache.flink.optimizer.plan.Channel
 
setRelativeMemoryPerSubtask(double) - Method in class org.apache.flink.optimizer.plan.PlanNode
Sets the memory dedicated to each task for this node.
setRelativeSolutionSetMemory(double) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setRelativeTempMemory(double) - Method in class org.apache.flink.optimizer.plan.Channel
Sets the memory for materializing the channel's result from this Channel.
setReplicationFactor(int) - Method in class org.apache.flink.optimizer.plan.Channel
Sets the replication factor of the connection.
setRequestedChannelMax(int) - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
Set the requested maximum channel number
setRequestedFrameMax(int) - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
Set the requested maximum frame size
setRequestedHeartbeat(int) - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
Set the requested heartbeat.
setRequestFuture(CompletableFuture<Acknowledge>) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.PendingSlotRequest
 
setRequiredGlobalProps(RequestedGlobalProperties) - Method in class org.apache.flink.optimizer.plan.Channel
 
setRequiredLocalProps(RequestedLocalProperties) - Method in class org.apache.flink.optimizer.plan.Channel
 
setResize(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Size
 
setResources(ResourceSpec, ResourceSpec) - Method in class org.apache.flink.api.common.operators.Operator
Sets the minimum and preferred resources for this contract instance.
setResources(ResourceSpec, ResourceSpec) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
Sets the minimum and preferred resources for the task.
setResources(int, ResourceSpec, ResourceSpec) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
setResources(ResourceSpec, ResourceSpec) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
setResources(ResourceSpec, ResourceSpec) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
Sets the minimum and preferred resources for this stream transformation.
setRestartStrategy(RestartStrategies.RestartStrategyConfiguration) - Method in class org.apache.flink.api.common.ExecutionConfig
Sets the restart strategy to be used for recovery.
setRestartStrategy(RestartStrategies.RestartStrategyConfiguration) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Sets the restart strategy configuration.
setRestartStrategy(RestartStrategies.RestartStrategyConfiguration) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Sets the restart strategy configuration.
setRestartStrategy(RestartStrategies.RestartStrategyConfiguration) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Sets the restart strategy configuration.
setRestartStrategy(RestartStrategies.RestartStrategyConfiguration) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Sets the restart strategy configuration.
setResult(VV) - Method in class org.apache.flink.graph.gsa.ApplyFunction
Sets the result for the apply function
setResultIterator(MutableObjectIterator<E>) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
Sets the result iterator.
setResultIteratorException(IOException) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
Reports an exception to all threads that are waiting for the result iterator.
setResultOptimizerProperties(String) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
setResultSetConcurrency(int) - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat.JDBCInputFormatBuilder
 
setResultSetType(int) - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat.JDBCInputFormatBuilder
 
setRetweet_count(long) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
setRetweeted(boolean) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
setRetweeted_status(Tweet) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
setReuseAvroValue(boolean) - Method in class org.apache.flink.api.java.io.AvroInputFormat
Sets the flag whether to reuse the Avro value instance for all records.
setRevenue(Double) - Method in class org.apache.flink.examples.java.relational.TPCHQuery3.ShippingPriorityItem
 
setRoot(RelNode, boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
Sets a new root relational expression, as the translation process backs its way further up the tree.
setRowTypeInfo(RowTypeInfo) - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat.JDBCInputFormatBuilder
 
setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.api.common.functions.AbstractRichFunction
 
setRuntimeContext(RuntimeContext) - Method in interface org.apache.flink.api.common.functions.RichFunction
Sets the function's runtime context.
setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.api.common.io.ReplicatingInputFormat
 
setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.api.common.io.RichInputFormat
 
setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.api.common.io.RichOutputFormat
 
setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.api.java.operators.translation.WrappingFunction
 
setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.async.RichAsyncFunction
 
setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.sink.OutputFormatSinkFunction
 
setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessAllWindowFunction
Deprecated.
 
setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.windowing.FoldApplyProcessWindowFunction
Deprecated.
 
setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessAllWindowFunction
 
setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.functions.windowing.ReduceApplyProcessWindowFunction
 
setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.scala.function.util.ScalaProcessAllWindowFunctionWrapper
 
setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.api.scala.function.util.ScalaProcessWindowFunctionWrapper
 
setRuntimeContext(RuntimeContext) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
This method is used for approach (a) (see above)
setSafetyNetCloseableRegistryForThread(SafetyNetCloseableRegistry) - Static method in class org.apache.flink.core.fs.FileSystemSafetyNet
Sets the active safety-net registry for the current thread.
setSavepointRestoreSettings(SavepointRestoreSettings) - Method in class org.apache.flink.client.program.PackagedProgram
 
setSavepointRestoreSettings(SavepointRestoreSettings) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Sets the savepoint restore settings.
setScheduleMode(ScheduleMode) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
setScheduleMode(ScheduleMode) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
 
setSchema(Schema) - Method in class org.apache.flink.api.java.io.AvroOutputFormat
 
setScreen_name(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.UserMention
 
setScreen_name(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setScreenName(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Contributors
 
setSecondDegree(Integer) - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.EdgeWithDegrees
 
setSecondDegree(Integer) - Method in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
 
setSecondInput(Operator<IN2>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
Clears all previous connections and connects the second input to the task wrapped in this contract
setSecondInput(Operator<IN2>...) - Method in class org.apache.flink.api.common.operators.DualInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
setSecondInputs(List<Operator<IN2>>) - Method in class org.apache.flink.api.common.operators.DualInputOperator
Deprecated.
This method will be removed in future versions. Use the Union operator instead.
setSecondVertex(Integer) - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Edge
 
setSecondVertex(Integer) - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.EdgeWithDegrees
 
setSecondVertex(Integer) - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Triad
 
setSecondVertex(K) - Method in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
 
setSecondVertex(K) - Method in class org.apache.flink.graph.library.TriangleEnumerator.Triad
 
setSeed(long) - Method in class org.apache.flink.ml.classification.SVM
Sets the seed value for the random number generator
setSeed(long) - Method in class org.apache.flink.ml.recommendation.ALS
Sets the random seed for the initial item matrix initialization
setSemanticProperties(DualInputSemanticProperties) - Method in class org.apache.flink.api.common.operators.DualInputOperator
 
setSemanticProperties(SingleInputSemanticProperties) - Method in class org.apache.flink.api.common.operators.SingleInputOperator
 
setSemanticProperties(SingleInputSemanticProperties) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
Sets the semantic properties for the user-defined function (UDF).
setSemanticProperties(DualInputSemanticProperties) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
Sets the semantic properties for the user-defined function (UDF).
setSentence(String) - Method in class org.apache.flink.storm.wordcount.operators.WordCountDataPojos.Sentence
 
setSerializer(TypeSerializer<T>) - Method in class org.apache.flink.api.java.io.TypeSerializerOutputFormat
 
setSerializer(TypeSerializerFactory<?>) - Method in class org.apache.flink.optimizer.plan.Channel
Sets the serializer for this Channel.
setSerializer(TypeSerializerFactory<?>) - Method in class org.apache.flink.optimizer.plan.SourcePlanNode
Sets the serializer for this PlanNode.
setSerializerForIterationChannel(TypeSerializerFactory<?>) - Method in class org.apache.flink.optimizer.plan.BulkIterationPlanNode
 
setSerializerForIterationChannel(TypeSerializerFactory<?>) - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
 
setSerializerIn1(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
setSerializerIn2(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
setSerializerOut(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
setSerializers(Integer, TypeSerializer<?>, TypeSerializer<?>, TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
setSerializersFrom(Integer, Integer) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
setSessionTimeout(long) - Method in class org.apache.flink.api.common.Plan
 
setSessionTimeout(long) - Method in class org.apache.flink.api.java.ExecutionEnvironment
Sets the session timeout to hold the intermediate results of a job.
setSessionTimeout(long) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Sets the session timeout to hold the intermediate results of a job.
setSessionTimeout(long) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Sets the timeout of the session in seconds.
setSharedSlot(SharedSlot) - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
Assigns a new shared slot to this co-location constraint.
setShipStrategy(ShipStrategyType) - Method in class org.apache.flink.optimizer.dag.DagConnection
Sets the shipping strategy for this connection.
setShipStrategy(ShipStrategyType, DataExchangeMode) - Method in class org.apache.flink.optimizer.plan.Channel
 
setShipStrategy(ShipStrategyType, FieldList, DataExchangeMode) - Method in class org.apache.flink.optimizer.plan.Channel
 
setShipStrategy(ShipStrategyType, FieldList, boolean[], DataExchangeMode) - Method in class org.apache.flink.optimizer.plan.Channel
 
setShipStrategy(ShipStrategyType, FieldList, Partitioner<?>, DataExchangeMode) - Method in class org.apache.flink.optimizer.plan.Channel
 
setShipStrategy(ShipStrategyType, FieldList, boolean[], Partitioner<?>, DataExchangeMode) - Method in class org.apache.flink.optimizer.plan.Channel
 
setShipStrategyComparator(TypeComparatorFactory<?>) - Method in class org.apache.flink.optimizer.plan.Channel
Sets the ship strategy comparator for this Channel.
setShipStrategyName(String) - Method in class org.apache.flink.runtime.jobgraph.JobEdge
Sets the name of the ship strategy for the represented input.
setSize(int) - Method in class org.apache.flink.runtime.io.network.buffer.Buffer
 
setSizeHint(CrossOperatorBase.CrossHint) - Method in class org.apache.flink.ml.nn.KNN
Parameter a user can specify if one of the training or test sets are small
setSizes(Map<String, Size>) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Media
 
setSkipFirstLineAsHeader(boolean) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
setSkipInvalidLines(boolean) - Method in class org.apache.flink.api.java.io.TextValueInputFormat
 
setSlotAvailabilityListener(SlotAvailabilityListener) - Method in class org.apache.flink.runtime.instance.Instance
Sets the listener that receives notifications for slot availability.
setSlotSharingGroup(SlotSharingGroup) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
Associates this vertex with a slot sharing group for scheduling.
setSlotSharingGroup(String) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
setSlotSharingGroup(String) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
Sets the slot sharing group of this transformation.
setSnapshotSettings(JobCheckpointingSettings) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Sets the settings for asynchronous snapshots.
setSolutionSetComparator(TypeComparatorFactory<?>) - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
 
setSolutionSetComparator(TypeComparatorFactory<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setSolutionSetDelta(Operator<ST>) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
Sets the contract of the step function that represents the solution set delta.
setSolutionSetSerializer(TypeSerializerFactory<?>) - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
 
setSolutionSetSerializer(TypeSerializerFactory<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setSolutionSetUnManaged(boolean) - Method in class org.apache.flink.api.common.operators.base.DeltaIterationBase
Sets whether to keep the solution set in managed memory (safe against heap exhaustion) or unmanaged memory (objects on heap).
setSolutionSetUnManaged(boolean) - Method in class org.apache.flink.api.java.operators.DeltaIteration
Sets whether to keep the solution set in managed memory (safe against heap exhaustion) or unmanaged memory (objects on heap).
setSolutionSetUnmanaged(boolean) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setSolutionSetUnmanagedMemory(boolean) - Method in class org.apache.flink.graph.IterationConfiguration
Defines whether the solution set is kept in managed memory (Flink's internal way of keeping object in serialized form) or as a simple object map.
setSortTriangleVertices(boolean) - Method in class org.apache.flink.graph.library.clustering.directed.TriangleListing
Normalize the triangle listing such that for each result (K0, K1, K2) the vertex IDs are sorted K0 < K1 < K2.
setSortTriangleVertices(boolean) - Method in class org.apache.flink.graph.library.clustering.undirected.TriangleListing
Normalize the triangle listing such that for each result (K0, K1, K2) the vertex IDs are sorted K0 < K1 < K2.
setSource(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
setSource(K) - Method in class org.apache.flink.graph.Edge
 
setSource(PlanNode) - Method in class org.apache.flink.optimizer.plan.Channel
 
setSource(Path) - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
setSpillingThresholdDriver(float) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setSpillingThresholdInput(int, float) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setSplitDataProperties(GenericDataSourceBase.SplitDataProperties<OUT>) - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
Sets properties of input splits for this data source.
setSplitState(Serializable) - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
Sets the state of the split.
setSqlTypes(int[]) - Method in class org.apache.flink.api.java.io.jdbc.JDBCOutputFormat.JDBCOutputFormatBuilder
 
setSSLVerAndCipherSuites(SSLEngine) - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
setSSLVerAndCipherSuites(ServerSocket, Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
Sets SSl version and cipher suites for SSLServerSocket
setSSLVerAndCipherSuites(SSLEngine, Configuration) - Static method in class org.apache.flink.runtime.net.SSLUtils
Sets SSL version and cipher suites for SSLEngine
setSSLVerifyHostname(SSLParameters) - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
setSSLVerifyHostname(Configuration, SSLParameters) - Static method in class org.apache.flink.runtime.net.SSLUtils
Sets SSL options to verify peer's hostname in the certificate
setStackTrace(StackTraceElement[]) - Static method in exception org.apache.flink.table.api.AmbiguousTableSourceConverterException
 
setStackTrace(StackTraceElement[]) - Static method in exception org.apache.flink.table.api.CatalogAlreadyExistException
 
setStackTrace(StackTraceElement[]) - Static method in exception org.apache.flink.table.api.CatalogNotExistException
 
setStackTrace(StackTraceElement[]) - Static method in exception org.apache.flink.table.api.ExpressionParserException
 
setStackTrace(StackTraceElement[]) - Static method in exception org.apache.flink.table.api.ExternalCatalogAlreadyExistException
 
setStackTrace(StackTraceElement[]) - Static method in exception org.apache.flink.table.api.ExternalCatalogNotExistException
 
setStackTrace(StackTraceElement[]) - Static method in exception org.apache.flink.table.api.NoMatchedTableSourceConverterException
 
setStackTrace(StackTraceElement[]) - Static method in exception org.apache.flink.table.api.SqlParserException
 
setStackTrace(StackTraceElement[]) - Static method in exception org.apache.flink.table.api.TableAlreadyExistException
 
setStackTrace(StackTraceElement[]) - Static method in exception org.apache.flink.table.api.TableException
 
setStackTrace(StackTraceElement[]) - Static method in exception org.apache.flink.table.api.TableNotExistException
 
setStackTrace(StackTraceElement[]) - Static method in exception org.apache.flink.table.api.UnresolvedException
 
setStackTrace(StackTraceElement[]) - Static method in exception org.apache.flink.table.api.ValidationException
 
setStartFromEarliest() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
Specifies the consumer to start reading from the earliest offset for all partitions.
setStartFromGroupOffsets() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
Specifies the consumer to start reading from any committed group offsets found in Zookeeper / Kafka brokers.
setStartFromLatest() - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
Specifies the consumer to start reading from the latest offset for all partitions.
setStartFromSpecificOffsets(Map<KafkaTopicPartition, Long>) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
Specifies the consumer to start reading partitions from specific offsets, set independently for each partition.
setState(int) - Method in class org.apache.flink.api.java.sca.UdfAnalyzer
 
setStateBackend(AbstractStateBackend) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Sets the state backend that describes how to store and checkpoint operator state.
setStateBackend(AbstractStateBackend) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setStateBackend(AbstractStateBackend) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
setStateBackend(AbstractStateBackend) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Sets the state backend that describes how to store and checkpoint operator state.
setStateKeySelector(KeySelector<IN, ?>) - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
Sets the KeySelector that must be used for partitioning keyed state of this operation.
setStateKeySelector(KeySelector<T, ?>) - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
Sets the KeySelector that must be used for partitioning keyed state of this Sink.
setStateKeySelectors(KeySelector<IN1, ?>, KeySelector<IN2, ?>) - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
Sets the KeySelectors that must be used for partitioning keyed state of this transformation.
setStateKeySerializer(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setStateKeySerializer(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
setStateKeyType(TypeInformation<?>) - Method in class org.apache.flink.streaming.api.transformations.OneInputTransformation
 
setStateKeyType(TypeInformation<?>) - Method in class org.apache.flink.streaming.api.transformations.SinkTransformation
 
setStateKeyType(TypeInformation<?>) - Method in class org.apache.flink.streaming.api.transformations.TwoInputTransformation
 
setStatePartitioner(int, KeySelector<?, ?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setStatePartitioner1(KeySelector<?, ?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
setStatePartitioner2(KeySelector<?, ?>) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
setStateTimeout(S, Option<FiniteDuration>) - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
setStateTimeout(S, Option<FiniteDuration>) - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
setStateTimeout(S, Option<FiniteDuration>) - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
setStateTimeout(S, Option<FiniteDuration>) - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
setStatisticsKey(String) - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
Sets the key under which statistics about this data source may be obtained from the statistics cache.
setStatus(String) - Method in class org.apache.flink.api.java.hadoop.mapred.wrapper.HadoopDummyReporter
 
setStatuses_count(long) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setStd(double) - Method in class org.apache.flink.ml.preprocessing.StandardScaler
Sets the target standard deviation of the transformed data
setStepsize(double) - Method in class org.apache.flink.ml.classification.SVM
Sets the stepsize for the weight vector updates
setStepsize(double) - Static method in class org.apache.flink.ml.optimization.GradientDescent
 
setStepsize(double) - Method in class org.apache.flink.ml.optimization.IterativeSolver
 
setStepsize(double) - Method in class org.apache.flink.ml.regression.MultipleLinearRegression
 
setStormTopology(StormTopology) - Method in class org.apache.flink.storm.wrappers.BoltWrapper
Sets the original Storm topology.
setStormTopology(StormTopology) - Method in class org.apache.flink.storm.wrappers.SpoutWrapper
Sets the original Storm topology.
setStreamOperator(StreamOperator<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setStreamTimeCharacteristic(TimeCharacteristic) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Sets the time characteristic for all streams create from this environment, e.g., processing time, event time, or ingestion time.
setStreamTimeCharacteristic(TimeCharacteristic) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Sets the time characteristic for all streams create from this environment, e.g., processing time, event time, or ingestion time.
setStreet_address(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Attributes
 
setStrictlyCoLocatedWith(JobVertex) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
Tells this vertex to strictly co locate its subtasks with the subtasks of the given vertex.
setString(String, String) - Method in class org.apache.flink.configuration.Configuration
Adds the given key/value pair to the configuration object.
setString(ConfigOption<String>, String) - Method in class org.apache.flink.configuration.Configuration
Adds the given value to the configuration object.
setString(String, String) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
setString(ConfigOption<String>, String) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
setStringToTokenize(StringValue) - Method in class org.apache.flink.util.StringValueUtils.WhitespaceTokenizer
Sets the string to be tokenized and resets the state of the tokenizer.
setStubParameter(String, String) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setStubParameters(Configuration) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setStubWrapper(UserCodeWrapper<?>) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setSubQueryConverter(SubQueryConverter) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Sets a new SubQueryConverter.
setSymbols(List<Symbol>) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Entities
 
setSyncDurationMillis(long) - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
setTag(TaggedValue.Tag) - Method in class org.apache.flink.api.java.sca.TaggedValue
 
setTarget(K) - Method in class org.apache.flink.graph.Edge
 
setTarget(PlanNode) - Method in class org.apache.flink.optimizer.plan.Channel
Sets the target of this Channel.
setTargetToStandardErr() - Method in class org.apache.flink.api.java.io.PrintingOutputFormat
 
setTargetToStandardErr() - Method in class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
 
setTargetToStandardOut() - Method in class org.apache.flink.api.java.io.PrintingOutputFormat
 
setTargetToStandardOut() - Method in class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
 
setTaskCancellationInterval(long) - Method in class org.apache.flink.api.common.ExecutionConfig
Sets the configuration parameter specifying the interval (in milliseconds) between consecutive attempts to cancel a running task.
setTaskCancellationTimeout(long) - Method in class org.apache.flink.api.common.ExecutionConfig
Sets the timeout (in milliseconds) after which an ongoing task cancellation is considered failed, leading to a fatal TaskManager error.
setTaskManagerCount(int) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
 
setTaskManagerMemory(int) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
 
setTaskManagerNumSlots(int) - Method in class org.apache.flink.client.LocalExecutor
 
setTaskManagerNumSlots(int) - Method in class org.apache.flink.test.util.AbstractTestBase
 
setTaskManagerSlots(int) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
 
setTaskName(String) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setTempMode(TempMode) - Method in class org.apache.flink.optimizer.plan.Channel
Sets the temp mode of the connection.
setTemporaryPath(String) - Method in class org.apache.flink.ml.recommendation.ALS
Sets the temporary path into which intermediate results are written in order to increase performance.
setter() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.FieldDescriptor
 
setTerminationCriterion(Operator<X>) - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
 
setText(String, boolean) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.HashTags
 
setText(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Symbol
 
setText(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
setTheta0(double) - Method in class org.apache.flink.examples.java.ml.LinearRegression.Params
 
setTheta1(double) - Method in class org.apache.flink.examples.java.ml.LinearRegression.Params
 
setThirdVertex(Integer) - Method in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Triad
 
setThirdVertex(K) - Method in class org.apache.flink.graph.library.TriangleEnumerator.Triad
 
setThreshold(double) - Method in class org.apache.flink.ml.classification.SVM
Sets the threshold above which elements are classified as positive.
setTime_zone(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setTimeCharacteristic(TimeCharacteristic) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setTimer(String, Object, FiniteDuration, boolean) - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
setTimer(String, Object, FiniteDuration, boolean) - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
setTimer(String, Object, FiniteDuration, boolean) - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
setTimer(String, Object, FiniteDuration, boolean) - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
setTimer$default$4() - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
setTimer$default$4() - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
setTimer$default$4() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
setTimer$default$4() - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
setTimestamp(StreamRecord<?>) - Method in class org.apache.flink.streaming.api.operators.TimestampedCollector
 
setTimestamp(long) - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
 
setTimeZone(TimeZone) - Method in class org.apache.flink.table.api.TableConfig
Sets the timezone for date/time/timestamp conversions.
setTokensFor(ContainerLaunchContext, List<Path>, Configuration) - Static method in class org.apache.flink.yarn.Utils
 
setTopId(KT) - Method in class org.apache.flink.graph.bipartite.BipartiteEdge
 
setTopologyRecoveryEnabled(boolean) - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
Enables or disables topology recovery
setTransitiveChainedTaskConfigs(Map<Integer, StreamConfig>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setTruncated(boolean) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
setTweetLevel(int) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
setTwoInputStateKey(Integer, KeySelector<?, ?>, KeySelector<?, ?>, TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamGraph
 
setType(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.places.BoundingBox
 
setType(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Media
 
setTypeSerializerIn1(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setTypeSerializerIn2(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setTypeSerializerOut(TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setTypeSerializerSideOut(OutputTag<?>, TypeSerializer<?>) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setUdfConfiguration(Configuration) - Method in class org.apache.flink.runtime.operators.sort.CombiningUnilateralSortMerger
 
setUid(String) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
Sets an ID for this StreamTransformation.
setUidHash(String) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
Sets an user provided hash for this operator.
setUidHash(String) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Sets an user provided hash for this operator.
setUidHash(String) - Method in class org.apache.flink.streaming.api.scala.DataStream
Sets an user provided hash for this operator.
setUidHash(String) - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
Sets an user provided hash for this operator.
setUidHash(String) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink
Sets an user provided hash for this operator.
setUidHash(String) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010.FlinkKafkaProducer010Configuration
 
setUnsplittable(boolean) - Method in class org.apache.flink.api.java.io.AvroInputFormat
If set, the InputFormat will only read entire files.
setup() - Method in class org.apache.flink.runtime.iterative.concurrent.SolutionSetUpdateBarrier
 
setup() - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepBarrier
setup the barrier, has to be called at the beginning of each superstep
setup(TaskContext<FlatJoinFunction<IT1, IT2, OT>, OT>) - Method in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
setup(TaskContext<GroupCombineFunction<IN, OUT>, OUT>) - Method in class org.apache.flink.runtime.operators.AllGroupCombineDriver
 
setup(TaskContext<GroupReduceFunction<IT, OT>, OT>) - Method in class org.apache.flink.runtime.operators.AllGroupReduceDriver
 
setup(TaskContext<ReduceFunction<T>, T>) - Method in class org.apache.flink.runtime.operators.AllReduceDriver
 
setup(AbstractInvokable) - Method in class org.apache.flink.runtime.operators.chaining.ChainedAllReduceDriver
 
setup(TaskConfig, String, Collector<OT>, AbstractInvokable, ClassLoader, ExecutionConfig, Map<String, Accumulator<?, ?>>) - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
setup(AbstractInvokable) - Method in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
setup(AbstractInvokable) - Method in class org.apache.flink.runtime.operators.chaining.ChainedFlatMapDriver
 
setup(AbstractInvokable) - Method in class org.apache.flink.runtime.operators.chaining.ChainedMapDriver
 
setup(AbstractInvokable) - Method in class org.apache.flink.runtime.operators.chaining.ChainedReduceCombineDriver
 
setup(AbstractInvokable) - Method in class org.apache.flink.runtime.operators.chaining.ChainedTerminationCriterionDriver
 
setup(AbstractInvokable) - Method in class org.apache.flink.runtime.operators.chaining.GroupCombineChainedDriver
 
setup(AbstractInvokable) - Method in class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
 
setup(TaskContext<CoGroupFunction<IT1, IT2, OT>, OT>) - Method in class org.apache.flink.runtime.operators.CoGroupDriver
 
setup(TaskContext<CoGroupFunction<IT1, IT2, OT>, OT>) - Method in class org.apache.flink.runtime.operators.CoGroupRawDriver
 
setup(TaskContext<CoGroupFunction<IT1, IT2, OT>, OT>) - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
 
setup(TaskContext<CoGroupFunction<IT1, IT2, OT>, OT>) - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
 
setup(TaskContext<CrossFunction<T1, T2, OT>, OT>) - Method in class org.apache.flink.runtime.operators.CrossDriver
 
setup(TaskContext<S, OT>) - Method in interface org.apache.flink.runtime.operators.Driver
 
setup(TaskContext<FlatMapFunction<IT, OT>, OT>) - Method in class org.apache.flink.runtime.operators.FlatMapDriver
 
setup(TaskContext<GroupCombineFunction<IN, OUT>, OUT>) - Method in class org.apache.flink.runtime.operators.GroupReduceCombineDriver
 
setup(TaskContext<GroupReduceFunction<IT, OT>, OT>) - Method in class org.apache.flink.runtime.operators.GroupReduceDriver
 
setup(TaskContext<FlatJoinFunction<IT1, IT2, OT>, OT>) - Method in class org.apache.flink.runtime.operators.JoinDriver
 
setup(TaskContext<FlatJoinFunction<IT1, IT2, OT>, OT>) - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
 
setup(TaskContext<FlatJoinFunction<IT1, IT2, OT>, OT>) - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
 
setup(TaskContext<MapFunction<IT, OT>, OT>) - Method in class org.apache.flink.runtime.operators.MapDriver
 
setup(TaskContext<MapPartitionFunction<IT, OT>, OT>) - Method in class org.apache.flink.runtime.operators.MapPartitionDriver
 
setup(AbstractInvokable) - Method in class org.apache.flink.runtime.operators.NoOpChainedDriver
 
setup(TaskContext<AbstractRichFunction, T>) - Method in class org.apache.flink.runtime.operators.NoOpDriver
 
setup(TaskContext<ReduceFunction<T>, T>) - Method in class org.apache.flink.runtime.operators.ReduceCombineDriver
 
setup(TaskContext<ReduceFunction<T>, T>) - Method in class org.apache.flink.runtime.operators.ReduceDriver
 
setup(TaskContext<Function, T>) - Method in class org.apache.flink.runtime.operators.UnionWithTempOperator
 
setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
setup(StreamTask<?, ?>, StreamConfig, Output<StreamRecord<OUT>>) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
Initializes the operator.
setup() - Static method in class org.apache.flink.streaming.util.StreamingMultipleProgramsTestBase
 
setup() - Static method in class org.apache.flink.test.util.MultipleProgramsTestBase
 
setupApplicationMasterContainer(boolean, boolean, boolean) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
 
setupConnectionFactory() - Method in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
Initializes the connection to RMQ with a default connection factory.
setUpdatesAsRetraction(RelNode) - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamRetractionRules.SetUpdatesAsRetractionRule
Annotates a RelNode to send out update changes with retraction messages.
SetUpdatesAsRetractionRule() - Constructor for class org.apache.flink.table.plan.rules.datastream.DataStreamRetractionRules.SetUpdatesAsRetractionRule
 
setupEnvironment() - Method in class org.apache.flink.test.util.MultipleProgramsTestBase
 
setupLocalResource(FileSystem, String, Path, LocalResource, Path) - Static method in class org.apache.flink.yarn.Utils
 
setupQueue() - Method in class org.apache.flink.streaming.connectors.rabbitmq.RMQSink
Sets up the queue.
setupQueue() - Method in class org.apache.flink.streaming.connectors.rabbitmq.RMQSource
Sets up the queue.
setupYarnClassPath(Configuration, Map<String, String>) - Static method in class org.apache.flink.yarn.Utils
 
setUri(String) - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
Convenience method for setting the fields in an AMQP URI: host, port, username, password and virtual host.
setUrl(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Attributes
 
setUrl(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.places.Places
 
setUrl(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Media
 
setUrl(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.URL
 
setUrl(String) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setUrls(List<URL>) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Entities
 
setUseLargeRecordHandler(boolean) - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setUseQuadTree(boolean) - Method in class org.apache.flink.ml.nn.KNN
Sets the Boolean variable that decides whether to use the QuadTree or not
setUser(Users) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
setUser_mentions(List<UserMention>) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Entities
 
setUserCodeClassLoader(ClassLoader) - Method in class org.apache.flink.api.common.typeutils.TypeSerializerConfigSnapshot
Set the user code class loader.
setUserHash(String) - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
setUsername(String) - Method in class org.apache.flink.api.java.io.jdbc.JDBCInputFormat.JDBCInputFormatBuilder
 
setUsername(String) - Method in class org.apache.flink.api.java.io.jdbc.JDBCOutputFormat.JDBCOutputFormatBuilder
 
setUserName(String) - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
Set the user name.
setUseRpcServicePerComponent() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
setUseSingleRpcService() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
setUtc_offset(long) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setValidLengthPrefix(String) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
Sets the prefix of valid-length files.
setValidLengthPrefix(String) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
Deprecated.
Sets the prefix of valid-length files.
setValidLengthSuffix(String) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
Sets the suffix of valid-length files.
setValidLengthSuffix(String) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
Deprecated.
Sets the suffix of valid-length files.
setValue(EV) - Method in class org.apache.flink.graph.bipartite.BipartiteEdge
 
setValue(V) - Method in class org.apache.flink.graph.Edge
 
setValue(ValueArray<IntValue>) - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
 
setValue(ValueArray<LongValue>) - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
 
setValue(ValueArray<NullValue>) - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
 
setValue(ValueArray<StringValue>) - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
 
setValue(V) - Method in class org.apache.flink.graph.Vertex
 
setValue(byte[]) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedValue
 
setValue(V) - Method in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter.AvroKeyValue
 
setValue(boolean) - Method in class org.apache.flink.types.BooleanValue
 
setValue(BooleanValue) - Method in class org.apache.flink.types.BooleanValue
 
setValue(byte) - Method in class org.apache.flink.types.ByteValue
Sets the encapsulated byte to the specified value.
setValue(ByteValue) - Method in class org.apache.flink.types.ByteValue
 
setValue(char) - Method in class org.apache.flink.types.CharValue
Sets the encapsulated char to the specified value.
setValue(CharValue) - Method in class org.apache.flink.types.CharValue
 
setValue(double) - Method in class org.apache.flink.types.DoubleValue
Sets the value of the encapsulated primitive double.
setValue(DoubleValue) - Method in class org.apache.flink.types.DoubleValue
 
setValue(L) - Method in class org.apache.flink.types.Either.Left
Sets the encapsulated value to another value
setValue(R) - Method in class org.apache.flink.types.Either.Right
Sets the encapsulated value to another value
setValue(float) - Method in class org.apache.flink.types.FloatValue
Sets the value of the encapsulated primitive float.
setValue(FloatValue) - Method in class org.apache.flink.types.FloatValue
 
setValue(int) - Method in class org.apache.flink.types.IntValue
Sets the encapsulated int to the specified value.
setValue(IntValue) - Method in class org.apache.flink.types.IntValue
 
setValue(long) - Method in class org.apache.flink.types.LongValue
Sets the value of the encapsulated long to the specified value.
setValue(LongValue) - Method in class org.apache.flink.types.LongValue
 
setValue(T) - Method in interface org.apache.flink.types.ResettableValue
Sets the encapsulated value to another value
setValue(short) - Method in class org.apache.flink.types.ShortValue
Sets the encapsulated short to the specified value.
setValue(ShortValue) - Method in class org.apache.flink.types.ShortValue
 
setValue(CharSequence) - Method in class org.apache.flink.types.StringValue
Sets the value of the StringValue to the given string.
setValue(StringValue) - Method in class org.apache.flink.types.StringValue
Sets the value of the StringValue to the given string.
setValue(StringValue, int, int) - Method in class org.apache.flink.types.StringValue
Sets the value of the StringValue to a substring of the given string.
setValue(CharSequence, int, int) - Method in class org.apache.flink.types.StringValue
Sets the value of the StringValue to a substring of the given string.
setValue(CharBuffer) - Method in class org.apache.flink.types.StringValue
Sets the contents of this string to the contents of the given CharBuffer.
setValue(char[], int, int) - Method in class org.apache.flink.types.StringValue
Sets the value of the StringValue to a substring of the given value.
setValueAscii(byte[], int, int) - Method in class org.apache.flink.types.StringValue
Sets the value of this StringValue, assuming that the binary data is ASCII coded.
setVerbose(boolean) - Method in class org.apache.flink.api.java.JarHelper
 
setVerified(boolean) - Method in class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
setVertexGroupCount(Long) - Method in class org.apache.flink.graph.library.Summarization.VertexGroupItem
 
setVertexGroupCount(Long) - Method in class org.apache.flink.graph.library.Summarization.VertexValue
 
setVertexGroupValue(VGV) - Method in class org.apache.flink.graph.library.Summarization.VertexGroupItem
 
setVertexGroupValue(VV) - Method in class org.apache.flink.graph.library.Summarization.VertexValue
 
setVertexId(K) - Method in class org.apache.flink.graph.library.Summarization.VertexGroupItem
 
setVertexId(K) - Method in class org.apache.flink.graph.library.Summarization.VertexWithRepresentative
 
setVertexID(Integer) - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
setVertexId0(T) - Method in interface org.apache.flink.graph.asm.result.BinaryResult
Set the first vertex ID.
setVertexId0(T) - Method in interface org.apache.flink.graph.asm.result.TertiaryResult
Set the first vertex ID.
setVertexId0(T) - Method in interface org.apache.flink.graph.asm.result.UnaryResult
Set the first vertex ID.
setVertexId0(T) - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient.Result
 
setVertexId0(T) - Method in class org.apache.flink.graph.library.clustering.directed.TriangleListing.Result
 
setVertexId0(T) - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient.Result
 
setVertexId0(T) - Method in class org.apache.flink.graph.library.clustering.undirected.TriangleListing.Result
 
setVertexId0(T) - Method in class org.apache.flink.graph.library.link_analysis.HITS.Result
 
setVertexId0(T) - Method in class org.apache.flink.graph.library.link_analysis.PageRank.Result
 
setVertexId0(T) - Method in class org.apache.flink.graph.library.similarity.AdamicAdar.Result
 
setVertexId0(T) - Method in class org.apache.flink.graph.library.similarity.JaccardIndex.Result
 
setVertexId1(T) - Method in interface org.apache.flink.graph.asm.result.BinaryResult
Set the second vertex ID.
setVertexId1(T) - Method in interface org.apache.flink.graph.asm.result.TertiaryResult
Set the second vertex ID.
setVertexId1(T) - Method in class org.apache.flink.graph.library.clustering.directed.TriangleListing.Result
 
setVertexId1(T) - Method in class org.apache.flink.graph.library.clustering.undirected.TriangleListing.Result
 
setVertexId1(T) - Method in class org.apache.flink.graph.library.similarity.AdamicAdar.Result
 
setVertexId1(T) - Method in class org.apache.flink.graph.library.similarity.JaccardIndex.Result
 
setVertexId2(T) - Method in interface org.apache.flink.graph.asm.result.TertiaryResult
Set the third vertex ID.
setVertexId2(T) - Method in class org.apache.flink.graph.library.clustering.directed.TriangleListing.Result
 
setVertexId2(T) - Method in class org.apache.flink.graph.library.clustering.undirected.TriangleListing.Result
 
setVirtualHost(String) - Method in class org.apache.flink.streaming.connectors.rabbitmq.common.RMQConnectionConfig.Builder
Set the virtual host.
setWaitForSolutionSetUpdate() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
setWebUIPort(int) - Method in class org.apache.flink.runtime.jobmanager.JobManagerCliOptions
 
setWidth(long) - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Size
 
setWord(String) - Method in class org.apache.flink.examples.java.wordcount.WordCountPojo.Word
 
setWord(String) - Method in class org.apache.flink.streaming.examples.wordcount.PojoExample.Word
 
SetWorkerPoolSize - Class in org.apache.flink.runtime.clusterframework.messages
Message sent to the resource master actor to adjust the designated number of workers it maintains.
SetWorkerPoolSize(int) - Constructor for class org.apache.flink.runtime.clusterframework.messages.SetWorkerPoolSize
 
setWorksetSerializer(TypeSerializerFactory<?>) - Method in class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
 
setWriteMode(FileSystem.WriteMode) - Method in class org.apache.flink.api.common.io.FileOutputFormat
 
setWritePosition(long) - Method in interface org.apache.flink.core.memory.SeekableDataOutputView
Sets the write pointer to the given position.
setWritePosition(long) - Method in class org.apache.flink.runtime.io.disk.RandomAccessOutputView
 
setWriter(Writer<T>) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
Sets the Writer to be used for writing the incoming elements to bucket files.
setWriter(Writer<T>) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
Deprecated.
Sets the Writer to be used for writing the incoming elements to bucket files.
setWriteTimestampToKafka(boolean) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010.FlinkKafkaProducer010Configuration
If set to true, Flink will write the (event time) timestamp attached to each record into Kafka.
setZookeeperNamespace(String) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
 
SharedBuffer<K extends Serializable,V> - Class in org.apache.flink.cep.nfa
A shared buffer implementation which stores values under a key.
SharedBuffer(TypeSerializer<V>) - Constructor for class org.apache.flink.cep.nfa.SharedBuffer
 
SharedBuffer.SharedBufferEdge<K,V> - Class in org.apache.flink.cep.nfa
Versioned edge between two shared buffer entries.
SharedBuffer.SharedBufferSerializer<K extends Serializable,V> - Class in org.apache.flink.cep.nfa
SharedBuffer.SharedBufferSerializerConfigSnapshot<K,V> - Class in org.apache.flink.cep.nfa
The TypeSerializerConfigSnapshot serializer configuration to be stored with the managed state.
SharedBufferEdge(SharedBuffer.SharedBufferEntry<K, V>, DeweyNumber) - Constructor for class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferEdge
 
SharedBufferSerializer(TypeSerializer<K>, TypeSerializer<V>) - Constructor for class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
 
SharedBufferSerializer(TypeSerializer<K>, TypeSerializer<V>, TypeSerializer<DeweyNumber>) - Constructor for class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
 
SharedBufferSerializerConfigSnapshot() - Constructor for class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializerConfigSnapshot
This empty constructor is required for deserializing the configuration.
SharedBufferSerializerConfigSnapshot(TypeSerializer<K>, TypeSerializer<V>, TypeSerializer<DeweyNumber>) - Constructor for class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializerConfigSnapshot
 
SharedSlot - Class in org.apache.flink.runtime.instance
This class represents a shared slot.
SharedSlot(JobID, SlotOwner, TaskManagerLocation, int, TaskManagerGateway, SlotSharingGroupAssignment) - Constructor for class org.apache.flink.runtime.instance.SharedSlot
Creates a new shared slot that has no parent (is a root slot) and does not belong to any task group.
SharedSlot(JobID, SlotOwner, TaskManagerLocation, int, TaskManagerGateway, SlotSharingGroupAssignment, SharedSlot, AbstractID) - Constructor for class org.apache.flink.runtime.instance.SharedSlot
Creates a new shared slot that has is a sub-slot of the given parent shared slot, and that belongs to the given task group.
SharedSlot(AllocatedSlot, SlotOwner, SlotSharingGroupAssignment) - Constructor for class org.apache.flink.runtime.instance.SharedSlot
Creates a new shared slot that has no parent (is a root slot) and does not belong to any task group.
SharedSlot(SharedSlot, SlotOwner, int, SlotSharingGroupAssignment, AbstractID) - Constructor for class org.apache.flink.runtime.instance.SharedSlot
Creates a new shared slot that is a sub-slot of the given parent shared slot, and that belongs to the given task group.
SharedStateRegistry - Class in org.apache.flink.runtime.state
This registry manages state that is shared across (incremental) checkpoints, and is responsible for deleting shared state that is no longer used in any valid checkpoint.
SharedStateRegistry() - Constructor for class org.apache.flink.runtime.state.SharedStateRegistry
Default uses direct executor to delete unreferenced state
SharedStateRegistry(Executor) - Constructor for class org.apache.flink.runtime.state.SharedStateRegistry
 
SharedStateRegistry.Result - Class in org.apache.flink.runtime.state
The result of an attempt to (un)/reference state
SharedStateRegistryFactory - Interface in org.apache.flink.runtime.state
Simple factory to produce SharedStateRegistry objects.
SharedStateRegistryKey - Class in org.apache.flink.runtime.state
This class represents a key that uniquely identifies (on a logical level) state handles for registration in the SharedStateRegistry.
SharedStateRegistryKey(String, StateHandleID) - Constructor for class org.apache.flink.runtime.state.SharedStateRegistryKey
 
SharedStateRegistryKey(String) - Constructor for class org.apache.flink.runtime.state.SharedStateRegistryKey
 
SHIP_STRATEGY - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
 
shipDate() - Method in class org.apache.flink.examples.scala.relational.TPCHQuery3.Lineitem
 
shipDate() - Method in class org.apache.flink.table.examples.scala.TPCHQuery3Table.Lineitem
 
shipFiles - Variable in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
Lazily initialized list of files to ship
ShippedItem(long, double, String, long) - Constructor for class org.apache.flink.examples.scala.relational.TPCHQuery3.ShippedItem
 
ShippedItem$() - Constructor for class org.apache.flink.examples.scala.relational.TPCHQuery3.ShippedItem$
 
ShippingPriorityItem() - Constructor for class org.apache.flink.examples.java.relational.TPCHQuery3.ShippingPriorityItem
 
ShippingPriorityItem(Long, Double, String, Long) - Constructor for class org.apache.flink.examples.java.relational.TPCHQuery3.ShippingPriorityItem
 
shipPrio() - Method in class org.apache.flink.examples.scala.relational.TPCHQuery3.Order
 
shipPrio() - Method in class org.apache.flink.examples.scala.relational.TPCHQuery3.ShippedItem
 
shipPrio() - Method in class org.apache.flink.table.examples.scala.TPCHQuery3Table.Order
 
ShipStrategyType - Enum in org.apache.flink.runtime.operators.shipping
Enumeration defining the different shipping types of the output, such as local forward, re-partitioning by hash, or re-partitioning by range.
SHORT - Static variable in class org.apache.flink.api.common.typeinfo.Types
 
SHORT() - Method in class org.apache.flink.table.api.Types$
 
SHORT() - Static method in class org.apache.flink.table.api.Types
 
SHORT() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
SHORT() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
short2Literal(short) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionConversions
 
SHORT_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
SHORT_PRIMITIVE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
SHORT_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
SHORT_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
ShortAvgAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Short Avg aggregate function
ShortAvgAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.ShortAvgAggFunction
 
ShortComparator - Class in org.apache.flink.api.common.typeutils.base
 
ShortComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.ShortComparator
 
ShortExplodeTableFunc - Class in org.apache.flink.table.plan.util
 
ShortExplodeTableFunc() - Constructor for class org.apache.flink.table.plan.util.ShortExplodeTableFunc
 
ShortMaxAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Short Max aggregate function
ShortMaxAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.ShortMaxAggFunction
 
ShortMaxWithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Short Max with retraction aggregate function
ShortMaxWithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.ShortMaxWithRetractAggFunction
 
ShortMinAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Short Min aggregate function
ShortMinAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.ShortMinAggFunction
 
ShortMinWithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Short Min with retraction aggregate function
ShortMinWithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.ShortMinWithRetractAggFunction
 
ShortParser - Class in org.apache.flink.types.parser
Parses a decimal text field into a Short.
ShortParser() - Constructor for class org.apache.flink.types.parser.ShortParser
 
ShortPrimitiveArrayComparator - Class in org.apache.flink.api.common.typeutils.base.array
 
ShortPrimitiveArrayComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArrayComparator
 
ShortPrimitiveArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
A serializer for short arrays.
ShortPrimitiveArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.ShortPrimitiveArraySerializer
 
ShortSerializer - Class in org.apache.flink.api.common.typeutils.base
 
ShortSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.ShortSerializer
 
ShortSum0AggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Short Sum0 aggregate function
ShortSum0AggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.ShortSum0AggFunction
 
ShortSum0WithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Short Sum0 with retract aggregate function
ShortSum0WithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.ShortSum0WithRetractAggFunction
 
ShortSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.ShortSumAgg
 
ShortSumAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Short Sum aggregate function
ShortSumAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.ShortSumAggFunction
 
ShortSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
Aggregator that can handle Short types
ShortSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator
 
ShortSummaryAggregator.MaxShortAggregator - Class in org.apache.flink.api.java.summarize.aggregation
 
ShortSummaryAggregator.MinShortAggregator - Class in org.apache.flink.api.java.summarize.aggregation
 
ShortSummaryAggregator.SumShortAggregator - Class in org.apache.flink.api.java.summarize.aggregation
 
ShortSumWithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in Short Sum with retract aggregate function
ShortSumWithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.ShortSumWithRetractAggFunction
 
ShortValue - Class in org.apache.flink.types
Boxed serializable and comparable short integer type, representing the primitive type short.
ShortValue() - Constructor for class org.apache.flink.types.ShortValue
Initializes the encapsulated short with 0.
ShortValue(short) - Constructor for class org.apache.flink.types.ShortValue
Initializes the encapsulated short with the provided value.
ShortValueComparator - Class in org.apache.flink.api.common.typeutils.base
Specialized comparator for ShortValue based on CopyableValueComparator.
ShortValueComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
ShortValueParser - Class in org.apache.flink.types.parser
Parses a decimal text field into a ShortValue.
ShortValueParser() - Constructor for class org.apache.flink.types.parser.ShortValueParser
 
ShortValueSerializer - Class in org.apache.flink.api.common.typeutils.base
 
ShortValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.ShortValueSerializer
 
ShortValueSumAgg() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.ShortValueSumAgg
 
ShortValueSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.ShortValueSummaryAggregator
 
shouldAutocastTo(BasicTypeInfo<?>) - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
Returns whether this type should be automatically casted to the target type in an arithmetic operation.
shouldExitJvmOnOutOfMemoryError() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
shouldExitJvmOnOutOfMemoryError() - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerRuntimeInfo
Checks whether the TaskManager should exit the JVM when the task thread throws an OutOfMemoryError.
shouldIncludeFinished() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
 
shouldIncludeRunning() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
 
shouldRaggedFixedLengthValueUnionBeVariable() - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
shouldStartNewBucket(Path, Path) - Method in interface org.apache.flink.streaming.connectors.fs.Bucketer
Deprecated.
Returns true when a new bucket should be started.
shouldStartNewBucket(Path, Path) - Method in class org.apache.flink.streaming.connectors.fs.DateTimeBucketer
Deprecated.
 
shouldStartNewBucket(Path, Path) - Method in class org.apache.flink.streaming.connectors.fs.NonRollingBucketer
Deprecated.
 
showControlCharacters(String) - Static method in class org.apache.flink.util.StringUtils
Replaces control characters by their escape-coded version.
shuffle() - Method in class org.apache.flink.streaming.api.datastream.DataStream
Sets the partitioning of the DataStream so that the output elements are shuffled uniformly randomly to the next operation.
shuffle() - Method in class org.apache.flink.streaming.api.scala.DataStream
Sets the partitioning of the DataStream so that the output tuples are shuffled to the next component.
ShufflePartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
Partitioner that distributes the data equally by selecting one output channel randomly.
ShufflePartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
 
shutdown() - Method in class org.apache.flink.client.program.ClusterClient.LazyActorSystemLoader
 
shutdown() - Method in class org.apache.flink.client.program.ClusterClient
Shuts down the client.
shutdown() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
shutdown(JobStatus) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Shuts down the checkpoint coordinator.
shutdown(JobStatus) - Method in interface org.apache.flink.runtime.checkpoint.CheckpointIDCounter
Shuts the CheckpointIDCounter service.
shutdown(JobStatus) - Method in interface org.apache.flink.runtime.checkpoint.CompletedCheckpointStore
Shuts down the store.
shutdown(JobStatus) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
 
shutdown(JobStatus) - Method in class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
 
shutdown(JobStatus) - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
 
shutdown(JobStatus) - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
 
shutdown() - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
 
shutdown() - Method in class org.apache.flink.runtime.execution.librarycache.FallbackLibraryCacheManager
 
shutdown() - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
Shutdown method
shutdown() - Method in class org.apache.flink.runtime.filecache.FileCache
Shuts down the file cache by cancelling all
shutdown() - Method in class org.apache.flink.runtime.highavailability.nonha.embedded.EmbeddedLeaderService
Shuts down this leader election service.
shutdown() - Method in class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
 
shutdown() - Method in class org.apache.flink.runtime.instance.InstanceManager
 
shutdown() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManager
Close method, marks the I/O manager as closed and removed all temporary files.
shutdown() - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
Close method.
shutdown() - Method in interface org.apache.flink.runtime.io.network.ConnectionManager
 
shutdown() - Method in class org.apache.flink.runtime.io.network.LocalConnectionManager
 
shutdown() - Method in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager
 
shutdown() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
Tries to shut down all network I/O components.
shutdown() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionManager
 
shutdown() - Method in class org.apache.flink.runtime.jobmanager.JobManager
Shutdown method which may be overridden for testing.
shutdown() - Method in class org.apache.flink.runtime.jobmanager.scheduler.Scheduler
Shuts the scheduler down.
shutdown() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
 
shutdown() - Method in class org.apache.flink.runtime.jobmaster.JobManagerServices
This method makes sure all services are closed or shut down, even when an exception occurred in the shutdown of one component.
shutDown() - Method in class org.apache.flink.runtime.jobmaster.JobMaster
Suspend the job and shutdown all other services including rpc.
shutdown() - Method in class org.apache.flink.runtime.memory.MemoryManager
Shuts the memory manager down, trying to release all the memory it managed.
shutdown() - Method in class org.apache.flink.runtime.metrics.MetricRegistry
Shuts down this registry and the associated MetricReporter.
shutdown() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
shutdown() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
Shuts down the mini cluster, failing all currently executing jobs.
shutdown() - Method in class org.apache.flink.runtime.minicluster.MiniClusterJobDispatcher
Shuts down the mini cluster dispatcher.
shutdown() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
Forces an immediate shutdown of the thread.
shutDown() - Method in interface org.apache.flink.runtime.query.KvStateLocationLookupService
Shuts down the lookup service.
shutDown() - Method in class org.apache.flink.runtime.query.netty.KvStateClient
Shuts down the client and closes all connections.
shutDown() - Method in class org.apache.flink.runtime.query.netty.KvStateServer
Shuts down the server and all related thread pools.
shutDown() - Method in class org.apache.flink.runtime.query.QueryableStateClient
Shuts down the client and all components.
shutDown() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
shutDown() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRunner
 
shutDown() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRuntimeServices
 
shutDown() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
Shuts down the underlying RPC endpoint via the RPC service.
shutDown() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
Called to shut down the TaskManager.
shutDown(Throwable) - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
 
shutdown() - Method in class org.apache.flink.runtime.taskmanager.MemoryLogger
 
shutdown() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
 
shutDown() - Method in class org.apache.flink.runtime.webmonitor.BackPressureStatsTracker
Shuts down the stats tracker.
shutDown() - Method in class org.apache.flink.runtime.webmonitor.StackTraceSampleCoordinator
Shuts down the coordinator.
shutdown() - Method in class org.apache.flink.runtime.webmonitor.utils.WebFrontendBootstrap
 
shutdown() - Method in class org.apache.flink.storm.api.FlinkLocalCluster
 
shutdown() - Method in class org.apache.flink.streaming.connectors.kafka.internal.KafkaConsumerThread
Shuts this thread down, waking up the thread gracefully if blocked (without Thread.interrupt() calls).
shutdown() - Method in class org.apache.flink.streaming.connectors.kafka.internals.PeriodicOffsetCommitter
 
shutdown(ApplicationStatus, String) - Method in class org.apache.flink.yarn.YarnFlinkApplicationMasterRunner
 
shutDown() - Method in class org.apache.flink.yarn.YarnResourceManager
 
shutdown() - Method in class org.apache.flink.yarn.YarnTaskExecutorRunner
 
shutdown() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
shutdownApplication(ApplicationStatus, String) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
Called to shut down the cluster (not a failover situation).
shutdownApplication(ApplicationStatus, String) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
The framework specific code for shutting down the application.
shutdownApplication(ApplicationStatus, String) - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
 
shutDownApplication(ApplicationStatus, String) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
The framework specific code for shutting down the application.
shutDownApplication(ApplicationStatus, String) - Method in class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
 
shutdownApplication(ApplicationStatus, String) - Method in class org.apache.flink.yarn.YarnFlinkResourceManager
 
shutDownApplication(ApplicationStatus, String) - Method in class org.apache.flink.yarn.YarnResourceManager
 
shutDownCluster(ApplicationStatus, String) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
Cleanup application and shut down cluster
shutDownCluster(ApplicationStatus, String) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
shutdown cluster
shutdownCluster() - Method in class org.apache.flink.yarn.YarnClusterClient
Shuts down the Yarn application
ShutdownClusterAfterJob - Class in org.apache.flink.runtime.clusterframework.messages
Message sent to the cluster framework master to signal it that the cluster should be shut down upon completion of a certain job identified by a job id.
ShutdownClusterAfterJob(JobID) - Constructor for class org.apache.flink.runtime.clusterframework.messages.ShutdownClusterAfterJob
 
shutDownInternally() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
 
shutdownJobClientActorSystem(ActorSystem) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
shutdownService() - Method in class org.apache.flink.streaming.runtime.tasks.ProcessingTimeService
Shuts down and clean up the timer service provider hard and immediately.
shutdownService() - Method in class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
 
shutdownService() - Method in class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
SIDE - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
 
sideOutput(StreamRecord<IN>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
Write skipped late arriving element to SideOutput.
SideOutputExample - Class in org.apache.flink.streaming.examples.sideoutput
An example that illustrates the use of side outputs.
SideOutputExample() - Constructor for class org.apache.flink.streaming.examples.sideoutput.SideOutputExample
 
SideOutputExample.Tokenizer - Class in org.apache.flink.streaming.examples.sideoutput
Implements the string tokenizer that splits sentences into words as a user-defined FlatMapFunction.
sideOutputLateData(OutputTag<T>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Send late arriving data to the side output identified by the given OutputTag.
sideOutputLateData(OutputTag<T>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Send late arriving data to the side output identified by the given OutputTag.
sideOutputLateData(OutputTag<T>) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Send late arriving data to the side output identified by the given OutputTag.
sideOutputLateData(OutputTag<T>) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Send late arriving data to the side output identified by the given OutputTag.
SideOutputTransformation<T> - Class in org.apache.flink.streaming.api.transformations
This transformation represents a selection of a side output of an upstream operation with a given OutputTag.
SideOutputTransformation(StreamTransformation<?>, OutputTag<T>) - Constructor for class org.apache.flink.streaming.api.transformations.SideOutputTransformation
 
SIGN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
sign() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Calculates the signum of a given number.
Sign - Class in org.apache.flink.table.expressions
 
Sign(Expression) - Constructor for class org.apache.flink.table.expressions.Sign
 
Sign$ - Class in org.apache.flink.table.expressions
 
Sign$() - Constructor for class org.apache.flink.table.expressions.Sign$
 
SIGN_DEC() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
SIGN_DEC() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
SIGN_DOUBLE() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
SIGN_DOUBLE() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
SIGN_INT() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
SIGN_INT() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
SIGN_LONG() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
SIGN_LONG() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
SIGNAL_BUFFER_REQUEST - Static variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
SIGNAL_BUFFER_REQUEST_G0 - Static variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
SIGNAL_BUFFER_REQUEST_G1 - Static variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
SIGNAL_ERROR - Static variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
SIGNAL_FINISHED - Static variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
SIGNAL_LAST - Static variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
SignalHandler - Class in org.apache.flink.runtime.util
This signal handler / signal logger is based on Apache Hadoop's org.apache.hadoop.util.SignalLogger.
SignalHandler() - Constructor for class org.apache.flink.runtime.util.SignalHandler
 
signalTermination() - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepKickoffLatch
 
signaturesToString(UserDefinedFunction, String) - Method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils$
Prints all signatures of methods with given name in a class.
signaturesToString(UserDefinedFunction, String) - Static method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils
Prints all signatures of methods with given name in a class.
signatureToString(Class<?>[]) - Method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils$
Prints one signature consisting of classes.
signatureToString(Seq<TypeInformation<?>>) - Method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils$
Prints one signature consisting of TypeInformation.
signatureToString(Class<?>[]) - Static method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils
Prints one signature consisting of classes.
signatureToString(Seq<TypeInformation<?>>) - Static method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils
Prints one signature consisting of TypeInformation.
SignatureVisitorImpl(int) - Constructor for class org.apache.flink.runtime.util.DependencyVisitor.SignatureVisitorImpl
 
similar(Expression) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Returns true, if a string matches the specified SQL regex pattern.
Similar - Class in org.apache.flink.table.expressions
Returns true if str is similar to pattern.
Similar(Expression, Expression) - Constructor for class org.apache.flink.table.expressions.Similar
 
Similar$ - Class in org.apache.flink.table.expressions
 
Similar$() - Constructor for class org.apache.flink.table.expressions.Similar$
 
SIMILAR_TO - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
SIMILAR_WITH_ESCAPE() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
SIMILAR_WITH_ESCAPE() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
SimpleAccumulator<T extends Serializable> - Interface in org.apache.flink.api.common.accumulators
Similar to Accumulator, but the type of items to add and the result value must be the same.
SimpleCloseableInputProvider<E> - Class in org.apache.flink.runtime.operators.util
A simple iterator provider that returns a supplied iterator and does nothing when closed.
SimpleCloseableInputProvider(MutableObjectIterator<E>) - Constructor for class org.apache.flink.runtime.operators.util.SimpleCloseableInputProvider
Creates a new simple input provider that will return the given iterator.
SimpleCollectingOutputView - Class in org.apache.flink.runtime.io.disk
The list with the full segments contains at any point all completely full segments, plus the segment that is currently filled.
SimpleCollectingOutputView(List<MemorySegment>, MemorySegmentSource, int) - Constructor for class org.apache.flink.runtime.io.disk.SimpleCollectingOutputView
 
SimpleCondition<T> - Class in org.apache.flink.cep.pattern.conditions
A user-defined condition that decides if an element should be accepted in the pattern or not.
SimpleCondition() - Constructor for class org.apache.flink.cep.pattern.conditions.SimpleCondition
 
SimpleCounter - Class in org.apache.flink.metrics
A simple low-overhead Counter that is not thread-safe.
SimpleCounter() - Constructor for class org.apache.flink.metrics.SimpleCounter
 
SimpleDriver<K,VV,EV,R extends PrintableResult> - Class in org.apache.flink.graph.drivers
A base driver storing a single result DataSet with values implementing PrintableResult.
SimpleDriver() - Constructor for class org.apache.flink.graph.drivers.SimpleDriver
 
SimpleIterable(IN, MutableObjectIterator<IN>) - Constructor for class org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable
 
SimpleIterator(IN, MutableObjectIterator<IN>) - Constructor for class org.apache.flink.runtime.operators.CoGroupRawDriver.SimpleIterable.SimpleIterator
 
SimpleListIterable(List<IN>, TypeComparator<IN>, TypeSerializer<IN>) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase.SimpleListIterable
 
SimpleListIterator(List<IN>, TypeSerializer<IN>) - Constructor for class org.apache.flink.api.common.operators.base.CoGroupRawOperatorBase.SimpleListIterable.SimpleListIterator
 
SimpleOutputFormatter - Class in org.apache.flink.storm.util
 
SimpleOutputFormatter() - Constructor for class org.apache.flink.storm.util.SimpleOutputFormatter
 
SimpleParameter<T> - Class in org.apache.flink.graph.drivers.parameter
A Parameter with a default value.
SimpleParameter(ParameterizedBase, String) - Constructor for class org.apache.flink.graph.drivers.parameter.SimpleParameter
Set the parameter name and add this parameter to the list of parameters stored by owner.
simplePlan(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.drivers.AdamicAdar
 
simplePlan(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.drivers.ClusteringCoefficient
 
simplePlan(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.drivers.HITS
 
simplePlan(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.drivers.JaccardIndex
 
simplePlan(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.drivers.PageRank
 
simplePlan(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.drivers.SimpleDriver
Plan the algorithm and return the result DataSet.
simplePlan(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.drivers.TriangleListing
 
SimpleSlot - Class in org.apache.flink.runtime.instance
A SimpleSlot represents a single slot on a TaskManager instance, or a slot within a shared slot.
SimpleSlot(JobID, SlotOwner, TaskManagerLocation, int, TaskManagerGateway) - Constructor for class org.apache.flink.runtime.instance.SimpleSlot
Creates a new simple slot that stands alone and does not belong to shared slot.
SimpleSlot(JobID, SlotOwner, TaskManagerLocation, int, TaskManagerGateway, SharedSlot, AbstractID) - Constructor for class org.apache.flink.runtime.instance.SimpleSlot
Creates a new simple slot that belongs to the given shared slot and is identified by the given ID.
SimpleSlot(AllocatedSlot, SlotOwner, int) - Constructor for class org.apache.flink.runtime.instance.SimpleSlot
Creates a new simple slot that stands alone and does not belong to shared slot.
SimpleSlot(SharedSlot, SlotOwner, int, AbstractID) - Constructor for class org.apache.flink.runtime.instance.SimpleSlot
Creates a new simple slot that belongs to the given shared slot and is identified by the given ID..
SimpleSource - Class in org.apache.flink.streaming.scala.examples.async
 
SimpleSource() - Constructor for class org.apache.flink.streaming.scala.examples.async.SimpleSource
 
SimpleStringSchema - Class in org.apache.flink.streaming.util.serialization
Very simple serialization schema for strings.
SimpleStringSchema() - Constructor for class org.apache.flink.streaming.util.serialization.SimpleStringSchema
Creates a new SimpleStringSchema that uses "UTF-8" as the encoding.
SimpleStringSchema(Charset) - Constructor for class org.apache.flink.streaming.util.serialization.SimpleStringSchema
Creates a new SimpleStringSchema that uses the given charset to convert between strings and bytes.
SimpleTimerService - Class in org.apache.flink.streaming.api
Implementation of TimerService that uses a InternalTimerService.
SimpleTimerService(InternalTimerService<VoidNamespace>) - Constructor for class org.apache.flink.streaming.api.SimpleTimerService
 
SimpleTweetInputFormat - Class in org.apache.flink.contrib.tweetinputformat.io
 
SimpleTweetInputFormat() - Constructor for class org.apache.flink.contrib.tweetinputformat.io.SimpleTweetInputFormat
 
SimpleVersionedSerializer<E> - Interface in org.apache.flink.core.io
A simple serializer interface for versioned serialization.
Simplify<K extends Comparable<K>,VV,EV> - Class in org.apache.flink.graph.asm.simple.directed
Remove self-loops and duplicate edges from a directed graph.
Simplify() - Constructor for class org.apache.flink.graph.asm.simple.directed.Simplify
 
Simplify<K extends Comparable<K>,VV,EV> - Class in org.apache.flink.graph.asm.simple.undirected
Add symmetric edges and remove self-loops and duplicate edges from an undirected graph.
Simplify(boolean) - Constructor for class org.apache.flink.graph.asm.simple.undirected.Simplify
Simplifies an undirected graph by adding reverse edges and removing self-loops and duplicate edges.
Simplify - Class in org.apache.flink.graph.drivers.parameter
A simple graph has no self-loops (edges where the source and target vertices are the same) and no duplicate edges.
Simplify(ParameterizedBase) - Constructor for class org.apache.flink.graph.drivers.parameter.Simplify
Add this parameter to the list of parameters stored by owner.
simplify(Graph<T, NullValue, NullValue>) - Method in class org.apache.flink.graph.drivers.parameter.Simplify
Simplify the given graph based on the configured value.
Simplify.Ordering - Enum in org.apache.flink.graph.drivers.parameter
 
SIN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
sin() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Calculates the sine of a given number.
SIN() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
SIN() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
Sin - Class in org.apache.flink.table.expressions
 
Sin(Expression) - Constructor for class org.apache.flink.table.expressions.Sin
 
Sin$ - Class in org.apache.flink.table.expressions
 
Sin$() - Constructor for class org.apache.flink.table.expressions.Sin$
 
SIN_DEC() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
SIN_DEC() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
SINGLE_VALUE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
SINGLE_VALUE aggregate function.
SingleElementIterable<T> - Class in org.apache.flink.table.runtime.aggregate
 
SingleElementIterable() - Constructor for class org.apache.flink.table.runtime.aggregate.SingleElementIterable
 
SingleElementIterable.SingleElementIterator - Class in org.apache.flink.table.runtime.aggregate
 
SingleElementIterator<E> - Class in org.apache.flink.runtime.util
An Iterator that contains only a single element.
SingleElementIterator() - Constructor for class org.apache.flink.runtime.util.SingleElementIterator
 
SingleElementIterator() - Constructor for class org.apache.flink.table.runtime.aggregate.SingleElementIterable.SingleElementIterator
 
SingleInputGate - Class in org.apache.flink.runtime.io.network.partition.consumer
An input gate consumes one or more partitions of a single produced intermediate result.
SingleInputGate(String, JobID, IntermediateDataSetID, ResultPartitionType, int, int, TaskActions, TaskIOMetricGroup) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
SingleInputNode - Class in org.apache.flink.optimizer.dag
A node in the optimizer's program representation for an operation with a single input.
SingleInputNode(SingleInputOperator<?, ?, ?>) - Constructor for class org.apache.flink.optimizer.dag.SingleInputNode
Creates a new node with a single input for the optimizer plan.
SingleInputNode(FieldSet) - Constructor for class org.apache.flink.optimizer.dag.SingleInputNode
 
SingleInputNode() - Constructor for class org.apache.flink.optimizer.dag.SingleInputNode
 
SingleInputNode(SingleInputNode) - Constructor for class org.apache.flink.optimizer.dag.SingleInputNode
 
SingleInputOperator<IN,OUT,FT extends Function> - Class in org.apache.flink.api.common.operators
Abstract superclass for for all operators that have one input like "map" or "reduce".
SingleInputOperator(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, int[], String) - Constructor for class org.apache.flink.api.common.operators.SingleInputOperator
Creates a new abstract single-input operator with the given name wrapping the given user function.
SingleInputOperator(UserCodeWrapper<FT>, UnaryOperatorInformation<IN, OUT>, String) - Constructor for class org.apache.flink.api.common.operators.SingleInputOperator
Creates a new abstract single-input operator with the given name wrapping the given user function.
SingleInputOperator<IN,OUT,O extends SingleInputOperator<IN,OUT,O>> - Class in org.apache.flink.api.java.operators
Base class for operations that operates on a single input data set.
SingleInputOperator(DataSet<IN>, TypeInformation<OUT>) - Constructor for class org.apache.flink.api.java.operators.SingleInputOperator
 
SingleInputPlanNode - Class in org.apache.flink.optimizer.plan
 
SingleInputPlanNode(OptimizerNode, String, Channel, DriverStrategy) - Constructor for class org.apache.flink.optimizer.plan.SingleInputPlanNode
 
SingleInputPlanNode(OptimizerNode, String, Channel, DriverStrategy, FieldList) - Constructor for class org.apache.flink.optimizer.plan.SingleInputPlanNode
 
SingleInputPlanNode(OptimizerNode, String, Channel, DriverStrategy, FieldList, boolean[]) - Constructor for class org.apache.flink.optimizer.plan.SingleInputPlanNode
 
SingleInputSemanticProperties - Class in org.apache.flink.api.common.operators
Container for the semantic properties associated to a single input operator.
SingleInputSemanticProperties() - Constructor for class org.apache.flink.api.common.operators.SingleInputSemanticProperties
 
SingleInputSemanticProperties.AllFieldsForwardedProperties - Class in org.apache.flink.api.common.operators
 
SingleInputUdfOperator<IN,OUT,O extends SingleInputUdfOperator<IN,OUT,O>> - Class in org.apache.flink.api.java.operators
The SingleInputUdfOperator is the base class of all unary operators that execute user-defined functions (UDFs).
SingleInputUdfOperator(DataSet<IN>, TypeInformation<OUT>) - Constructor for class org.apache.flink.api.java.operators.SingleInputUdfOperator
Creates a new operators with the given data set as input.
SingleJoinExample - Class in org.apache.flink.storm.join
 
SingleJoinExample() - Constructor for class org.apache.flink.storm.join.SingleJoinExample
 
SingleLeaderElectionService - Class in org.apache.flink.runtime.highavailability.nonha.leaderelection
An implementation of the LeaderElectionService interface that handles a single leader contender.
SingleLeaderElectionService(Executor, UUID) - Constructor for class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
Creates a new leader election service.
SingleOutputStreamOperator<T> - Class in org.apache.flink.streaming.api.datastream
SingleOutputStreamOperator represents a user defined transformation applied on a DataStream with one predefined output type.
SingleOutputStreamOperator(StreamExecutionEnvironment, StreamTransformation<T>) - Constructor for class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
 
singleQuoteStringLiteral() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
singleQuoteStringLiteral() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
SingleSourceShortestPaths - Class in org.apache.flink.graph.examples
This example shows how to use Gelly's scatter-gather iterations.
SingleSourceShortestPaths() - Constructor for class org.apache.flink.graph.examples.SingleSourceShortestPaths
 
SingleSourceShortestPaths<K,VV> - Class in org.apache.flink.graph.library
This is an implementation of the Single-Source-Shortest Paths algorithm, using a scatter-gather iteration.
SingleSourceShortestPaths(K, Integer) - Constructor for class org.apache.flink.graph.library.SingleSourceShortestPaths
Creates an instance of the SingleSourceShortestPaths algorithm.
SingleSourceShortestPaths - Class in org.apache.flink.graph.scala.examples
This example shows how to use Gelly's scatter-gather iterations.
SingleSourceShortestPaths() - Constructor for class org.apache.flink.graph.scala.examples.SingleSourceShortestPaths
 
SingleSourceShortestPaths$ - Class in org.apache.flink.graph.scala.examples
This example shows how to use Gelly's scatter-gather iterations.
SingleSourceShortestPaths$() - Constructor for class org.apache.flink.graph.scala.examples.SingleSourceShortestPaths$
 
SingleSourceShortestPaths.InitVerticesMapper<K,VV> - Class in org.apache.flink.graph.library
 
SingleSourceShortestPaths.MinDistanceMessenger<K> - Class in org.apache.flink.graph.library
Distributes the minimum distance associated with a given vertex among all the target vertices summed up with the edge's value.
SingleSourceShortestPaths.VertexDistanceUpdater<K> - Class in org.apache.flink.graph.library
Function that updates the value of a vertex by picking the minimum distance from all incoming messages.
SingleSourceShortestPathsData - Class in org.apache.flink.graph.examples.data
Provides the default data set used for the Single Source Shortest Paths example program.
SingletonEdgeGraph - Class in org.apache.flink.graph.drivers.input
Generate a SingletonEdgeGraph.
SingletonEdgeGraph() - Constructor for class org.apache.flink.graph.drivers.input.SingletonEdgeGraph
 
SingletonEdgeGraph - Class in org.apache.flink.graph.generator
A singleton-edge Graph contains one or more isolated two-paths.
SingletonEdgeGraph(ExecutionEnvironment, long) - Constructor for class org.apache.flink.graph.generator.SingletonEdgeGraph
An undirected Graph containing one or more isolated two-paths.
SinkFunction<IN> - Interface in org.apache.flink.streaming.api.functions.sink
Interface for implementing user defined sink functionality.
sinkId - Static variable in class org.apache.flink.storm.exclamation.ExclamationTopology
 
sinkId - Static variable in class org.apache.flink.storm.wordcount.WordCountTopology
 
SinkJoiner - Class in org.apache.flink.optimizer.dag
This class represents a utility node that is not part of the actual plan.
SinkJoiner(OptimizerNode, OptimizerNode) - Constructor for class org.apache.flink.optimizer.dag.SinkJoiner
 
SinkJoinerPlanNode - Class in org.apache.flink.optimizer.plan
 
SinkJoinerPlanNode(SinkJoiner, Channel, Channel) - Constructor for class org.apache.flink.optimizer.plan.SinkJoinerPlanNode
 
SinkPlanNode - Class in org.apache.flink.optimizer.plan
Plan candidate node for data flow sinks.
SinkPlanNode(DataSinkNode, String, Channel) - Constructor for class org.apache.flink.optimizer.plan.SinkPlanNode
Constructs a new sink candidate node that uses NONE as its local strategy.
sinks - Variable in class org.apache.flink.api.common.Plan
A collection of all sinks in the plan.
SinkTransformation<T> - Class in org.apache.flink.streaming.api.transformations
This Transformation represents a Sink.
SinkTransformation(StreamTransformation<T>, String, StreamSink<T>, int) - Constructor for class org.apache.flink.streaming.api.transformations.SinkTransformation
Creates a new SinkTransformation from the given input StreamTransformation.
size() - Method in class org.apache.flink.api.common.operators.util.FieldSet
 
Size - Class in org.apache.flink.contrib.tweetinputformat.model.tweet.entities
An object showing available sizes for the media file.
Size(long, long, String) - Constructor for class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Size
 
size() - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
size - Variable in class org.apache.flink.core.memory.MemorySegment
The size in bytes of the memory segment
size() - Method in class org.apache.flink.core.memory.MemorySegment
Gets the size of the memory segment, in bytes.
size() - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
 
size() - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
 
size() - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
 
size() - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
 
size() - Method in interface org.apache.flink.graph.types.valuearray.ValueArray
Returns the number of elements stored in the array.
size() - Method in class org.apache.flink.metrics.HistogramStatistics
Returns the size of the statistics' sample
size() - Method in class org.apache.flink.ml.math.DenseVector
Number of elements in a vector
size() - Method in class org.apache.flink.ml.math.SparseVector
 
size() - Method in interface org.apache.flink.ml.math.Vector
Number of elements in a vector
size() - Method in class org.apache.flink.runtime.jobmanager.scheduler.LifoSetQueue
 
size() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
size() - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
size() - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
Gets the number of elements in the sortable.
size() - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
size() - Method in class org.apache.flink.runtime.operators.sort.PartialOrderPriorityQueue
Returns the number of elements currently stored in the PriorityQueue.
size() - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
Returns the total number of entries in this CopyOnWriteStateTable.
size() - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
size() - Method in class org.apache.flink.runtime.state.heap.StateTable
Returns the total number of entries in this NestedMapsStateTable.
size() - Method in class org.apache.flink.runtime.util.EvictingBoundedList
 
size() - Method in class org.apache.flink.runtime.util.IntArrayList
 
size() - Method in class org.apache.flink.runtime.util.LongArrayList
 
size() - Method in class org.apache.flink.runtime.util.LRUCache
 
size() - Method in class org.apache.flink.runtime.util.LRUCacheMap
 
size() - Method in class org.apache.flink.storm.util.StormConfig
 
size() - Method in class org.apache.flink.storm.wrappers.StormTuple
 
size() - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
 
size() - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
Return the size of the queue.
size() - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
 
size() - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
Gets the number of elements currently in the queue.
size() - Method in class org.apache.flink.streaming.runtime.io.BufferSpiller.SpilledBufferOrEventSequence
Gets the size of this spilled sequence.
size() - Method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
Gets the number of elements currently in the map.
size() - Method in class org.apache.flink.table.plan.logical.SlidingGroupWindow
 
size() - Method in class org.apache.flink.table.plan.logical.TumblingGroupWindow
 
size() - Method in class org.apache.flink.types.ListValue
 
size() - Method in class org.apache.flink.types.MapValue
 
SIZE - Static variable in class org.apache.flink.util.AbstractID
The size of the ID in byte
SIZE_MISMATCH_MESSAGE - Static variable in exception org.apache.flink.api.common.operators.Keys.IncompatibleKeysException
 
SIZE_UNKNOWN - Static variable in interface org.apache.flink.api.common.io.statistics.BaseStatistics
Constant indicating that the input size is unknown.
SizeHint$() - Constructor for class org.apache.flink.ml.nn.KNN.SizeHint$
 
sizeOfNamespace(Object) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
sizeOfNamespace(Object) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
sizeOfNamespace(Object) - Method in class org.apache.flink.runtime.state.heap.StateTable
 
skip(long) - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputViewStream
 
skip(int) - Method in class org.apache.flink.api.java.typeutils.runtime.NoFetchingInput
 
skip(long) - Method in class org.apache.flink.core.fs.AbstractMultiFSDataInputStream
 
skip(long) - Method in class org.apache.flink.core.fs.FSDataInputStreamWrapper
 
skip(long) - Method in class org.apache.flink.core.fs.local.LocalDataInputStream
 
skip(long) - Method in class org.apache.flink.core.memory.ByteArrayInputStreamWithPos
 
skip(long) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataInputStream
 
skip(long) - Method in class org.apache.flink.runtime.state.BoundedInputStream
 
skip(long) - Method in class org.apache.flink.runtime.util.NonClosingStreamDecorator
 
skipArray() - Method in class org.apache.flink.api.avro.DataInputDecoder
 
skipArray() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
skipBytes() - Method in class org.apache.flink.api.avro.DataInputDecoder
 
skipBytes() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
skipBytes(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
 
skipBytes(int) - Method in class org.apache.flink.runtime.util.DataInputDeserializer
 
skipBytesToRead(int) - Method in interface org.apache.flink.core.memory.DataInputView
Skips numBytes bytes of memory.
skipBytesToRead(int) - Method in class org.apache.flink.core.memory.DataInputViewStreamWrapper
 
skipBytesToRead(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedInputView
 
skipBytesToRead(int) - Method in class org.apache.flink.runtime.util.DataInputDeserializer
 
skipBytesToWrite(int) - Method in interface org.apache.flink.core.memory.DataOutputView
Skips numBytes bytes memory.
skipBytesToWrite(int) - Method in class org.apache.flink.core.memory.DataOutputViewStreamWrapper
 
skipBytesToWrite(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
 
skipBytesToWrite(int) - Method in class org.apache.flink.runtime.util.DataOutputSerializer
 
skipCollectionExecution() - Method in class org.apache.flink.test.util.JavaProgramTestBase
 
skipFields(byte[], int, int, byte[]) - Method in class org.apache.flink.api.common.io.GenericCsvInputFormat
 
skipFirstLineAsHeader - Variable in class org.apache.flink.api.java.io.CsvReader
 
skipFixed(int) - Method in class org.apache.flink.api.avro.DataInputDecoder
 
skipFixed(int) - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
skipFully(InputStream, long) - Static method in class org.apache.flink.util.IOUtils
Similar to readFully().
skipMap() - Method in class org.apache.flink.api.avro.DataInputDecoder
 
skipMap() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
skipString() - Method in class org.apache.flink.api.avro.DataInputDecoder
 
skipString() - Method in class org.apache.flink.api.java.typeutils.runtime.DataInputDecoder
 
skipWhitespace() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
slaveID() - Method in class org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore.Worker
Get the worker's assigned slave ID.
slaveId() - Method in class org.apache.flink.mesos.scheduler.messages.ExecutorLost
 
slaveId() - Method in class org.apache.flink.mesos.scheduler.messages.FrameworkMessage
 
slaveId() - Method in class org.apache.flink.mesos.scheduler.messages.SlaveLost
 
slaveID() - Method in class org.apache.flink.mesos.scheduler.TaskMonitor.Launched
 
slaveID() - Method in class org.apache.flink.mesos.scheduler.TaskMonitor.Released
 
SlaveLost - Class in org.apache.flink.mesos.scheduler.messages
Message sent by the callback handler to the scheduler actor when a slave has been determined unreachable (e.g., machine failure, network partition).
SlaveLost(Protos.SlaveID) - Constructor for class org.apache.flink.mesos.scheduler.messages.SlaveLost
 
slaveLost(SchedulerDriver, Protos.SlaveID) - Method in class org.apache.flink.mesos.scheduler.SchedulerProxy
 
SLICE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The internal "$SLICE" operator takes a multiset of records and returns a multiset of the first column of those records.
Slide - Class in org.apache.flink.table.api.java
Helper class for creating a sliding window.
Slide() - Constructor for class org.apache.flink.table.api.java.Slide
 
Slide - Class in org.apache.flink.table.api.scala
Helper object for creating a sliding window.
Slide() - Constructor for class org.apache.flink.table.api.scala.Slide
 
slide() - Method in class org.apache.flink.table.plan.logical.SlidingGroupWindow
 
Slide$ - Class in org.apache.flink.table.api.java
Helper class for creating a sliding window.
Slide$() - Constructor for class org.apache.flink.table.api.java.Slide$
 
Slide$ - Class in org.apache.flink.table.api.scala
Helper object for creating a sliding window.
Slide$() - Constructor for class org.apache.flink.table.api.scala.Slide$
 
slidePanes(int) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
 
SlideWithSize - Class in org.apache.flink.table.api
Partially specified sliding window.
SlideWithSize(Expression) - Constructor for class org.apache.flink.table.api.SlideWithSize
 
SlideWithSize(String) - Constructor for class org.apache.flink.table.api.SlideWithSize
Partially specified sliding window.
SlideWithSizeAndSlide - Class in org.apache.flink.table.api
Sliding window.
SlideWithSizeAndSlide(Expression, Expression) - Constructor for class org.apache.flink.table.api.SlideWithSizeAndSlide
 
SlideWithSizeAndSlideOnTime - Class in org.apache.flink.table.api
Sliding window on time.
SlideWithSizeAndSlideOnTime(Expression, Expression, Expression) - Constructor for class org.apache.flink.table.api.SlideWithSizeAndSlideOnTime
 
SlideWithSizeAndSlideOnTimeWithAlias - Class in org.apache.flink.table.api
Sliding window on time with alias.
SlideWithSizeAndSlideOnTimeWithAlias(Expression, Expression, Expression, Expression) - Constructor for class org.apache.flink.table.api.SlideWithSizeAndSlideOnTimeWithAlias
 
SlidingAlignedProcessingTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
This is a special window assigner used to tell the system to use the "Fast Aligned Processing Time Window Operator" for windowing.
SlidingAlignedProcessingTimeWindows(long, long) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.SlidingAlignedProcessingTimeWindows
 
SlidingEventTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
A WindowAssigner that windows elements into sliding windows based on the timestamp of the elements.
SlidingEventTimeWindows(long, long, long) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
 
SlidingGroupWindow - Class in org.apache.flink.table.plan.logical
 
SlidingGroupWindow(Expression, Expression, Expression, Expression) - Constructor for class org.apache.flink.table.plan.logical.SlidingGroupWindow
 
SlidingGroupWindow$ - Class in org.apache.flink.table.plan.logical
 
SlidingGroupWindow$() - Constructor for class org.apache.flink.table.plan.logical.SlidingGroupWindow$
 
SlidingProcessingTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
A WindowAssigner that windows elements into sliding windows based on the current system time of the machine the operation is running on.
SlidingTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
Deprecated.
Slot - Class in org.apache.flink.runtime.instance
Base class for slots that the Scheduler / ExecutionGraph take from the SlotPool and use to place tasks to execute into.
Slot(JobID, SlotOwner, TaskManagerLocation, int, TaskManagerGateway, SharedSlot, AbstractID) - Constructor for class org.apache.flink.runtime.instance.Slot
Base constructor for slots.
Slot(AllocatedSlot, SlotOwner, int, SharedSlot, AbstractID) - Constructor for class org.apache.flink.runtime.instance.Slot
Base constructor for slots.
slot() - Method in class org.apache.flink.runtime.jobmanager.slots.SlotAndLocality
 
SlotActions - Interface in org.apache.flink.runtime.taskexecutor.slot
Interface to trigger slot actions from within the TaskSlotTable.
SlotAllocationException - Exception in org.apache.flink.runtime.taskexecutor.exceptions
Exception indicating that the slot allocation on the task manager failed.
SlotAllocationException(String) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.SlotAllocationException
 
SlotAllocationException(String, Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.SlotAllocationException
 
SlotAllocationException(Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.SlotAllocationException
 
SlotAndLocality - Class in org.apache.flink.runtime.jobmanager.slots
A combination of a AllocatedSlot and a Locality.
SlotAndLocality(AllocatedSlot, Locality) - Constructor for class org.apache.flink.runtime.jobmanager.slots.SlotAndLocality
 
SlotAvailabilityListener - Interface in org.apache.flink.runtime.jobmanager.scheduler
A SlotAvailabilityListener can be notified when new Slots become available on an Instance.
slotFuture - Variable in class org.apache.flink.runtime.executiongraph.ExecutionAndSlot
 
SlotID - Class in org.apache.flink.runtime.clusterframework.types
Unique identifier for a slot on a TaskManager.
SlotID(ResourceID, int) - Constructor for class org.apache.flink.runtime.clusterframework.types.SlotID
 
SlotManager - Class in org.apache.flink.runtime.resourcemanager.slotmanager
The slot manager is responsible for maintaining a view on all registered task manager slots, their allocation and all pending slot requests.
SlotManager(ScheduledExecutor, Time, Time, Time) - Constructor for class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
 
SlotManagerConfiguration - Class in org.apache.flink.runtime.resourcemanager.slotmanager
 
SlotManagerConfiguration(Time, Time, Time) - Constructor for class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerConfiguration
 
SlotManagerException - Exception in org.apache.flink.runtime.resourcemanager.slotmanager
 
SlotManagerException(String) - Constructor for exception org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerException
 
SlotManagerException(String, Throwable) - Constructor for exception org.apache.flink.runtime.resourcemanager.slotmanager.SlotManagerException
 
SlotNotActiveException - Exception in org.apache.flink.runtime.taskexecutor.slot
Exception indicating that the given TaskSlot was not in state active.
SlotNotActiveException(JobID, AllocationID) - Constructor for exception org.apache.flink.runtime.taskexecutor.slot.SlotNotActiveException
 
SlotNotFoundException - Exception in org.apache.flink.runtime.taskexecutor.slot
Exception indicating that a TaskSlot could not be found.
SlotNotFoundException(AllocationID) - Constructor for exception org.apache.flink.runtime.taskexecutor.slot.SlotNotFoundException
 
SlotNotFoundException(String) - Constructor for exception org.apache.flink.runtime.taskexecutor.slot.SlotNotFoundException
 
SlotOccupiedException - Exception in org.apache.flink.runtime.taskexecutor.exceptions
 
SlotOccupiedException(String, AllocationID) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.SlotOccupiedException
 
SlotOccupiedException(String, Throwable, AllocationID) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.SlotOccupiedException
 
SlotOccupiedException(Throwable, AllocationID) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.SlotOccupiedException
 
SlotOffer - Class in org.apache.flink.runtime.taskexecutor.slot
Describe the slot offering to job manager provided by task manager.
SlotOffer(AllocationID, int, ResourceProfile) - Constructor for class org.apache.flink.runtime.taskexecutor.slot.SlotOffer
 
SlotOwner - Interface in org.apache.flink.runtime.jobmanager.slots
Interface for components that hold slots and to which slots get released / recycled.
SlotPool - Class in org.apache.flink.runtime.instance
The slot pool serves slot request issued by Scheduler or ExecutionGraph.
SlotPool(RpcService, JobID) - Constructor for class org.apache.flink.runtime.instance.SlotPool
 
SlotPool(RpcService, JobID, Clock, Time, Time, Time) - Constructor for class org.apache.flink.runtime.instance.SlotPool
 
SlotPoolGateway - Interface in org.apache.flink.runtime.instance
The gateway for calls on the SlotPool.
SlotProvider - Interface in org.apache.flink.runtime.instance
The slot provider is responsible for preparing slots for ready-to-run tasks.
SlotReport - Class in org.apache.flink.runtime.taskexecutor
A report about the current status of all slots of the TaskExecutor, describing which slots are available and allocated, and what jobs (JobManagers) the allocated slots have been allocated to.
SlotReport() - Constructor for class org.apache.flink.runtime.taskexecutor.SlotReport
 
SlotReport(SlotStatus) - Constructor for class org.apache.flink.runtime.taskexecutor.SlotReport
 
SlotReport(Collection<SlotStatus>) - Constructor for class org.apache.flink.runtime.taskexecutor.SlotReport
 
SlotRequest - Class in org.apache.flink.runtime.resourcemanager
This describes the requirement of the slot, mainly used by JobManager requesting slot from ResourceManager.
SlotRequest(JobID, AllocationID, ResourceProfile, String) - Constructor for class org.apache.flink.runtime.resourcemanager.SlotRequest
 
slots() - Method in class org.apache.flink.api.scala.FlinkShell.YarnConfig
 
SlotSharingGroup - Class in org.apache.flink.runtime.jobmanager.scheduler
A slot sharing units defines which different task (from different job vertices) can be deployed together within a slot.
SlotSharingGroup() - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
 
SlotSharingGroup(JobVertexID...) - Constructor for class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
 
slotSharingGroup(String) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
Sets the slot sharing group of this operation.
slotSharingGroup(String) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Sets the slot sharing group of this operation.
slotSharingGroup(String) - Method in class org.apache.flink.streaming.api.scala.DataStream
Sets the slot sharing group of this operation.
slotSharingGroup(String) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink
Sets the slot sharing group of this operation.
slotSharingGroup(String) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010.FlinkKafkaProducer010Configuration
 
SlotSharingGroupAssignment - Class in org.apache.flink.runtime.instance
The SlotSharingGroupAssignment manages a set of shared slots, which are shared between tasks of a SlotSharingGroup.
SlotSharingGroupAssignment() - Constructor for class org.apache.flink.runtime.instance.SlotSharingGroupAssignment
 
SlotStatus - Class in org.apache.flink.runtime.taskexecutor
This describes the slot current status which located in TaskManager.
SlotStatus(SlotID, ResourceProfile) - Constructor for class org.apache.flink.runtime.taskexecutor.SlotStatus
 
SlotStatus(SlotID, ResourceProfile, JobID, AllocationID) - Constructor for class org.apache.flink.runtime.taskexecutor.SlotStatus
 
snapshot(long, long, CheckpointStreamFactory, CheckpointOptions) - Method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
Triggers an asynchronous snapshot of the keyed state backend from RocksDB.
Snapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<ACC>, FoldingStateDescriptor<T, ACC>, Path) - Constructor for class org.apache.flink.migration.runtime.state.filesystem.FsFoldingState.Snapshot
Deprecated.
 
Snapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<ArrayList<V>>, ListStateDescriptor<V>, Path) - Constructor for class org.apache.flink.migration.runtime.state.filesystem.FsListState.Snapshot
Deprecated.
 
Snapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<V>, ReducingStateDescriptor<V>, Path) - Constructor for class org.apache.flink.migration.runtime.state.filesystem.FsReducingState.Snapshot
Deprecated.
 
Snapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<V>, ValueStateDescriptor<V>, Path) - Constructor for class org.apache.flink.migration.runtime.state.filesystem.FsValueState.Snapshot
Deprecated.
 
Snapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<ACC>, FoldingStateDescriptor<T, ACC>, byte[]) - Constructor for class org.apache.flink.migration.runtime.state.memory.MemFoldingState.Snapshot
Deprecated.
 
Snapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<ArrayList<V>>, ListStateDescriptor<V>, byte[]) - Constructor for class org.apache.flink.migration.runtime.state.memory.MemListState.Snapshot
Deprecated.
 
Snapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<V>, ReducingStateDescriptor<V>, byte[]) - Constructor for class org.apache.flink.migration.runtime.state.memory.MemReducingState.Snapshot
Deprecated.
 
Snapshot(TypeSerializer<K>, TypeSerializer<N>, TypeSerializer<V>, ValueStateDescriptor<V>, byte[]) - Constructor for class org.apache.flink.migration.runtime.state.memory.MemValueState.Snapshot
Deprecated.
 
snapshot(long, long, CheckpointStreamFactory, CheckpointOptions) - Method in class org.apache.flink.runtime.state.DefaultOperatorStateBackend
 
snapshot(long, long, CheckpointStreamFactory, CheckpointOptions) - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
snapshot() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo
 
snapshot() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo
 
snapshot(long, long, CheckpointStreamFactory, CheckpointOptions) - Method in interface org.apache.flink.runtime.state.Snapshotable
Operation that writes a snapshot into a stream that is provided by the given CheckpointStreamFactory and returns a @RunnableFuture that gives a state handle to the snapshot.
Snapshotable<S extends StateObject> - Interface in org.apache.flink.runtime.state
Interface for operators that can perform snapshots of their state.
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.ListSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.MapSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.TypeDeserializerAdapter
 
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.TypeSerializer
Create a snapshot of the serializer's current configuration to be stored along with the managed state it is registered to (if any - this method is only relevant if this serializer is registered for serialization of managed state).
snapshotConfiguration() - Method in class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.java.typeutils.runtime.EitherSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.KryoSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.java.typeutils.runtime.RowSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
snapshotConfiguration() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.scala.typeutils.EitherSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.scala.typeutils.EnumValueSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.scala.typeutils.NothingSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.scala.typeutils.OptionSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.scala.typeutils.TraversableSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.api.scala.typeutils.TrySerializer
 
snapshotConfiguration() - Method in class org.apache.flink.cep.nfa.NFA.NFASerializer
 
snapshotConfiguration() - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.cep.NonDuplicatingTypeSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.migration.MigrationNamespaceSerializerProxy
Deprecated.
 
snapshotConfiguration() - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.MultiplexingStreamRecordSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.migration.streaming.runtime.streamrecord.StreamRecordSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.runtime.state.ArrayListSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.runtime.state.HashMapSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.streaming.api.operators.InternalTimer.TimerSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
snapshotConfiguration() - Method in class org.apache.flink.table.runtime.types.CRowSerializer
 
snapshotCurrentState() - Method in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
Takes a snapshot of the partition offsets.
snapshotFunctionState(StateSnapshotContext, OperatorStateBackend, Function) - Static method in class org.apache.flink.streaming.util.functions.StreamingFunctionUtils
 
snapshotLegacyOperatorState(long, long, CheckpointOptions) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
Deprecated.
Non-repartitionable operator state that has been deprecated. Can be removed when we remove the APIs for non-repartitionable operator state.
snapshotLegacyOperatorState(long, long, CheckpointOptions) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
Deprecated.
This method will be removed as soon as no more operators use the legacy state code paths
snapshotState(long, long) - Method in interface org.apache.flink.streaming.api.checkpoint.Checkpointed
Deprecated.
Gets the current state of the function of operator.
snapshotState(FunctionSnapshotContext) - Method in interface org.apache.flink.streaming.api.checkpoint.CheckpointedFunction
This method is called when a snapshot for a checkpoint is requested.
snapshotState(long, long) - Method in interface org.apache.flink.streaming.api.checkpoint.ListCheckpointed
Gets the current state of the function.
snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileMonitoringFunction
 
snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.ContinuousFileReaderOperator
 
snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.FromElementsFunction
 
snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.MessageAcknowledgingSourceBase
 
snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.MultipleIdsMessageAcknowledgingSourceBase
 
snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
 
snapshotState(long, long, CheckpointOptions) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
 
snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.api.operators.AbstractStreamOperator
Stream operators with state, which want to participate in a snapshot need to override this hook method.
snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
snapshotState(FSDataOutputStream, long, long) - Method in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
 
snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.api.operators.async.AsyncWaitOperator
 
snapshotState(FSDataOutputStream, long, long) - Method in interface org.apache.flink.streaming.api.operators.StreamCheckpointedOperator
Deprecated.
Called to draw a state snapshot from the operator.
snapshotState(long, long, CheckpointOptions) - Method in interface org.apache.flink.streaming.api.operators.StreamOperator
Called to draw a state snapshot from the operator.
snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase
 
snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BucketingSink
 
snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.connectors.fs.RollingSink
Deprecated.
 
snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
 
snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
 
snapshotState(FunctionSnapshotContext) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
 
snapshotState(StateSnapshotContext) - Method in class org.apache.flink.streaming.runtime.operators.GenericWriteAheadSink
 
snapshotState(FSDataOutputStream, long, long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
Deprecated.
 
snapshotTimersForKeyGroup(DataOutputViewStreamWrapper, int) - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
Snapshots the timers (both processing and event time ones) for a given keyGroupIdx.
socket - Variable in class org.apache.flink.python.api.streaming.data.PythonStreamer
 
socketAddressToUrlString(InetSocketAddress) - Static method in class org.apache.flink.util.NetUtils
Encodes an IP address and port to be included in URL.
SocketClientSink<IN> - Class in org.apache.flink.streaming.api.functions.sink
Socket client that acts as a streaming sink.
SocketClientSink(String, int, SerializationSchema<IN>) - Constructor for class org.apache.flink.streaming.api.functions.sink.SocketClientSink
Creates a new SocketClientSink.
SocketClientSink(String, int, SerializationSchema<IN>, int) - Constructor for class org.apache.flink.streaming.api.functions.sink.SocketClientSink
Creates a new SocketClientSink that retries connections upon failure up to a given number of times.
SocketClientSink(String, int, SerializationSchema<IN>, int, boolean) - Constructor for class org.apache.flink.streaming.api.functions.sink.SocketClientSink
Creates a new SocketClientSink that retries connections upon failure up to a given number of times.
socketTextStream(String, int, char, long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
socketTextStream(String, int, String, long) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a new data stream that contains the strings received infinitely from a socket.
socketTextStream(String, int, char) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
socketTextStream(String, int, String) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a new data stream that contains the strings received infinitely from a socket.
socketTextStream(String, int) - Method in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
Creates a new data stream that contains the strings received infinitely from a socket.
socketTextStream(String, int, char, long) - Method in class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
Creates a new DataStream that contains the strings received infinitely from socket.
SocketTextStreamFunction - Class in org.apache.flink.streaming.api.functions.source
A source function that reads strings from a socket.
SocketTextStreamFunction(String, int, String, long) - Constructor for class org.apache.flink.streaming.api.functions.source.SocketTextStreamFunction
 
SocketTextStreamFunction(String, int, String, long, long) - Constructor for class org.apache.flink.streaming.api.functions.source.SocketTextStreamFunction
 
SocketWindowWordCount - Class in org.apache.flink.streaming.examples.socket
Implements a streaming windowed version of the "WordCount" program.
SocketWindowWordCount() - Constructor for class org.apache.flink.streaming.examples.socket.SocketWindowWordCount
 
SocketWindowWordCount - Class in org.apache.flink.streaming.scala.examples.socket
Implements a streaming windowed version of the "WordCount" program.
SocketWindowWordCount() - Constructor for class org.apache.flink.streaming.scala.examples.socket.SocketWindowWordCount
 
SocketWindowWordCount$ - Class in org.apache.flink.streaming.scala.examples.socket
Implements a streaming windowed version of the "WordCount" program.
SocketWindowWordCount$() - Constructor for class org.apache.flink.streaming.scala.examples.socket.SocketWindowWordCount$
 
SocketWindowWordCount.WordWithCount - Class in org.apache.flink.streaming.examples.socket
Data type for words with count
SocketWindowWordCount.WordWithCount - Class in org.apache.flink.streaming.scala.examples.socket
Data type for words with count
SocketWindowWordCount.WordWithCount$ - Class in org.apache.flink.streaming.scala.examples.socket
 
SolutionSetBroker - Class in org.apache.flink.runtime.iterative.concurrent
Used to hand over the hash-join from the iteration head to the solution-set match.
SolutionSetDeltaOperator - Class in org.apache.flink.optimizer.operators
 
SolutionSetDeltaOperator(FieldList) - Constructor for class org.apache.flink.optimizer.operators.SolutionSetDeltaOperator
 
SolutionSetFastUpdateOutputCollector<T> - Class in org.apache.flink.runtime.iterative.io
A Collector to update the solution set of a workset iteration.
SolutionSetFastUpdateOutputCollector(CompactingHashTable<T>) - Constructor for class org.apache.flink.runtime.iterative.io.SolutionSetFastUpdateOutputCollector
 
SolutionSetFastUpdateOutputCollector(CompactingHashTable<T>, Collector<T>) - Constructor for class org.apache.flink.runtime.iterative.io.SolutionSetFastUpdateOutputCollector
 
SolutionSetNode - Class in org.apache.flink.optimizer.dag
The optimizer's internal representation of the solution set of a workset iteration.
SolutionSetNode(DeltaIterationBase.SolutionSetPlaceHolder<?>, WorksetIterationNode) - Constructor for class org.apache.flink.optimizer.dag.SolutionSetNode
 
SolutionSetObjectsUpdateOutputCollector<T> - Class in org.apache.flink.runtime.iterative.io
A Collector to update the solution set of a workset iteration.
SolutionSetObjectsUpdateOutputCollector(JoinHashMap<T>) - Constructor for class org.apache.flink.runtime.iterative.io.SolutionSetObjectsUpdateOutputCollector
 
SolutionSetObjectsUpdateOutputCollector(JoinHashMap<T>, Collector<T>) - Constructor for class org.apache.flink.runtime.iterative.io.SolutionSetObjectsUpdateOutputCollector
 
SolutionSetPlaceHolder(DeltaIterationBase<ST, ?>, OperatorInformation<ST>) - Constructor for class org.apache.flink.api.common.operators.base.DeltaIterationBase.SolutionSetPlaceHolder
 
SolutionSetPlanNode - Class in org.apache.flink.optimizer.plan
Plan candidate node for partial solution of a bulk iteration.
SolutionSetPlanNode(SolutionSetNode, String, GlobalProperties, LocalProperties, Channel) - Constructor for class org.apache.flink.optimizer.plan.SolutionSetPlanNode
 
SolutionSetUpdateBarrier - Class in org.apache.flink.runtime.iterative.concurrent
Resettable barrier to synchronize the IterationHeadTask and the IterationTailTask in case of iterations that contain a separate solution set tail.
SolutionSetUpdateBarrier() - Constructor for class org.apache.flink.runtime.iterative.concurrent.SolutionSetUpdateBarrier
 
SolutionSetUpdateBarrierBroker - Class in org.apache.flink.runtime.iterative.concurrent
SolutionSetUpdateOutputCollector<T> - Class in org.apache.flink.runtime.iterative.io
A Collector to update the solution set of a workset iteration.
SolutionSetUpdateOutputCollector(CompactingHashTable<T>) - Constructor for class org.apache.flink.runtime.iterative.io.SolutionSetUpdateOutputCollector
 
SolutionSetUpdateOutputCollector(CompactingHashTable<T>, Collector<T>) - Constructor for class org.apache.flink.runtime.iterative.io.SolutionSetUpdateOutputCollector
 
Solver - Class in org.apache.flink.ml.optimization
Base class for optimization algorithms
Solver() - Constructor for class org.apache.flink.ml.optimization.Solver
 
Solver$ - Class in org.apache.flink.ml.optimization
 
Solver$() - Constructor for class org.apache.flink.ml.optimization.Solver$
 
Solver.LossFunction$ - Class in org.apache.flink.ml.optimization
 
Solver.RegularizationConstant$ - Class in org.apache.flink.ml.optimization
 
Solver.RegularizationPenaltyValue$ - Class in org.apache.flink.ml.optimization
 
sort(IndexedSortable, int, int) - Method in class org.apache.flink.runtime.operators.sort.HeapSort
 
sort(IndexedSortable) - Method in class org.apache.flink.runtime.operators.sort.HeapSort
 
sort(IndexedSortable, int, int) - Method in interface org.apache.flink.runtime.operators.sort.IndexedSorter
Sort the items accessed through the given IndexedSortable over the given range of logical indices.
sort(IndexedSortable) - Method in interface org.apache.flink.runtime.operators.sort.IndexedSorter
 
sort(IndexedSortable, int, int) - Method in class org.apache.flink.runtime.operators.sort.QuickSort
Sort the given range of items using quick sort.
sort(IndexedSortable) - Method in class org.apache.flink.runtime.operators.sort.QuickSort
 
sort(int[]) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
sort(RexNode[]) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
sort(Iterable<? extends RexNode>) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
Sort - Class in org.apache.flink.table.plan.logical
 
Sort(Seq<Ordering>, LogicalNode) - Constructor for class org.apache.flink.table.plan.logical.Sort
 
Sort$ - Class in org.apache.flink.table.plan.logical
 
Sort$() - Constructor for class org.apache.flink.table.plan.logical.Sort$
 
SortedGrouping<T> - Class in org.apache.flink.api.java.operators
SortedGrouping is an intermediate step for a transformation on a grouped and sorted DataSet.
The following transformation can be applied on sorted groups: SortedGrouping.reduceGroup(org.apache.flink.api.common.functions.GroupReduceFunction),
SortedGrouping(DataSet<T>, Keys<T>, int, Order) - Constructor for class org.apache.flink.api.java.operators.SortedGrouping
 
SortedGrouping(DataSet<T>, Keys<T>, String, Order) - Constructor for class org.apache.flink.api.java.operators.SortedGrouping
 
SortedGrouping(DataSet<T>, Keys<T>, Keys.SelectorFunctionKeys<T, K>, Order) - Constructor for class org.apache.flink.api.java.operators.SortedGrouping
 
Sorter<E> - Interface in org.apache.flink.runtime.operators.sort
The SortMerger interface representing the public interface to all specific Sort-Merge implementations.
sortFirstGroup(int, Order) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
Sorts Tuple elements within a group in the first input on the specified field in the specified Order.
Note: Only groups of Tuple elements and Pojos can be sorted.
Groups can be sorted by multiple fields by chaining CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction.sortFirstGroup(int, Order) calls.
sortFirstGroup(String, Order) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
Sorts Pojo or Tuple elements within a group in the first input on the specified field in the specified Order.
Groups can be sorted by multiple fields by chaining CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction.sortFirstGroup(String, Order) calls.
sortFirstGroup(int, Order) - Method in class org.apache.flink.api.scala.CoGroupDataSet
Adds a secondary sort key to the first input of this CoGroupDataSet.
sortFirstGroup(String, Order) - Method in class org.apache.flink.api.scala.CoGroupDataSet
Adds a secondary sort key to the first input of this CoGroupDataSet.
sortGroup(int, Order) - Method in class org.apache.flink.api.java.operators.SortedGrouping
Sorts Tuple elements within a group on the specified field in the specified Order.
Note: Only groups of Tuple or Pojo elements can be sorted.
Groups can be sorted by multiple fields by chaining SortedGrouping.sortGroup(int, Order) calls.
sortGroup(String, Order) - Method in class org.apache.flink.api.java.operators.SortedGrouping
Sorts Tuple or POJO elements within a group on the specified field in the specified Order.
Note: Only groups of Tuple or Pojo elements can be sorted.
Groups can be sorted by multiple fields by chaining SortedGrouping.sortGroup(String, Order) calls.
sortGroup(int, Order) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Sorts Tuple elements within a group on the specified field in the specified Order.
Note: Only groups of Tuple elements and Pojos can be sorted.
Groups can be sorted by multiple fields by chaining UnsortedGrouping.sortGroup(int, Order) calls.
sortGroup(String, Order) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Sorts Pojos within a group on the specified field in the specified Order.
Note: Only groups of Tuple elements and Pojos can be sorted.
Groups can be sorted by multiple fields by chaining UnsortedGrouping.sortGroup(String, Order) calls.
sortGroup(KeySelector<T, K>, Order) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Sorts elements within a group on a key extracted by the specified KeySelector in the specified Order.
Chaining UnsortedGrouping.sortGroup(KeySelector, Order) calls is not supported.
sortGroup(int, Order) - Method in class org.apache.flink.api.scala.GroupedDataSet
Adds a secondary sort key to this GroupedDataSet.
sortGroup(String, Order) - Method in class org.apache.flink.api.scala.GroupedDataSet
Adds a secondary sort key to this GroupedDataSet.
sortGroup(Function1<T, K>, Order, TypeInformation<K>) - Method in class org.apache.flink.api.scala.GroupedDataSet
Adds a secondary sort key to this GroupedDataSet.
sortGroupWith(Order, Function1<T, K>, TypeInformation<K>) - Method in class org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions.OnGroupedDataSet
Sorts a group using a sorting function fun and an Order
SortingThread(ExceptionHandler<IOException>, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SortingThread
Creates a new sorting thread.
sortLimit(int, int, RexNode[]) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
sortLimit(int, int, Iterable<? extends RexNode>) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
sortLocalOutput(int, Order) - Method in class org.apache.flink.api.java.operators.DataSink
Deprecated.
sortLocalOutput(String, Order) - Method in class org.apache.flink.api.java.operators.DataSink
Deprecated.
SortMergeFullOuterJoinDescriptor - Class in org.apache.flink.optimizer.operators
 
SortMergeFullOuterJoinDescriptor(FieldList, FieldList) - Constructor for class org.apache.flink.optimizer.operators.SortMergeFullOuterJoinDescriptor
 
SortMergeInnerJoinDescriptor - Class in org.apache.flink.optimizer.operators
 
SortMergeInnerJoinDescriptor(FieldList, FieldList) - Constructor for class org.apache.flink.optimizer.operators.SortMergeInnerJoinDescriptor
 
SortMergeInnerJoinDescriptor(FieldList, FieldList, boolean, boolean, boolean) - Constructor for class org.apache.flink.optimizer.operators.SortMergeInnerJoinDescriptor
 
SortMergeLeftOuterJoinDescriptor - Class in org.apache.flink.optimizer.operators
 
SortMergeLeftOuterJoinDescriptor(FieldList, FieldList) - Constructor for class org.apache.flink.optimizer.operators.SortMergeLeftOuterJoinDescriptor
 
SortMergeLeftOuterJoinDescriptor(FieldList, FieldList, boolean) - Constructor for class org.apache.flink.optimizer.operators.SortMergeLeftOuterJoinDescriptor
 
SortMergeRightOuterJoinDescriptor - Class in org.apache.flink.optimizer.operators
 
SortMergeRightOuterJoinDescriptor(FieldList, FieldList) - Constructor for class org.apache.flink.optimizer.operators.SortMergeRightOuterJoinDescriptor
 
SortMergeRightOuterJoinDescriptor(FieldList, FieldList, boolean) - Constructor for class org.apache.flink.optimizer.operators.SortMergeRightOuterJoinDescriptor
 
sortOrders - Variable in class org.apache.flink.optimizer.plan.DualInputPlanNode
 
sortPartition(int, Order) - Method in class org.apache.flink.api.java.DataSet
Locally sorts the partitions of the DataSet on the specified field in the specified order.
sortPartition(String, Order) - Method in class org.apache.flink.api.java.DataSet
Locally sorts the partitions of the DataSet on the specified field in the specified order.
sortPartition(KeySelector<T, K>, Order) - Method in class org.apache.flink.api.java.DataSet
Locally sorts the partitions of the DataSet on the extracted key in the specified order.
sortPartition(int, Order) - Method in class org.apache.flink.api.java.operators.SortPartitionOperator
Appends an additional sort order with the specified field in the specified order to the local partition sorting of the DataSet.
sortPartition(String, Order) - Method in class org.apache.flink.api.java.operators.SortPartitionOperator
Appends an additional sort order with the specified field in the specified order to the local partition sorting of the DataSet.
sortPartition(KeySelector<T, K>, Order) - Method in class org.apache.flink.api.java.operators.SortPartitionOperator
 
sortPartition(int, Order) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
sortPartition(String, Order) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
sortPartition(Function1<T, K>, Order, TypeInformation<K>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
sortPartition(int, Order) - Method in class org.apache.flink.api.scala.DataSet
Locally sorts the partitions of the DataSet on the specified field in the specified order.
sortPartition(String, Order) - Method in class org.apache.flink.api.scala.DataSet
Locally sorts the partitions of the DataSet on the specified field in the specified order.
sortPartition(Function1<T, K>, Order, TypeInformation<K>) - Method in class org.apache.flink.api.scala.DataSet
Locally sorts the partitions of the DataSet on the extracted key in the specified order.
sortPartition(int, Order) - Method in class org.apache.flink.api.scala.PartitionSortedDataSet
Appends the given field and order to the sort-partition operator.
sortPartition(String, Order) - Method in class org.apache.flink.api.scala.PartitionSortedDataSet
Appends the given field and order to the sort-partition operator.
sortPartition(Function1<T, K>, Order, TypeInformation<K>) - Method in class org.apache.flink.api.scala.PartitionSortedDataSet
 
SortPartitionDescriptor(Ordering) - Constructor for class org.apache.flink.optimizer.dag.SortPartitionNode.SortPartitionDescriptor
 
SortPartitionNode - Class in org.apache.flink.optimizer.dag
The optimizer's internal representation of a SortPartition operator node.
SortPartitionNode(SortPartitionOperatorBase<?>) - Constructor for class org.apache.flink.optimizer.dag.SortPartitionNode
 
SortPartitionNode.SortPartitionDescriptor - Class in org.apache.flink.optimizer.dag
 
SortPartitionOperator<T> - Class in org.apache.flink.api.java.operators
This operator represents a DataSet with locally sorted partitions.
SortPartitionOperator(DataSet<T>, int, Order, String) - Constructor for class org.apache.flink.api.java.operators.SortPartitionOperator
 
SortPartitionOperator(DataSet<T>, String, Order, String) - Constructor for class org.apache.flink.api.java.operators.SortPartitionOperator
 
SortPartitionOperator(DataSet<T>, Keys.SelectorFunctionKeys<T, K>, Order, String) - Constructor for class org.apache.flink.api.java.operators.SortPartitionOperator
 
SortPartitionOperatorBase<IN> - Class in org.apache.flink.api.common.operators.base
 
SortPartitionOperatorBase(UnaryOperatorInformation<IN, IN>, Ordering, String) - Constructor for class org.apache.flink.api.common.operators.base.SortPartitionOperatorBase
 
sortReadMemory - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
The memory segments used first for sorting and later for reading/pre-fetching during the external merge.
sortSecondGroup(int, Order) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
Sorts Tuple elements within a group in the second input on the specified field in the specified Order.
Note: Only groups of Tuple elements and Pojos can be sorted.
Groups can be sorted by multiple fields by chaining CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction.sortSecondGroup(int, Order) calls.
sortSecondGroup(String, Order) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
Sorts Pojo or Tuple elements within a group in the second input on the specified field in the specified Order.
Groups can be sorted by multiple fields by chaining CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction.sortSecondGroup(String, Order) calls.
sortSecondGroup(int, Order) - Method in class org.apache.flink.api.scala.CoGroupDataSet
Adds a secondary sort key to the second input of this CoGroupDataSet.
sortSecondGroup(String, Order) - Method in class org.apache.flink.api.scala.CoGroupDataSet
Adds a secondary sort key to the second input of this CoGroupDataSet.
source - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact.Builder
 
source - Variable in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
 
source - Variable in class org.apache.flink.storm.util.InMemorySpout
 
SOURCE() - Method in class org.apache.flink.table.plan.cost.FlinkRelMdRowCount$
 
SOURCE() - Static method in class org.apache.flink.table.plan.cost.FlinkRelMdRowCount
 
sourceContext - Variable in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
The source context to emit records and watermarks to
SourceFunction<T> - Interface in org.apache.flink.streaming.api.functions.source
Base interface for all stream data sources in Flink.
SourceFunction.SourceContext<T> - Interface in org.apache.flink.streaming.api.functions.source
Interface that source functions use to emit elements, and possibly watermarks.
sourceId() - Method in class org.apache.flink.examples.scala.graph.PageRankBasic.AdjacencyList
 
sourceId() - Method in class org.apache.flink.examples.scala.graph.PageRankBasic.Link
 
SourcePartitionerMarker(String) - Constructor for class org.apache.flink.api.java.io.SplitDataProperties.SourcePartitionerMarker
 
SourcePlanNode - Class in org.apache.flink.optimizer.plan
Plan candidate node for data flow sources that have no input and no special strategies.
SourcePlanNode(DataSourceNode, String) - Constructor for class org.apache.flink.optimizer.plan.SourcePlanNode
Constructs a new source candidate node that uses NONE as its local strategy.
SourcePlanNode(DataSourceNode, String, GlobalProperties, LocalProperties) - Constructor for class org.apache.flink.optimizer.plan.SourcePlanNode
 
SourceStreamTask<OUT,SRC extends SourceFunction<OUT>,OP extends StreamSource<OUT,SRC>> - Class in org.apache.flink.streaming.runtime.tasks
StreamTask for executing a StreamSource.
SourceStreamTask() - Constructor for class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
 
SourceTransformation<T> - Class in org.apache.flink.streaming.api.transformations
This represents a Source.
SourceTransformation(String, StreamSource<T, ?>, TypeInformation<T>, int) - Constructor for class org.apache.flink.streaming.api.transformations.SourceTransformation
Creates a new SourceTransformation from the given operator.
SpanningRecordSerializer<T extends IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.serialization
Record serializer which serializes the complete record to an intermediate data serialization buffer and copies this buffer to target buffers one-by-one using SpanningRecordSerializer.setNextBuffer(Buffer).
SpanningRecordSerializer() - Constructor for class org.apache.flink.runtime.io.network.api.serialization.SpanningRecordSerializer
 
SparseMatrix - Class in org.apache.flink.ml.math
Sparse matrix using the compressed sparse column (CSC) representation.
SparseMatrix(int, int, int[], int[], double[]) - Constructor for class org.apache.flink.ml.math.SparseMatrix
 
SparseMatrix$ - Class in org.apache.flink.ml.math
 
SparseMatrix$() - Constructor for class org.apache.flink.ml.math.SparseMatrix$
 
SparseVector - Class in org.apache.flink.ml.math
Sparse vector implementation storing the data in two arrays.
SparseVector(int, int[], double[]) - Constructor for class org.apache.flink.ml.math.SparseVector
 
SparseVector$ - Class in org.apache.flink.ml.math
 
SparseVector$() - Constructor for class org.apache.flink.ml.math.SparseVector$
 
sparseVectorBuilder() - Method in class org.apache.flink.ml.math.VectorBuilder$
Type class implementation for SparseVector
sparseVectorConverter() - Method in class org.apache.flink.ml.math.SparseVector$
BreezeVectorConverter implementation for SparseVector
sparseVectorConverter() - Static method in class org.apache.flink.ml.math.SparseVector
BreezeVectorConverter implementation for SparseVector
SpecificInstanceCollectionSerializer(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.SpecificInstanceCollectionSerializer
 
SpecificInstanceCollectionSerializerForArrayList() - Constructor for class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.SpecificInstanceCollectionSerializerForArrayList
 
specificStartupOffsets - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumerBase
Specific startup offsets; only relevant when startup mode is StartupMode.SPECIFIC_OFFSETS
speed() - Method in class org.apache.flink.streaming.scala.examples.windowing.TopSpeedWindowing.CarEvent
 
spillHeadCopy - Variable in class org.apache.flink.runtime.operators.sort.AbstractMergeIterator
 
SpillingAdaptiveSpanningRecordDeserializer<T extends IOReadableWritable> - Class in org.apache.flink.runtime.io.network.api.serialization
 
SpillingAdaptiveSpanningRecordDeserializer(String[]) - Constructor for class org.apache.flink.runtime.io.network.api.serialization.SpillingAdaptiveSpanningRecordDeserializer
 
SpillingBuffer - Class in org.apache.flink.runtime.io.disk
An output view that buffers written data in memory pages and spills them when they are full.
SpillingBuffer(IOManager, MemorySegmentSource, int) - Constructor for class org.apache.flink.runtime.io.disk.SpillingBuffer
 
spillingMarker() - Static method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
Gets the element that is passed as marker for signal beginning of spilling.
SpillingResettableIterator<T> - Class in org.apache.flink.runtime.operators.resettable
Implementation of a resettable iterator.
SpillingResettableIterator(Iterator<T>, TypeSerializer<T>, MemoryManager, IOManager, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
SpillingResettableIterator(Iterator<T>, TypeSerializer<T>, MemoryManager, IOManager, List<MemorySegment>) - Constructor for class org.apache.flink.runtime.operators.resettable.SpillingResettableIterator
 
SpillingResettableMutableObjectIterator<T> - Class in org.apache.flink.runtime.operators.resettable
Implementation of a resettable iterator.
SpillingResettableMutableObjectIterator(MutableObjectIterator<T>, TypeSerializer<T>, MemoryManager, IOManager, int, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
SpillingResettableMutableObjectIterator(MutableObjectIterator<T>, TypeSerializer<T>, MemoryManager, IOManager, List<MemorySegment>) - Constructor for class org.apache.flink.runtime.operators.resettable.SpillingResettableMutableObjectIterator
 
SpillingThread(ExceptionHandler<IOException>, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable, MemoryManager, IOManager, TypeSerializer<E>, TypeComparator<E>, List<MemorySegment>, List<MemorySegment>, int) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Creates the spilling thread.
spillPartition(List<MemorySegment>, IOManager, FileIOChannel.ID, LinkedBlockingQueue<MemorySegment>) - Method in class org.apache.flink.runtime.operators.hash.HashPartition
Spills this partition to disk and sets it up such that it continues spilling records that are added to it.
spillPartition() - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable
Selects a partition and spills it.
split(OutputSelector<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Operator used for directing tuples to specific named outputs using an OutputSelector.
split(OutputSelector<T>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Operator used for directing tuples to specific named outputs using an OutputSelector.
split(Function1<T, TraversableOnce<String>>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Creates a new SplitStream that contains only the elements satisfying the given output selector predicate.
split(int) - Method in class org.apache.flink.util.LongValueSequenceIterator
 
split(int) - Method in class org.apache.flink.util.NumberSequenceIterator
 
split(int) - Method in class org.apache.flink.util.SplittableIterator
Splits this iterator into a number disjoint iterators.
splitData() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.NextInputSplit
 
SplitDataProperties<T> - Class in org.apache.flink.api.java.io
SplitDataProperties define data properties on InputSplit generated by the InputFormat of a DataSource.
SplitDataProperties(TypeInformation<T>) - Constructor for class org.apache.flink.api.java.io.SplitDataProperties
Creates SplitDataProperties for the given data types.
SplitDataProperties(DataSource<T>) - Constructor for class org.apache.flink.api.java.io.SplitDataProperties
Creates SplitDataProperties for the given data types.
SplitDataProperties.SourcePartitionerMarker<T> - Class in org.apache.flink.api.java.io
A custom partitioner to mark compatible split partitionings.
splitLength - Variable in class org.apache.flink.api.common.io.FileInputFormat
The length of the split that this parallel instance must consume.
splitsGroupedBy(int...) - Method in class org.apache.flink.api.java.io.SplitDataProperties
Defines that the data within an input split is grouped on the fields defined by the field positions.
splitsGroupedBy(String) - Method in class org.apache.flink.api.java.io.SplitDataProperties
Defines that the data within an input split is grouped on the fields defined by the field expressions.
splitsOrderedBy(int[], Order[]) - Method in class org.apache.flink.api.java.io.SplitDataProperties
Defines that the data within an input split is sorted on the fields defined by the field positions in the specified orders.
splitsOrderedBy(String, Order[]) - Method in class org.apache.flink.api.java.io.SplitDataProperties
Defines that the data within an input split is sorted on the fields defined by the field expressions in the specified orders.
splitsPartitionedBy(int...) - Method in class org.apache.flink.api.java.io.SplitDataProperties
Defines that data is partitioned across input splits on the fields defined by field positions.
splitsPartitionedBy(String, int...) - Method in class org.apache.flink.api.java.io.SplitDataProperties
Defines that data is partitioned using a specific partitioning method across input splits on the fields defined by field positions.
splitsPartitionedBy(String) - Method in class org.apache.flink.api.java.io.SplitDataProperties
Defines that data is partitioned across input splits on the fields defined by field expressions.
splitsPartitionedBy(String, String) - Method in class org.apache.flink.api.java.io.SplitDataProperties
Defines that data is partitioned using an identifiable method across input splits on the fields defined by field expressions.
splitStart - Variable in class org.apache.flink.api.common.io.FileInputFormat
The start of the split that this parallel instance must consume.
SplitStream<OUT> - Class in org.apache.flink.streaming.api.datastream
The SplitStream represents an operator that has been split using an OutputSelector.
SplitStream(DataStream<OUT>, OutputSelector<OUT>) - Constructor for class org.apache.flink.streaming.api.datastream.SplitStream
 
SplitStream<T> - Class in org.apache.flink.streaming.api.scala
The SplitStream represents an operator that has been split using an OutputSelector.
SplitStream(SplitStream<T>) - Constructor for class org.apache.flink.streaming.api.scala.SplitStream
 
SplitStreamMapper<T> - Class in org.apache.flink.storm.util
Strips SplitStreamType<T> away, ie, extracts the wrapped record of type T.
SplitStreamMapper() - Constructor for class org.apache.flink.storm.util.SplitStreamMapper
 
SplitStreamType<T> - Class in org.apache.flink.storm.util
Used by org.apache.flink.storm.wrappers.AbstractStormCollector to wrap output tuples if multiple output streams are declared.
SplitStreamType() - Constructor for class org.apache.flink.storm.util.SplitStreamType
 
SplittableIterator<T> - Class in org.apache.flink.util
Abstract base class for iterators that can split themselves into multiple disjoint iterators.
SplittableIterator() - Constructor for class org.apache.flink.util.SplittableIterator
 
Splitter - Class in org.apache.flink.ml.preprocessing
 
Splitter() - Constructor for class org.apache.flink.ml.preprocessing.Splitter
 
Splitter$ - Class in org.apache.flink.ml.preprocessing
 
Splitter$() - Constructor for class org.apache.flink.ml.preprocessing.Splitter$
 
Splitter.TrainTestDataSet<T> - Class in org.apache.flink.ml.preprocessing
 
Splitter.TrainTestDataSet$ - Class in org.apache.flink.ml.preprocessing
 
Splitter.TrainTestHoldoutDataSet<T> - Class in org.apache.flink.ml.preprocessing
 
Splitter.TrainTestHoldoutDataSet$ - Class in org.apache.flink.ml.preprocessing
 
SplitTransformation<T> - Class in org.apache.flink.streaming.api.transformations
This transformation represents a split of one DataStream into several DataStreams using an OutputSelector.
SplitTransformation(StreamTransformation<T>, OutputSelector<T>) - Constructor for class org.apache.flink.streaming.api.transformations.SplitTransformation
Creates a new SplitTransformation from the given input and OutputSelector.
spoutId - Static variable in class org.apache.flink.storm.exclamation.ExclamationTopology
 
spoutId - Static variable in class org.apache.flink.storm.wordcount.WordCountTopology
 
SpoutSourceWordCount - Class in org.apache.flink.storm.wordcount
Implements the "WordCount" program that computes a simple word occurrence histogram over text files in a streaming fashion.
SpoutSourceWordCount() - Constructor for class org.apache.flink.storm.wordcount.SpoutSourceWordCount
 
SpoutSourceWordCount.Tokenizer - Class in org.apache.flink.storm.wordcount
Implements the string tokenizer that splits sentences into words as a user-defined FlatMapFunction.
SpoutSplitExample - Class in org.apache.flink.storm.split
Implements a simple example with two declared output streams for the embedded spout.
SpoutSplitExample() - Constructor for class org.apache.flink.storm.split.SpoutSplitExample
 
SpoutSplitExample.Enrich - Class in org.apache.flink.storm.split
SpoutWrapper<OUT> - Class in org.apache.flink.storm.wrappers
A SpoutWrapper wraps an IRichSpout in order to execute it within a Flink Streaming program.
SpoutWrapper(IRichSpout) - Constructor for class org.apache.flink.storm.wrappers.SpoutWrapper
Instantiates a new SpoutWrapper that calls the nextTuple() method of the given spout in an infinite loop.
SpoutWrapper(IRichSpout, Integer) - Constructor for class org.apache.flink.storm.wrappers.SpoutWrapper
Instantiates a new SpoutWrapper that calls the nextTuple() method of the given spout a finite number of times.
SpoutWrapper(IRichSpout, String[]) - Constructor for class org.apache.flink.storm.wrappers.SpoutWrapper
Instantiates a new SpoutWrapper that calls the nextTuple() method of the given spout in an infinite loop.
SpoutWrapper(IRichSpout, String[], Integer) - Constructor for class org.apache.flink.storm.wrappers.SpoutWrapper
Instantiates a new SpoutWrapper that calls the nextTuple() method of the given spout a finite number of times.
SpoutWrapper(IRichSpout, Collection<String>) - Constructor for class org.apache.flink.storm.wrappers.SpoutWrapper
Instantiates a new SpoutWrapper that calls the nextTuple() method of the given spout in an infinite loop.
SpoutWrapper(IRichSpout, Collection<String>, Integer) - Constructor for class org.apache.flink.storm.wrappers.SpoutWrapper
Instantiates a new SpoutWrapper that calls the nextTuple() method of the given spout a finite number of times.
SpoutWrapper(IRichSpout, String, Collection<String>, Integer) - Constructor for class org.apache.flink.storm.wrappers.SpoutWrapper
Instantiates a new SpoutWrapper that calls the nextTuple() method of the given spout a finite number of times.
sql(String) - Method in class org.apache.flink.table.api.TableEnvironment
Evaluates a SQL query on registered tables and retrieves the result as a Table.
SQL2REL_LOGGER - Static variable in class org.apache.calcite.sql2rel.SqlToRelConverter
 
SQL_DATE - Static variable in class org.apache.flink.api.common.typeinfo.Types
 
SQL_DATE() - Method in class org.apache.flink.table.api.Types$
 
SQL_DATE() - Static method in class org.apache.flink.table.api.Types
 
SQL_DATE() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
SQL_DATE() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
SQL_TIME - Static variable in class org.apache.flink.api.common.typeinfo.Types
 
SQL_TIME() - Method in class org.apache.flink.table.api.Types$
 
SQL_TIME() - Static method in class org.apache.flink.table.api.Types
 
SQL_TIME() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
SQL_TIME() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
SQL_TIMESTAMP - Static variable in class org.apache.flink.api.common.typeinfo.Types
 
SQL_TIMESTAMP() - Method in class org.apache.flink.table.api.Types$
 
SQL_TIMESTAMP() - Static method in class org.apache.flink.table.api.Types
 
SQL_TIMESTAMP() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
SQL_TIMESTAMP() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
sqlDate2Literal(Date) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionConversions
 
SqlDateParser - Class in org.apache.flink.types.parser
Parses a text field into a Date.
SqlDateParser() - Constructor for class org.apache.flink.types.parser.SqlDateParser
 
SqlDateSerializer - Class in org.apache.flink.api.common.typeutils.base
 
SqlDateSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.SqlDateSerializer
 
sqlOperator() - Method in class org.apache.flink.table.expressions.BinaryArithmetic
 
sqlOperator() - Method in class org.apache.flink.table.expressions.BinaryComparison
 
sqlOperator() - Method in class org.apache.flink.table.expressions.Div
 
sqlOperator() - Method in class org.apache.flink.table.expressions.EqualTo
 
sqlOperator() - Method in class org.apache.flink.table.expressions.GreaterThan
 
sqlOperator() - Method in class org.apache.flink.table.expressions.GreaterThanOrEqual
 
sqlOperator() - Method in class org.apache.flink.table.expressions.LessThan
 
sqlOperator() - Method in class org.apache.flink.table.expressions.LessThanOrEqual
 
sqlOperator() - Method in class org.apache.flink.table.expressions.Minus
 
sqlOperator() - Method in class org.apache.flink.table.expressions.Mod
 
sqlOperator() - Method in class org.apache.flink.table.expressions.Mul
 
sqlOperator() - Method in class org.apache.flink.table.expressions.NotEqualTo
 
sqlOperator() - Method in class org.apache.flink.table.expressions.Plus
 
SqlParserException - Exception in org.apache.flink.table.api
Exception for all errors occurring during sql parsing.
SqlParserException(String, Throwable) - Constructor for exception org.apache.flink.table.api.SqlParserException
 
SqlParserException(String) - Constructor for exception org.apache.flink.table.api.SqlParserException
 
SqlParserException$ - Class in org.apache.flink.table.api
 
SqlParserException$() - Constructor for class org.apache.flink.table.api.SqlParserException$
 
SqlStdOperatorTable - Class in org.apache.calcite.sql.fun
Implementation of SqlOperatorTable containing the standard operators and functions.
SqlStdOperatorTable() - Constructor for class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
sqlTime2Literal(Time) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionConversions
 
SqlTimeParser - Class in org.apache.flink.types.parser
Parses a text field into a Time.
SqlTimeParser() - Constructor for class org.apache.flink.types.parser.SqlTimeParser
 
SqlTimeSerializer - Class in org.apache.flink.api.common.typeutils.base
 
SqlTimeSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.SqlTimeSerializer
 
sqlTimestamp2Literal(Timestamp) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionConversions
 
SqlTimestampComparator - Class in org.apache.flink.api.common.typeutils.base
Comparator for comparing Java SQL Timestamps.
SqlTimestampComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.SqlTimestampComparator
 
SqlTimestampParser - Class in org.apache.flink.types.parser
Parses a text field into a Timestamp.
SqlTimestampParser() - Constructor for class org.apache.flink.types.parser.SqlTimestampParser
 
SqlTimestampSerializer - Class in org.apache.flink.api.common.typeutils.base
 
SqlTimestampSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.SqlTimestampSerializer
 
SqlTimeTypeInfo<T> - Class in org.apache.flink.api.common.typeinfo
Type information for Java SQL Date/Time/Timestamp.
SqlTimeTypeInfo(Class<T>, TypeSerializer<T>, Class<? extends TypeComparator<T>>) - Constructor for class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
SqlToRelConverter - Class in org.apache.calcite.sql2rel
Converts a SQL parse tree (consisting of SqlNode objects) into a relational algebra expression (consisting of RelNode objects).
SqlToRelConverter(RelOptTable.ViewExpander, SqlValidator, Prepare.CatalogReader, RelOptPlanner, RexBuilder, SqlRexConvertletTable) - Constructor for class org.apache.calcite.sql2rel.SqlToRelConverter
Deprecated.
SqlToRelConverter(RelOptTable.ViewExpander, SqlValidator, Prepare.CatalogReader, RelOptCluster, SqlRexConvertletTable) - Constructor for class org.apache.calcite.sql2rel.SqlToRelConverter
Deprecated.
SqlToRelConverter(RelOptTable.ViewExpander, SqlValidator, Prepare.CatalogReader, RelOptCluster, SqlRexConvertletTable, SqlToRelConverter.Config) - Constructor for class org.apache.calcite.sql2rel.SqlToRelConverter
 
SqlToRelConverter.AggConverter - Class in org.apache.calcite.sql2rel
Converts expressions to aggregates.
SqlToRelConverter.Blackboard - Class in org.apache.calcite.sql2rel
Workspace for translating an individual SELECT statement (or sub-SELECT).
SqlToRelConverter.Config - Interface in org.apache.calcite.sql2rel
Interface to define the configuration for a SqlToRelConverter.
SqlToRelConverter.ConfigBuilder - Class in org.apache.calcite.sql2rel
SqlUserDefinedAggFunction - Class in org.apache.calcite.sql.validate
User-defined aggregate function.
SqlUserDefinedAggFunction(SqlIdentifier, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker, AggregateFunction) - Constructor for class org.apache.calcite.sql.validate.SqlUserDefinedAggFunction
 
SqlUserDefinedAggFunction(SqlIdentifier, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker, AggregateFunction, Boolean) - Constructor for class org.apache.calcite.sql.validate.SqlUserDefinedAggFunction
 
SQRT - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
sqrt() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Calculates the square root of a given value.
Sqrt - Class in org.apache.flink.table.expressions
 
Sqrt(Expression) - Constructor for class org.apache.flink.table.expressions.Sqrt
 
Sqrt$ - Class in org.apache.flink.table.expressions
 
Sqrt$() - Constructor for class org.apache.flink.table.expressions.Sqrt$
 
SquaredEuclideanDistanceMetric - Class in org.apache.flink.ml.metrics.distances
This class is like EuclideanDistanceMetric but it does not take the square root.
SquaredEuclideanDistanceMetric() - Constructor for class org.apache.flink.ml.metrics.distances.SquaredEuclideanDistanceMetric
 
SquaredEuclideanDistanceMetric$ - Class in org.apache.flink.ml.metrics.distances
 
SquaredEuclideanDistanceMetric$() - Constructor for class org.apache.flink.ml.metrics.distances.SquaredEuclideanDistanceMetric$
 
SquaredLoss - Class in org.apache.flink.ml.optimization
Squared loss function which can be used with the GenericLossFunction
SquaredLoss() - Constructor for class org.apache.flink.ml.optimization.SquaredLoss
 
SquaredLoss$ - Class in org.apache.flink.ml.optimization
Squared loss function which can be used with the GenericLossFunction
SquaredLoss$() - Constructor for class org.apache.flink.ml.optimization.SquaredLoss$
 
squaredResidualSum(DataSet<LabeledVector>) - Method in class org.apache.flink.ml.regression.MultipleLinearRegression
 
SRC_EDGE_TO_BE_REMOVED - Static variable in class org.apache.flink.graph.examples.data.IncrementalSSSPData
 
SRC_VERTEX_ID - Static variable in class org.apache.flink.graph.examples.data.SingleSourceShortestPathsData
 
SSLStoreOverlay - Class in org.apache.flink.runtime.clusterframework.overlays
Overlays an SSL keystore/truststore into a container.
SSLStoreOverlay(File, File) - Constructor for class org.apache.flink.runtime.clusterframework.overlays.SSLStoreOverlay
 
SSLStoreOverlay.Builder - Class in org.apache.flink.runtime.clusterframework.overlays
A builder for the Krb5ConfOverlay.
SSLUtils - Class in org.apache.flink.runtime.net
Common utilities to manage SSL transport settings
SSLUtils() - Constructor for class org.apache.flink.runtime.net.SSLUtils
 
SSSPCombiner() - Constructor for class org.apache.flink.graph.examples.PregelSSSP.SSSPCombiner
 
SSSPComputeFunction(long) - Constructor for class org.apache.flink.graph.examples.PregelSSSP.SSSPComputeFunction
 
StackTrace - Class in org.apache.flink.runtime.messages
 
StackTrace(InstanceID, String) - Constructor for class org.apache.flink.runtime.messages.StackTrace
 
StackTrace(InstanceID, String) - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages.StackTrace
 
stackTrace() - Method in class org.apache.flink.runtime.messages.TaskManagerMessages.StackTrace
 
StackTrace$() - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages.StackTrace$
 
StackTraceSample - Class in org.apache.flink.runtime.webmonitor
A sample of stack traces for one or more tasks.
StackTraceSample(int, long, long, Map<ExecutionAttemptID, List<StackTraceElement[]>>) - Constructor for class org.apache.flink.runtime.webmonitor.StackTraceSample
Creates a stack trace sample
StackTraceSampleCoordinator - Class in org.apache.flink.runtime.webmonitor
A coordinator for triggering and collecting stack traces of running tasks.
StackTraceSampleCoordinator(Executor, long) - Constructor for class org.apache.flink.runtime.webmonitor.StackTraceSampleCoordinator
Creates a new coordinator for the job.
StackTraceSampleMessages - Class in org.apache.flink.runtime.messages
A set of messages exchanged with task manager instances in order to sample the stack traces of running tasks.
StackTraceSampleMessages() - Constructor for class org.apache.flink.runtime.messages.StackTraceSampleMessages
 
StackTraceSampleMessages$ - Class in org.apache.flink.runtime.messages
A set of messages exchanged with task manager instances in order to sample the stack traces of running tasks.
StackTraceSampleMessages$() - Constructor for class org.apache.flink.runtime.messages.StackTraceSampleMessages$
 
StackTraceSampleMessages.SampleTaskStackTrace - Class in org.apache.flink.runtime.messages
Task manager internal sample message.
StackTraceSampleMessages.SampleTaskStackTrace$ - Class in org.apache.flink.runtime.messages
 
StackTraceSampleMessages.StackTraceSampleMessages - Interface in org.apache.flink.runtime.messages
 
StackTraceSampleMessages.TriggerStackTraceSample - Class in org.apache.flink.runtime.messages
Triggers the sampling of a running task (sent by the job manager to the task managers).
StackTraceSampleMessages.TriggerStackTraceSample$ - Class in org.apache.flink.runtime.messages
 
StackTraceSampleResponse - Class in org.apache.flink.runtime.messages
Response to the TriggerStackTraceSample message.
StackTraceSampleResponse(int, ExecutionAttemptID, List<StackTraceElement[]>) - Constructor for class org.apache.flink.runtime.messages.StackTraceSampleResponse
 
Staging$() - Constructor for class org.apache.flink.mesos.scheduler.TaskMonitor.Staging$
 
StandaloneCheckpointIDCounter - Class in org.apache.flink.runtime.checkpoint
CheckpointIDCounter instances for JobManagers running in HighAvailabilityMode.NONE.
StandaloneCheckpointIDCounter() - Constructor for class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
 
StandaloneCheckpointRecoveryFactory - Class in org.apache.flink.runtime.checkpoint
StandaloneCheckpointRecoveryFactory() - Constructor for class org.apache.flink.runtime.checkpoint.StandaloneCheckpointRecoveryFactory
 
StandaloneClusterClient - Class in org.apache.flink.client.program
Cluster client for communication with an standalone (on-premise) cluster or an existing cluster that has been brought up independently of a specific job.
StandaloneClusterClient(Configuration) - Constructor for class org.apache.flink.client.program.StandaloneClusterClient
 
StandaloneClusterClient(Configuration, HighAvailabilityServices) - Constructor for class org.apache.flink.client.program.StandaloneClusterClient
 
StandaloneClusterDescriptor - Class in org.apache.flink.client.deployment
A deployment descriptor for an existing cluster
StandaloneClusterDescriptor(Configuration) - Constructor for class org.apache.flink.client.deployment.StandaloneClusterDescriptor
 
StandaloneCompletedCheckpointStore - Class in org.apache.flink.runtime.checkpoint
StandaloneCompletedCheckpointStore(int) - Constructor for class org.apache.flink.runtime.checkpoint.StandaloneCompletedCheckpointStore
StandaloneHaServices - Class in org.apache.flink.runtime.highavailability.nonha.standalone
An implementation of the HighAvailabilityServices for the non-high-availability case.
StandaloneHaServices(String, String) - Constructor for class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneHaServices
Creates a new services class for the fix pre-defined leaders.
StandaloneLeaderElectionService - Class in org.apache.flink.runtime.leaderelection
Standalone implementation of the LeaderElectionService interface.
StandaloneLeaderElectionService() - Constructor for class org.apache.flink.runtime.leaderelection.StandaloneLeaderElectionService
 
StandaloneLeaderRetrievalService - Class in org.apache.flink.runtime.leaderretrieval
Standalone implementation of the LeaderRetrievalService.
StandaloneLeaderRetrievalService(String) - Constructor for class org.apache.flink.runtime.leaderretrieval.StandaloneLeaderRetrievalService
StandaloneLeaderRetrievalService(String, UUID) - Constructor for class org.apache.flink.runtime.leaderretrieval.StandaloneLeaderRetrievalService
Creates a StandaloneLeaderRetrievalService with the given leader address.
StandaloneMesosServices - Class in org.apache.flink.mesos.runtime.clusterframework.services
MesosServices implementation for the standalone mode.
StandaloneMesosServices() - Constructor for class org.apache.flink.mesos.runtime.clusterframework.services.StandaloneMesosServices
 
StandaloneMesosWorkerStore - Class in org.apache.flink.mesos.runtime.clusterframework.store
A standalone Mesos worker store.
StandaloneMesosWorkerStore() - Constructor for class org.apache.flink.mesos.runtime.clusterframework.store.StandaloneMesosWorkerStore
 
StandaloneMiniCluster - Class in org.apache.flink.runtime.minicluster
Mini cluster to run the old JobManager code without embedded high availability services.
StandaloneMiniCluster(Configuration) - Constructor for class org.apache.flink.runtime.minicluster.StandaloneMiniCluster
 
StandaloneResourceManager - Class in org.apache.flink.runtime.clusterframework.standalone
A standalone implementation of the resource manager.
StandaloneResourceManager(Configuration, LeaderRetrievalService) - Constructor for class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
 
StandaloneResourceManager - Class in org.apache.flink.runtime.resourcemanager
A standalone implementation of the resource manager.
StandaloneResourceManager(RpcService, String, ResourceID, ResourceManagerConfiguration, HighAvailabilityServices, HeartbeatServices, SlotManager, MetricRegistry, JobLeaderIdService, FatalErrorHandler) - Constructor for class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
 
StandaloneRunningJobsRegistry - Class in org.apache.flink.runtime.highavailability.nonha.standalone
A registry for running jobs, not-highly available.
StandaloneRunningJobsRegistry() - Constructor for class org.apache.flink.runtime.highavailability.nonha.standalone.StandaloneRunningJobsRegistry
 
StandaloneSubmittedJobGraphStore - Class in org.apache.flink.runtime.jobmanager
SubmittedJobGraph instances for JobManagers running in HighAvailabilityMode.NONE.
StandaloneSubmittedJobGraphStore() - Constructor for class org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
 
StandaloneUtils - Class in org.apache.flink.runtime.util
Utility class to work with Flink standalone mode.
StandardNiFiDataPacket - Class in org.apache.flink.streaming.connectors.nifi
An implementation of NiFiDataPacket.
StandardNiFiDataPacket(byte[], Map<String, String>) - Constructor for class org.apache.flink.streaming.connectors.nifi.StandardNiFiDataPacket
 
StandardScaler - Class in org.apache.flink.ml.preprocessing
Scales observations, so that all features have a user-specified mean and standard deviation.
StandardScaler() - Constructor for class org.apache.flink.ml.preprocessing.StandardScaler
 
StandardScaler$ - Class in org.apache.flink.ml.preprocessing
 
StandardScaler$() - Constructor for class org.apache.flink.ml.preprocessing.StandardScaler$
 
StandardScaler.Mean$ - Class in org.apache.flink.ml.preprocessing
 
StandardScaler.StandardScalerTransformOperation<T> - Class in org.apache.flink.ml.preprocessing
Base class for StandardScaler's TransformOperation.
StandardScaler.Std$ - Class in org.apache.flink.ml.preprocessing
 
StandardScalerTransformOperation(TypeInformation<T>, ClassTag<T>) - Constructor for class org.apache.flink.ml.preprocessing.StandardScaler.StandardScalerTransformOperation
 
STAR() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
STAR() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
StarGraph - Class in org.apache.flink.graph.drivers.input
Generate a StarGraph.
StarGraph() - Constructor for class org.apache.flink.graph.drivers.input.StarGraph
 
StarGraph - Class in org.apache.flink.graph.generator
 
StarGraph(ExecutionEnvironment, long) - Constructor for class org.apache.flink.graph.generator.StarGraph
An undirected with n vertices where the single central node has degree n-1, connecting to the other n-1 vertices which have degree 1.
start() - Method in class org.apache.flink.api.common.PlanExecutor
Starts the program executor.
start() - Method in class org.apache.flink.client.LocalExecutor
 
start() - Method in class org.apache.flink.client.RemoteExecutor
 
start() - Method in interface org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore
Start the worker store.
start() - Method in class org.apache.flink.mesos.runtime.clusterframework.store.StandaloneMesosWorkerStore
 
start() - Method in class org.apache.flink.mesos.runtime.clusterframework.store.ZooKeeperMesosWorkerStore
 
Start() - Constructor for class org.apache.flink.mesos.scheduler.ConnectionMonitor.Start
 
start() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointIDCounter
Starts the CheckpointIDCounter service down.
start() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointRecoveryFactory
Starts the CheckpointRecoveryFactory service.
start() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointIDCounter
 
start() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointRecoveryFactory
 
start() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
 
start() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointRecoveryFactory
 
start(LeaderContender) - Method in class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
 
start() - Method in class org.apache.flink.runtime.instance.SlotPool
 
start(UUID, String) - Method in class org.apache.flink.runtime.instance.SlotPool
Start the slot pool to accept RPC calls.
start(ResultPartitionProvider, TaskEventDispatcher) - Method in interface org.apache.flink.runtime.io.network.ConnectionManager
 
start(ResultPartitionProvider, TaskEventDispatcher) - Method in class org.apache.flink.runtime.io.network.LocalConnectionManager
 
start(ResultPartitionProvider, TaskEventDispatcher) - Method in class org.apache.flink.runtime.io.network.netty.NettyConnectionManager
 
start() - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
start() - Method in class org.apache.flink.runtime.jobmanager.JobInfo
 
start(SubmittedJobGraphStore.SubmittedJobGraphListener) - Method in class org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
 
start(SubmittedJobGraphStore.SubmittedJobGraphListener) - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
Starts the SubmittedJobGraphStore service.
start(SubmittedJobGraphStore.SubmittedJobGraphListener) - Method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
 
start() - Method in class org.apache.flink.runtime.jobmaster.JobManagerRunner
 
start() - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
start(UUID) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
Start the rpc service and begin to run the job.
start(LeaderContender) - Method in interface org.apache.flink.runtime.leaderelection.LeaderElectionService
Starts the leader election service.
start(LeaderContender) - Method in class org.apache.flink.runtime.leaderelection.StandaloneLeaderElectionService
 
start(LeaderContender) - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
 
start(LeaderRetrievalListener) - Method in interface org.apache.flink.runtime.leaderretrieval.LeaderRetrievalService
Starts the leader retrieval service with the given listener to listen for new leaders.
start(LeaderRetrievalListener) - Method in class org.apache.flink.runtime.leaderretrieval.StandaloneLeaderRetrievalService
 
start(LeaderRetrievalListener) - Method in class org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalService
 
start() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
start(boolean) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
start() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
Starts the mini cluster, based on the configured properties.
start() - Method in interface org.apache.flink.runtime.query.KvStateLocationLookupService
Starts the lookup service.
start() - Method in class org.apache.flink.runtime.query.netty.KvStateServer
Starts the server by binding to the configured bind address (blocking).
start() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
 
start(JobLeaderIdActions) - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
Start the service with the given job leader actions.
start() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
start() - Method in class org.apache.flink.runtime.resourcemanager.ResourceManagerRunner
 
start(UUID, Executor, ResourceManagerActions) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Starts the slot manager with the given leader id and resource manager actions.
start() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
Starts the rpc endpoint.
start() - Method in interface org.apache.flink.runtime.rpc.StartStoppable
Starts the processing of remote procedure calls.
start(String, RpcService, HighAvailabilityServices, JobLeaderListener) - Method in class org.apache.flink.runtime.taskexecutor.JobLeaderService
Start the job leader service with the given services.
start(SlotActions) - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Start the task slot table with the given slot actions and slot timeout value.
start(TimeoutListener<K>) - Method in class org.apache.flink.runtime.taskexecutor.slot.TimerService
 
start() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
start() - Method in class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
 
start(String) - Method in interface org.apache.flink.runtime.webmonitor.WebMonitor
Starts the web monitor.
start(String) - Method in class org.apache.flink.runtime.webmonitor.WebRuntimeMonitor
 
start() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedCount
 
start() - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedValue
 
start() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Returns the start time (inclusive) of a window when applied on a window reference.
Start$() - Constructor for class org.apache.flink.mesos.scheduler.ConnectionMonitor.Start$
 
startActorSystem(Configuration, String, String, Logger) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
Starts an ActorSystem with the given configuration listening at the address/ports.
startActorSystem(Configuration, String, int, Logger) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
Starts an Actor System at a specific port.
startActorSystem(Configuration, String, int) - Method in class org.apache.flink.runtime.jobmanager.JobManager$
Starts the JobManager actor system.
startActorSystem(Configuration, String, int) - Static method in class org.apache.flink.runtime.jobmanager.JobManager
Starts the JobManager actor system.
startAppMaster(JobGraph, YarnClient, YarnClientApplication) - Method in class org.apache.flink.yarn.AbstractYarnClusterDescriptor
 
startArray() - Method in class org.apache.flink.contrib.tweetinputformat.io.TweetHandler
 
startCheckpointScheduler() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
startCluster() - Method in class org.apache.flink.test.util.AbstractTestBase
 
startCluster(int, int, boolean, boolean, boolean) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
startCluster(Configuration, boolean) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
startCuratorFramework(Configuration) - Static method in class org.apache.flink.mesos.util.ZooKeeperUtils
Starts a CuratorFramework instance and connects it to the given ZooKeeper quorum.
startCuratorFramework(Configuration) - Static method in class org.apache.flink.runtime.util.ZooKeeperUtils
Starts a CuratorFramework instance and connects it to the given ZooKeeper quorum.
starting() - Method in class org.apache.flink.table.expressions.Overlay
 
startItem() - Method in class org.apache.flink.api.avro.DataOutputEncoder
 
startItem() - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
startJobClientActorSystem(Configuration) - Static method in class org.apache.flink.runtime.client.JobClient
 
startJobClientActorSystem(JobID) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
startJobExecution() - Method in class org.apache.flink.runtime.jobmaster.JobMaster
 
startJobExecution() - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
 
startJobManager(int, ActorSystem) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
startJobManager(int, ActorSystem) - Method in class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
startJobManagerActors(ActorSystem, Configuration, JobManagerMode, String, ScheduledExecutorService, Executor, HighAvailabilityServices, Class<? extends JobManager>, Class<? extends MemoryArchivist>, Option<Class<? extends FlinkResourceManager<?>>>) - Method in class org.apache.flink.runtime.jobmanager.JobManager$
Starts the JobManager and all its components including the WebMonitor.
startJobManagerActors(Configuration, ActorSystem, ScheduledExecutorService, Executor, HighAvailabilityServices, Class<? extends JobManager>, Class<? extends MemoryArchivist>) - Method in class org.apache.flink.runtime.jobmanager.JobManager$
Starts the JobManager and job archiver based on the given configuration, in the given actor system.
startJobManagerActors(Configuration, ActorSystem, ScheduledExecutorService, Executor, HighAvailabilityServices, Option<String>, Option<String>, Class<? extends JobManager>, Class<? extends MemoryArchivist>) - Method in class org.apache.flink.runtime.jobmanager.JobManager$
Starts the JobManager and job archiver based on the given configuration, in the given actor system.
startJobManagerActors(ActorSystem, Configuration, JobManagerMode, String, ScheduledExecutorService, Executor, HighAvailabilityServices, Class<? extends JobManager>, Class<? extends MemoryArchivist>, Option<Class<? extends FlinkResourceManager<?>>>) - Static method in class org.apache.flink.runtime.jobmanager.JobManager
Starts the JobManager and all its components including the WebMonitor.
startJobManagerActors(Configuration, ActorSystem, ScheduledExecutorService, Executor, HighAvailabilityServices, Class<? extends JobManager>, Class<? extends MemoryArchivist>) - Static method in class org.apache.flink.runtime.jobmanager.JobManager
Starts the JobManager and job archiver based on the given configuration, in the given actor system.
startJobManagerActors(Configuration, ActorSystem, ScheduledExecutorService, Executor, HighAvailabilityServices, Option<String>, Option<String>, Class<? extends JobManager>, Class<? extends MemoryArchivist>) - Static method in class org.apache.flink.runtime.jobmanager.JobManager
Starts the JobManager and job archiver based on the given configuration, in the given actor system.
startJobManagerActorSystem(int) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
startJSON() - Method in class org.apache.flink.contrib.tweetinputformat.io.TweetHandler
 
startMetricQueryService(ActorSystem, ResourceID) - Static method in class org.apache.flink.runtime.metrics.dump.MetricQueryService
Starts the MetricQueryService actor in the given actor system.
startNewChain() - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Starts a new task chain beginning at this operator.
startNewChain() - Method in class org.apache.flink.streaming.api.scala.DataStream
Starts a new task chain beginning at this operator.
startNewKey(K) - Method in interface org.apache.flink.streaming.runtime.operators.windowing.KeyMap.TraversalEvaluator
Called whenever the traversal starts with a new key.
startNewKeyGroup(int) - Method in class org.apache.flink.runtime.state.KeyedStateCheckpointOutputStream
User code can call this method to signal that it begins to write a new key group with the given key group id.
startNewPartition() - Method in class org.apache.flink.runtime.state.OperatorStateCheckpointOutputStream
User code can call this method to signal that it begins to write a new partition of operator state.
startNewSession() - Method in class org.apache.flink.api.java.CollectionEnvironment
 
startNewSession() - Method in class org.apache.flink.api.java.ExecutionEnvironment
Starts a new session, discarding the previous data flow and all of its intermediate results.
startNewSession() - Method in class org.apache.flink.api.java.LocalEnvironment
 
startNewSession() - Method in class org.apache.flink.api.java.RemoteEnvironment
 
startNewSession() - Method in class org.apache.flink.api.scala.ExecutionEnvironment
Starts a new session, discarding all intermediate results.
startNewSession() - Method in class org.apache.flink.client.program.ContextEnvironment
 
startNewSession() - Method in class org.apache.flink.client.program.OptimizerPlanEnvironment
 
startNewSession() - Method in class org.apache.flink.client.program.PreviewPlanEnvironment
 
startNewSession() - Method in class org.apache.flink.test.util.TestEnvironment
 
startNewWorker(ResourceProfile) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
Allocates a resource using the resource profile.
startNewWorker(ResourceProfile) - Method in class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
 
startNewWorker(ResourceProfile) - Method in class org.apache.flink.yarn.YarnResourceManager
 
startNextSuperstep() - Method in class org.apache.flink.runtime.io.network.api.reader.AbstractReader
 
startNextSuperstep() - Method in interface org.apache.flink.runtime.io.network.api.reader.ReaderBase
 
startObject() - Method in class org.apache.flink.contrib.tweetinputformat.io.TweetHandler
 
startObjectEntry(String) - Method in class org.apache.flink.contrib.tweetinputformat.io.TweetHandler
 
startQueryService(ActorSystem, ResourceID) - Method in class org.apache.flink.runtime.metrics.MetricRegistry
Initializes the MetricQueryService.
startReading() - Method in class org.apache.flink.runtime.operators.TempBarrier
 
startRecord() - Method in class org.apache.flink.api.common.io.BinaryOutputFormat.BlockBasedOutput
 
startRegistration() - Method in class org.apache.flink.runtime.registration.RetryingRegistration
This method resolves the target address to a callable gateway and starts the registration after that.
startResourceManager(int, ActorSystem) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
startResourceManager(int, ActorSystem) - Method in class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
startResourceManagerActors(Configuration, ActorSystem, LeaderRetrievalService, Class<? extends FlinkResourceManager<?>>) - Static method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Starts the resource manager actors.
startResourceManagerActors(Configuration, ActorSystem, LeaderRetrievalService, Class<? extends FlinkResourceManager<?>>, String) - Static method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Starts the resource manager actors.
startResourceManagerActorSystem(int) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
startResourceManagers(Configuration, HighAvailabilityServices, HeartbeatServices, MetricRegistry, int, RpcService[]) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
 
startServer(S) - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
startServer(S) - Method in interface org.apache.flink.runtime.rpc.RpcService
Start a rpc server which forwards the remote procedure calls to the provided rpc endpoint.
startShell(FlinkShell.Config) - Method in class org.apache.flink.api.scala.FlinkShell$
 
startShell(FlinkShell.Config) - Static method in class org.apache.flink.api.scala.FlinkShell
 
StartStoppable - Interface in org.apache.flink.runtime.rpc
Interface to start and stop the processing of rpc calls in the rpc server.
startsWith(CharSequence, int) - Method in class org.apache.flink.types.StringValue
Checks whether the substring, starting at the specified index, starts with the given prefix string.
startsWith(CharSequence) - Method in class org.apache.flink.types.StringValue
Checks whether this StringValue starts with the given prefix string.
startTaskManager(int, ActorSystem) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
startTaskManager(int, ActorSystem) - Method in class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
startTaskManagerActorSystem(int) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
startTaskManagerComponentsAndActor(Configuration, ResourceID, ActorSystem, HighAvailabilityServices, String, Option<String>, boolean, Class<? extends TaskManager>) - Method in class org.apache.flink.runtime.taskmanager.TaskManager$
Starts the task manager actor.
startTaskManagerComponentsAndActor(Configuration, ResourceID, ActorSystem, HighAvailabilityServices, String, Option<String>, boolean, Class<? extends TaskManager>) - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
Starts the task manager actor.
startTaskManagers(Configuration, HighAvailabilityServices, MetricRegistry, int, RpcService[]) - Method in class org.apache.flink.runtime.minicluster.MiniCluster
 
startTaskThread() - Method in class org.apache.flink.runtime.taskmanager.Task
Starts the task's thread.
startThreads() - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
Starts all the threads that are used by this sort-merger.
startTimerService(TypeSerializer<K>, TypeSerializer<N>, Triggerable<K, N>) - Method in class org.apache.flink.streaming.api.operators.HeapInternalTimerService
Starts the local HeapInternalTimerService by: Setting the keySerialized and namespaceSerializer for the timers it will contain. Setting the triggerTarget which contains the action to be performed when a timer fires. Re-registering timers that were retrieved after recoveting from a node failure, if any. This method can be called multiple times, as long as it is called with the same serializers.
STARTUP_CONNECT_LOG_SUPPRESS() - Method in class org.apache.flink.runtime.taskmanager.TaskManager$
Time (milli seconds) after which the TaskManager will start logging failed
STARTUP_CONNECT_LOG_SUPPRESS() - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
Time (milli seconds) after which the TaskManager will start logging failed
STARTUP_FAILURE_RETURN_CODE() - Method in class org.apache.flink.runtime.jobmanager.JobManager$
 
STARTUP_FAILURE_RETURN_CODE() - Static method in class org.apache.flink.runtime.jobmanager.JobManager
 
STARTUP_FAILURE_RETURN_CODE() - Method in class org.apache.flink.runtime.taskmanager.TaskManager$
Return code for unsuccessful TaskManager startup
STARTUP_FAILURE_RETURN_CODE() - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
Return code for unsuccessful TaskManager startup
StartupMode - Enum in org.apache.flink.streaming.connectors.kafka.config
Startup modes for the Kafka Consumer.
startWebMonitorIfConfigured(Configuration, HighAvailabilityServices, ActorSystem, ActorRef, Logger) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
Starts the web frontend.
startWebRuntimeMonitor(Configuration, HighAvailabilityServices, ActorSystem) - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorUtils
Starts the web runtime monitor.
startWebServer(Configuration, ActorSystem, String) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
startWebServer - Static variable in class org.apache.flink.test.util.MultipleProgramsTestBase
 
startWith(S, D, Option<FiniteDuration>) - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
startWith(S, D, Option<FiniteDuration>) - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
startWith(S, D, Option<FiniteDuration>) - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
startWith(S, D, Option<FiniteDuration>) - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
startWith$default$3() - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
startWith$default$3() - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
startWith$default$3() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
startWith$default$3() - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
StartYarnSession(Configuration, int) - Constructor for class org.apache.flink.yarn.YarnMessages.StartYarnSession
 
StartYarnSession$() - Constructor for class org.apache.flink.yarn.YarnMessages.StartYarnSession$
 
State - Interface in org.apache.flink.api.common.state
Interface that different types of partitioned state must implement.
State<T> - Class in org.apache.flink.cep.nfa
Represents a state of the NFA.
State(String, State.StateType) - Constructor for class org.apache.flink.cep.nfa.State
 
state() - Method in class org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore.Worker
Get the worker's state.
state() - Method in class org.apache.flink.mesos.scheduler.TaskMonitor.TaskGoalStateUpdated
 
State.StateType - Enum in org.apache.flink.cep.nfa
Set of valid state types.
STATE_BACKEND - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
STATE_BACKEND - Static variable in class org.apache.flink.configuration.CoreOptions
 
StateAssignmentOperation - Class in org.apache.flink.runtime.checkpoint
This class encapsulates the operation of assigning restored state when restoring from a checkpoint.
StateAssignmentOperation(Map<JobVertexID, ExecutionJobVertex>, Map<OperatorID, OperatorState>, boolean) - Constructor for class org.apache.flink.runtime.checkpoint.StateAssignmentOperation
 
StateBackend - Interface in org.apache.flink.runtime.state
A State Backend defines how the state of a streaming application is stored and checkpointed.
StateBackendFactory<T extends StateBackend> - Interface in org.apache.flink.runtime.state
A factory to create a specific state backend.
StateBinder - Interface in org.apache.flink.api.common.state
The StateBinder is used by StateDescriptor instances to create actual State objects.
StateCleaningCountTrigger - Class in org.apache.flink.table.runtime.triggers
A Trigger that fires once the count of elements in a pane reaches the given count or the cleanup timer is triggered.
StateCleaningCountTrigger(StreamQueryConfig, long) - Constructor for class org.apache.flink.table.runtime.triggers.StateCleaningCountTrigger
 
StateCleaningCountTrigger$ - Class in org.apache.flink.table.runtime.triggers
 
StateCleaningCountTrigger$() - Constructor for class org.apache.flink.table.runtime.triggers.StateCleaningCountTrigger$
 
StateCleaningCountTrigger.Sum - Class in org.apache.flink.table.runtime.triggers
 
stateCleaningEnabled() - Method in class org.apache.flink.table.runtime.aggregate.ProcessFunctionWithCleanupState
 
stateCleaningEnabled() - Method in class org.apache.flink.table.runtime.triggers.StateCleaningCountTrigger
 
stateData() - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
stateData() - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
stateData() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
stateData() - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
StateData(TaskMonitor.TaskGoalState) - Constructor for class org.apache.flink.mesos.scheduler.TaskMonitor.StateData
 
StateData$() - Constructor for class org.apache.flink.mesos.scheduler.TaskMonitor.StateData$
 
stateDesc - Variable in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
State descriptor from which to create this state instance
stateDesc - Variable in class org.apache.flink.migration.runtime.state.filesystem.AbstractFsStateSnapshot
Deprecated.
StateDescriptor, for sanity checks
stateDesc - Variable in class org.apache.flink.migration.runtime.state.memory.AbstractMemStateSnapshot
Deprecated.
StateDescriptor, for sanity checks
stateDesc - Variable in class org.apache.flink.runtime.state.heap.AbstractHeapState
This holds the name of the state and can create an initial default value for the state.
StateDescriptor<S extends State,T> - Class in org.apache.flink.api.common.state
Base class for state descriptors.
StateDescriptor(String, TypeSerializer<T>, T) - Constructor for class org.apache.flink.api.common.state.StateDescriptor
Create a new StateDescriptor with the given name and the given type serializer.
StateDescriptor(String, TypeInformation<T>, T) - Constructor for class org.apache.flink.api.common.state.StateDescriptor
Create a new StateDescriptor with the given name and the given type information.
StateDescriptor(String, Class<T>, T) - Constructor for class org.apache.flink.api.common.state.StateDescriptor
Create a new StateDescriptor with the given name and the given type information.
StateDescriptor.Type - Enum in org.apache.flink.api.common.state
An enumeration of the types of supported states.
StateEntry<K,N,S> - Interface in org.apache.flink.runtime.state.heap
Interface of entries in a state table.
StatefulFunction<I,O,S> - Interface in org.apache.flink.streaming.api.scala.function
Trait implementing the functionality necessary to apply stateful functions in RichFunctions without exposing the OperatorStates to the user.
StatefulSequenceSource - Class in org.apache.flink.streaming.api.functions.source
A stateful streaming source that emits each number from a given interval exactly once, possibly in parallel.
StatefulSequenceSource(long, long) - Constructor for class org.apache.flink.streaming.api.functions.source.StatefulSequenceSource
Creates a source that emits all numbers from the given interval exactly once.
StatefulTask - Interface in org.apache.flink.runtime.jobgraph.tasks
This interface must be implemented by any invokable that has recoverable state and participates in checkpointing.
stateHandle - Variable in class org.apache.flink.migration.contrib.streaming.state.RocksDBStateBackend.FinalFullyAsyncSnapshot
Deprecated.
 
StateHandle<T> - Interface in org.apache.flink.migration.runtime.state
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
StateHandleID - Class in org.apache.flink.runtime.state
Unique ID that allows for logical comparison between state handles.
StateHandleID(String) - Constructor for class org.apache.flink.runtime.state.StateHandleID
 
StateInitializationContext - Interface in org.apache.flink.runtime.state
This interface provides a context in which operators can initialize by registering to managed state (i.e.
StateInitializationContextImpl - Class in org.apache.flink.runtime.state
Default implementation of StateInitializationContext.
StateInitializationContextImpl(boolean, OperatorStateStore, KeyedStateStore, Collection<KeyedStateHandle>, Collection<OperatorStateHandle>, CloseableRegistry) - Constructor for class org.apache.flink.runtime.state.StateInitializationContextImpl
 
stateLock - Variable in class org.apache.flink.runtime.operators.hash.AbstractMutableHashTable
The lock to synchronize state changes (open / close) on
stateMetaInfo - Variable in class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.AbstractOperatorBackendStateMetaInfoWriter
 
StateMetaInfo(long[], OperatorStateHandle.Mode) - Constructor for class org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo
 
StateMigrationException - Exception in org.apache.flink.util
Base class for state migration related exceptions
StateMigrationException(String) - Constructor for exception org.apache.flink.util.StateMigrationException
 
StateMigrationException(Throwable) - Constructor for exception org.apache.flink.util.StateMigrationException
 
StateMigrationException(String, Throwable) - Constructor for exception org.apache.flink.util.StateMigrationException
 
stateName() - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
stateName() - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
stateName() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
stateName() - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
StateObject - Interface in org.apache.flink.migration.runtime.state
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
StateObject - Interface in org.apache.flink.runtime.state
Base of all handles that represent checkpointed state in some form.
StatePartitionStreamProvider - Class in org.apache.flink.runtime.state
This class provides access to input streams that contain data of one state partition of a partitionable state.
StatePartitionStreamProvider(IOException) - Constructor for class org.apache.flink.runtime.state.StatePartitionStreamProvider
 
StatePartitionStreamProvider(InputStream) - Constructor for class org.apache.flink.runtime.state.StatePartitionStreamProvider
 
stateSerializer - Variable in class org.apache.flink.migration.runtime.state.filesystem.AbstractFsStateSnapshot
Deprecated.
Serializer for the state value
stateSerializer - Variable in class org.apache.flink.migration.runtime.state.memory.AbstractMemStateSnapshot
Deprecated.
Serializer for the state value
stateSerializer - Variable in class org.apache.flink.migration.runtime.state.memory.AbstractMigrationRestoreStrategy
Deprecated.
Serializer for the state value
stateSerializer() - Method in interface org.apache.flink.streaming.api.scala.function.StatefulFunction
 
StateSnapshotContext - Interface in org.apache.flink.runtime.state
This interface provides a context in which operators that use managed (i.e.
StateSnapshotContextSynchronousImpl - Class in org.apache.flink.runtime.state
This class is a default implementation for StateSnapshotContext.
StateSnapshotContextSynchronousImpl(long, long) - Constructor for class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
 
StateSnapshotContextSynchronousImpl(long, long, CheckpointStreamFactory, KeyGroupRange, CloseableRegistry) - Constructor for class org.apache.flink.runtime.state.StateSnapshotContextSynchronousImpl
 
stateTable - Variable in class org.apache.flink.runtime.state.heap.AbstractHeapState
Map containing the actual key/value pairs
StateTable<K,N,S> - Class in org.apache.flink.runtime.state.heap
Base class for state tables.
StateTable(InternalKeyContext<K>, RegisteredKeyedBackendStateMetaInfo<N, S>) - Constructor for class org.apache.flink.runtime.state.heap.StateTable
 
StateTimeout() - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
StateTimeout() - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
StateTimeout() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
StateTimeout() - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
StateTransformationFunction<S,T> - Interface in org.apache.flink.runtime.state
Interface for a binary function that is used for push-down of state transformation into state backends.
StateTransition<T> - Class in org.apache.flink.cep.nfa
 
StateTransition(State<T>, StateTransitionAction, State<T>, IterativeCondition<T>) - Constructor for class org.apache.flink.cep.nfa.StateTransition
 
StateTransitionAction - Enum in org.apache.flink.cep.nfa
Set of actions when doing a state transition from a State to another.
StateUtil - Class in org.apache.flink.runtime.state
Helpers for StateObject related code.
StaticDynamicPathIdentifier - Class in org.apache.flink.optimizer.traversals
A traversal that goes over the program data flow of an iteration and makes the nodes that depend on the partial solution (the data set recomputed in each iteration) as "dynamic" and the other nodes as "static".
StaticDynamicPathIdentifier(int) - Constructor for class org.apache.flink.optimizer.traversals.StaticDynamicPathIdentifier
 
StaticFileServerHandler - Class in org.apache.flink.runtime.webmonitor.files
Simple file server handler that serves requests to web frontend's static files, such as HTML, CSS, or JS files.
StaticFileServerHandler(JobManagerRetriever, Future<String>, FiniteDuration, File, boolean) - Constructor for class org.apache.flink.runtime.webmonitor.files.StaticFileServerHandler
 
StaticFileServerHandler(JobManagerRetriever, Future<String>, FiniteDuration, File, boolean, Logger) - Constructor for class org.apache.flink.runtime.webmonitor.files.StaticFileServerHandler
 
statistic() - Method in class org.apache.flink.table.plan.schema.DataSetTable
 
statistic() - Method in class org.apache.flink.table.plan.schema.DataStreamTable
 
statistic() - Method in class org.apache.flink.table.plan.schema.FlinkTable
 
statistic() - Method in class org.apache.flink.table.plan.schema.StreamTableSourceTable
 
statistic() - Method in class org.apache.flink.table.plan.schema.TableSourceTable
 
statisticsKey - Variable in class org.apache.flink.api.common.operators.GenericDataSourceBase
 
stats() - Method in class org.apache.flink.table.catalog.ExternalCatalogTable
 
StatsDReporter - Class in org.apache.flink.metrics.statsd
Largely based on the StatsDReporter class by ReadyTalk https://github.com/ReadyTalk/metrics-statsd/blob/master/metrics3-statsd/src/main/java/com/readytalk/metrics/StatsDReporter.java Ported since it was not present in maven central.
StatsDReporter() - Constructor for class org.apache.flink.metrics.statsd.StatsDReporter
 
status() - Method in class org.apache.flink.mesos.scheduler.messages.ExecutorLost
 
status() - Method in class org.apache.flink.mesos.scheduler.messages.StatusUpdate
 
status() - Method in class org.apache.flink.mesos.scheduler.TaskMonitor.TaskTerminated
 
status() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.CurrentJobStatus
 
status - Variable in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
status() - Method in class org.apache.flink.yarn.YarnMessages.LocalStopYarnSession
 
statuses() - Method in class org.apache.flink.yarn.YarnMessages.YarnContainersCompleted
 
StatusListenerMessenger - Class in org.apache.flink.runtime.executiongraph
A JobStatusListener and ExecutionStatusListener that sends an actor message for each status change.
StatusListenerMessenger(ActorRef, UUID) - Constructor for class org.apache.flink.runtime.executiongraph.StatusListenerMessenger
 
StatusOverview - Class in org.apache.flink.runtime.messages.webmonitor
Response to the RequestStatusOverview message, carrying a description of the Flink cluster status.
StatusOverview(int, int, int, int, int, int, int) - Constructor for class org.apache.flink.runtime.messages.webmonitor.StatusOverview
 
StatusOverview(int, int, int, JobsOverview, JobsOverview) - Constructor for class org.apache.flink.runtime.messages.webmonitor.StatusOverview
 
StatusUpdate - Class in org.apache.flink.mesos.scheduler.messages
Message sent by the callback handler to the scheduler actor when the status of a task has changed (e.g., a slave is lost and so the task is lost, a task finishes and an executor sends a status update saying so, etc).
StatusUpdate(Protos.TaskStatus) - Constructor for class org.apache.flink.mesos.scheduler.messages.StatusUpdate
 
statusUpdate(SchedulerDriver, Protos.TaskStatus) - Method in class org.apache.flink.mesos.scheduler.SchedulerProxy
 
StatusWatermarkValve - Class in org.apache.flink.streaming.runtime.streamstatus
A StatusWatermarkValve embodies the logic of how Watermark and StreamStatus are propagated to downstream outputs, given a set of one or multiple input channels that continuously receive them.
StatusWatermarkValve(int, StatusWatermarkValve.ValveOutputHandler) - Constructor for class org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve
Returns a new StatusWatermarkValve.
StatusWatermarkValve.InputChannelStatus - Class in org.apache.flink.streaming.runtime.streamstatus
An InputChannelStatus keeps track of an input channel's last watermark, stream status, and whether or not the channel's current watermark is aligned with the overall watermark output from the valve.
StatusWatermarkValve.ValveOutputHandler - Interface in org.apache.flink.streaming.runtime.streamstatus
Usages of StatusWatermarkValve should implement a ValveOutputHandler to handle watermark and stream status outputs from the valve.
stay() - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
stay() - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
stay() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
stay() - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
std() - Method in class org.apache.flink.ml.preprocessing.StandardScaler.StandardScalerTransformOperation
 
Std$() - Constructor for class org.apache.flink.ml.preprocessing.StandardScaler.Std$
 
stddev - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.HistogramDump
 
STDDEV_POP - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
STDDEV_POP aggregate function.
STDDEV_SAMP - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
STDDEV_SAMP aggregate function.
stddevPop() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Returns the population standard deviation of an expression (the square root of varPop()).
StddevPop - Class in org.apache.flink.table.expressions
 
StddevPop(Expression) - Constructor for class org.apache.flink.table.expressions.StddevPop
 
StddevPop$ - Class in org.apache.flink.table.expressions
 
StddevPop$() - Constructor for class org.apache.flink.table.expressions.StddevPop$
 
stddevSamp() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Returns the sample standard deviation of an expression (the square root of varSamp()).
StddevSamp - Class in org.apache.flink.table.expressions
 
StddevSamp(Expression) - Constructor for class org.apache.flink.table.expressions.StddevSamp
 
StddevSamp$ - Class in org.apache.flink.table.expressions
 
StddevSamp$() - Constructor for class org.apache.flink.table.expressions.StddevSamp$
 
stdOutFile - Variable in class org.apache.flink.runtime.webmonitor.WebMonitorUtils.LogFileLocation
 
StdOutFileRequest$() - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages.StdOutFileRequest$
 
Step() - Constructor for class org.apache.flink.streaming.examples.iteration.IterateExample.Step
 
StepFunctionValidator - Class in org.apache.flink.optimizer.traversals
A traversal that checks if the Workset of a delta iteration is used in the data flow of its step function.
StepFunctionValidator() - Constructor for class org.apache.flink.optimizer.traversals.StepFunctionValidator
 
STEPS - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
 
Stepsize$() - Constructor for class org.apache.flink.ml.classification.SVM.Stepsize$
 
Stepsize$() - Constructor for class org.apache.flink.ml.regression.MultipleLinearRegression.Stepsize$
 
StochasticOutlierSelection - Class in org.apache.flink.ml.outlier
An implementation of the Stochastic Outlier Selection algorithm by Jeroen Jansen
StochasticOutlierSelection() - Constructor for class org.apache.flink.ml.outlier.StochasticOutlierSelection
 
StochasticOutlierSelection$ - Class in org.apache.flink.ml.outlier
 
StochasticOutlierSelection$() - Constructor for class org.apache.flink.ml.outlier.StochasticOutlierSelection$
 
StochasticOutlierSelection.BreezeLabeledVector - Class in org.apache.flink.ml.outlier
 
StochasticOutlierSelection.BreezeLabeledVector$ - Class in org.apache.flink.ml.outlier
 
StochasticOutlierSelection.ErrorTolerance$ - Class in org.apache.flink.ml.outlier
 
StochasticOutlierSelection.MaxIterations$ - Class in org.apache.flink.ml.outlier
 
StochasticOutlierSelection.Perplexity$ - Class in org.apache.flink.ml.outlier
 
stop() - Method in interface org.apache.flink.api.common.functions.StoppableFunction
Stops the source.
stop() - Method in class org.apache.flink.api.common.PlanExecutor
Shuts down the plan executor and releases all local resources.
stop(String[]) - Method in class org.apache.flink.client.CliFrontend
Executes the STOP action.
stop() - Method in class org.apache.flink.client.LocalExecutor
 
stop(JobID) - Method in class org.apache.flink.client.program.ClusterClient
Stops a program on Flink cluster whose job-manager is configured in this client's configuration.
stop() - Method in class org.apache.flink.client.RemoteExecutor
 
stop(boolean) - Method in interface org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore
Stop the worker store.
stop(boolean) - Method in class org.apache.flink.mesos.runtime.clusterframework.store.StandaloneMesosWorkerStore
 
stop(boolean) - Method in class org.apache.flink.mesos.runtime.clusterframework.store.ZooKeeperMesosWorkerStore
 
stop() - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
stop(FSM.Reason) - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
stop(FSM.Reason, D) - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
Stop() - Constructor for class org.apache.flink.mesos.scheduler.ConnectionMonitor.Stop
 
stop() - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
stop(FSM.Reason) - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
stop(FSM.Reason, D) - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
stop() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
stop(FSM.Reason) - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
stop(FSM.Reason, D) - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
stop() - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
stop(FSM.Reason) - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
stop(FSM.Reason, D) - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
stop() - Method in class org.apache.flink.mesos.util.MesosArtifactServer
Stops the artifact server.
stop() - Method in interface org.apache.flink.runtime.checkpoint.CheckpointRecoveryFactory
Stops the CheckpointRecoveryFactory service.
stop() - Method in class org.apache.flink.runtime.checkpoint.StandaloneCheckpointRecoveryFactory
 
stop() - Method in class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointRecoveryFactory
 
stop() - Method in class org.apache.flink.runtime.executiongraph.Execution
Sends stop RPC call.
stop() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
stop() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
stop() - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatManager
Stops the heartbeat manager.
stop() - Method in class org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
 
stop() - Method in class org.apache.flink.runtime.heartbeat.HeartbeatManagerSenderImpl
 
stop() - Method in class org.apache.flink.runtime.highavailability.nonha.leaderelection.SingleLeaderElectionService
 
stop() - Method in class org.apache.flink.runtime.io.async.AbstractAsyncIOCallable
Stops the I/O operation by closing the I/O handle.
stop() - Method in interface org.apache.flink.runtime.io.async.AsyncStoppable
Stop the operation
stop() - Method in interface org.apache.flink.runtime.jobgraph.tasks.StoppableTask
Called on STOP signal.
stop() - Method in class org.apache.flink.runtime.jobmanager.StandaloneSubmittedJobGraphStore
 
stop() - Method in interface org.apache.flink.runtime.jobmanager.SubmittedJobGraphStore
Stops the SubmittedJobGraphStore service.
stop() - Method in class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
 
stop() - Method in interface org.apache.flink.runtime.leaderelection.LeaderElectionService
Stops the leader election service.
stop() - Method in class org.apache.flink.runtime.leaderelection.StandaloneLeaderElectionService
 
stop() - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
 
stop() - Method in interface org.apache.flink.runtime.leaderretrieval.LeaderRetrievalService
Stops the leader retrieval service.
stop() - Method in class org.apache.flink.runtime.leaderretrieval.StandaloneLeaderRetrievalService
 
stop() - Method in class org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalService
 
stop() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
stop() - Method in class org.apache.flink.runtime.resourcemanager.JobLeaderIdService
Stop the service.
stop() - Method in interface org.apache.flink.runtime.rpc.StartStoppable
Stops the processing of remote procedure calls.
stop() - Method in class org.apache.flink.runtime.taskexecutor.JobLeaderService
Stop the job leader services.
stop() - Method in class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
Stop the task slot table.
stop() - Method in class org.apache.flink.runtime.taskexecutor.slot.TimerService
 
stop() - Method in interface org.apache.flink.runtime.webmonitor.WebMonitor
Stops the web server.
stop() - Method in class org.apache.flink.runtime.webmonitor.WebRuntimeMonitor
 
stop() - Method in class org.apache.flink.storm.wrappers.SpoutWrapper
Stops the source.
stop() - Method in class org.apache.flink.streaming.api.operators.async.Emitter
 
stop() - Method in class org.apache.flink.streaming.api.operators.StoppableStreamSource
Marks the source a stopped and calls StoppableFunction.stop() on the user function.
stop() - Method in class org.apache.flink.streaming.connectors.nifi.NiFiSource
 
stop() - Method in class org.apache.flink.streaming.connectors.twitter.TwitterSource
 
stop() - Method in class org.apache.flink.streaming.runtime.tasks.StoppableSourceStreamTask
 
stop() - Method in class org.apache.flink.yarn.cli.FlinkYarnSessionCli
Utility method for tests.
Stop$() - Constructor for class org.apache.flink.mesos.scheduler.ConnectionMonitor.Stop$
 
stopCheckpointScheduler() - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
 
StopCluster - Class in org.apache.flink.runtime.clusterframework.messages
Generic message to signal the cluster framework to shut the cluster down.
StopCluster(ApplicationStatus, String) - Constructor for class org.apache.flink.runtime.clusterframework.messages.StopCluster
 
stopCluster(ApplicationStatus, String) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
stopCluster(ApplicationStatus, String) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Stop the cluster.
stopCluster(ApplicationStatus, String) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
stopCluster() - Method in class org.apache.flink.test.util.AbstractTestBase
 
stopCluster(LocalFlinkMiniCluster, FiniteDuration) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
StopClusterSuccessful - Class in org.apache.flink.runtime.clusterframework.messages
Generic message to signal the cluster listener that the cluster has been shut down.
StopEvent() - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
StopEvent() - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
StopEvent() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
StopEvent() - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
stopExecution() - Method in class org.apache.flink.runtime.taskmanager.Task
Stops the executing task by calling StoppableTask.stop().
StopJob(JobID) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.StopJob
 
stopJob(JobID) - Method in class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
StopJob$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.StopJob$
 
stopMessageReceiver() - Method in class org.apache.flink.yarn.ApplicationClient
 
StopOptions - Class in org.apache.flink.client.cli
Command line options for the STOP command
StopOptions(CommandLine) - Constructor for class org.apache.flink.client.cli.StopOptions
 
stoppableCallbackCallable - Variable in class org.apache.flink.runtime.io.async.AsyncStoppableTaskWithCallback
 
StoppableCallbackCallable<V> - Interface in org.apache.flink.runtime.io.async
A Callable that can be stopped and offers a callback on termination.
StoppableFunction - Interface in org.apache.flink.api.common.functions
Must be implemented by stoppable functions, eg, source functions of streaming jobs.
StoppableSourceStreamTask<OUT,SRC extends SourceFunction<OUT> & StoppableFunction> - Class in org.apache.flink.streaming.runtime.tasks
Stoppable task for executing stoppable streaming sources.
StoppableSourceStreamTask() - Constructor for class org.apache.flink.streaming.runtime.tasks.StoppableSourceStreamTask
 
StoppableStreamSource<OUT,SRC extends SourceFunction<OUT> & StoppableFunction> - Class in org.apache.flink.streaming.api.operators
StoppableStreamSource(SRC) - Constructor for class org.apache.flink.streaming.api.operators.StoppableStreamSource
Takes a SourceFunction that implements StoppableFunction.
StoppableTask - Interface in org.apache.flink.runtime.jobgraph.tasks
Implemented by tasks that can receive STOP signal.
stopped - Variable in class org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
Running state of the heartbeat manager
StoppedState$() - Constructor for class org.apache.flink.mesos.scheduler.ConnectionMonitor.StoppedState$
 
StoppingException - Exception in org.apache.flink.runtime
Indicates that a job is not stoppable.
StoppingException(String) - Constructor for exception org.apache.flink.runtime.StoppingException
 
StoppingException(String, Throwable) - Constructor for exception org.apache.flink.runtime.StoppingException
 
StoppingFailure(JobID, Throwable) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.StoppingFailure
 
StoppingFailure$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.StoppingFailure$
 
StoppingSuccess(JobID) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.StoppingSuccess
 
StoppingSuccess$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.StoppingSuccess$
 
stopServer(RpcGateway) - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
stopServer(C) - Method in interface org.apache.flink.runtime.rpc.RpcService
Stop the underlying rpc server of the provided self gateway.
stopService() - Method in class org.apache.flink.runtime.rpc.akka.AkkaRpcService
 
stopService() - Method in interface org.apache.flink.runtime.rpc.RpcService
Stop the rpc service shutting down all started rpc servers.
stopTask(ExecutionAttemptID, Time) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
stopTask(ExecutionAttemptID, Time) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Stop the given task.
stopTask(ExecutionAttemptID, Time) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
StopTask(ExecutionAttemptID) - Constructor for class org.apache.flink.runtime.messages.TaskMessages.StopTask
 
stopTask(ExecutionAttemptID) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
stopTask(ExecutionAttemptID, Time) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Stop the given task.
StopTask$() - Constructor for class org.apache.flink.runtime.messages.TaskMessages.StopTask$
 
stopWhenJobFinished() - Method in class org.apache.flink.runtime.clusterframework.ContaineredJobManager
 
stopWorker(InstanceID) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
 
stopWorker(InstanceID) - Method in class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
 
stopWorker(InstanceID) - Method in class org.apache.flink.yarn.YarnResourceManager
 
store(T) - Method in class org.apache.flink.runtime.zookeeper.filesystem.FileSystemStateStorageHelper
 
store(T) - Method in interface org.apache.flink.runtime.zookeeper.RetrievableStateStorageHelper
Stores the given state and returns a state handle to it.
storeExternalizedCheckpointToHandle(String, T) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointStore
Stores the externalized checkpoint metadata file to a state handle.
storeSavepoint(String, T) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointStore
Stores the savepoint metadata file.
storeSavepointToHandle(String, T) - Static method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointStore
Stores the savepoint metadata file to a state handle.
StormConfig - Class in org.apache.flink.storm.util
StormConfig is used to provide a user-defined Storm configuration (ie, a raw Map or Config object) for embedded Spouts and Bolts.
StormConfig() - Constructor for class org.apache.flink.storm.util.StormConfig
Creates an empty configuration.
StormConfig(Map) - Constructor for class org.apache.flink.storm.util.StormConfig
Creates an configuration with initial values provided by the given Map.
StormStreamSelector<T> - Class in org.apache.flink.storm.util
Used by FlinkTopology to split multiple declared output streams within Flink.
StormStreamSelector() - Constructor for class org.apache.flink.storm.util.StormStreamSelector
 
StormTuple<IN> - Class in org.apache.flink.storm.wrappers
StormTuple converts a Flink tuple of type IN into a Storm tuple.
StormTuple(IN, Fields, int, String, String, MessageId) - Constructor for class org.apache.flink.storm.wrappers.StormTuple
Create a new Storm tuple from the given Flink tuple.
str() - Method in class org.apache.flink.table.expressions.Like
 
str() - Method in class org.apache.flink.table.expressions.Overlay
 
str() - Method in class org.apache.flink.table.expressions.Similar
 
str() - Method in class org.apache.flink.table.expressions.Substring
 
str() - Method in class org.apache.flink.table.expressions.Trim
 
stream - Variable in class org.apache.flink.api.common.io.FileInputFormat
The input stream reading from the input file.
stream - Variable in class org.apache.flink.api.common.io.FileOutputFormat
The stream to which the data is written;
streamBufferWithGroups(Iterator<IN1>, Iterator<IN2>, Collector<OUT>) - Method in class org.apache.flink.python.api.streaming.data.PythonDualInputStreamer
Sends all values contained in both iterators to the external process and collects all results.
streamBufferWithoutGroups(Iterator<IN>, Collector<OUT>) - Method in class org.apache.flink.python.api.streaming.data.PythonSingleInputStreamer
Sends all values contained in the iterator to the external process and collects all results.
StreamCheckpointedOperator - Interface in org.apache.flink.streaming.api.operators
Deprecated.
This interface is deprecated without replacement. All operators are now checkpointed.
StreamConfig - Class in org.apache.flink.streaming.api.graph
Internal configuration for a StreamOperator.
StreamConfig(Configuration) - Constructor for class org.apache.flink.streaming.api.graph.StreamConfig
 
StreamContextEnvironment - Class in org.apache.flink.streaming.api.environment
Special StreamExecutionEnvironment that will be used in cases where the CLI client or testing utilities create a StreamExecutionEnvironment that should be used when StreamExecutionEnvironment.getExecutionEnvironment() is called.
StreamContextEnvironment(ContextEnvironment) - Constructor for class org.apache.flink.streaming.api.environment.StreamContextEnvironment
 
StreamEdge - Class in org.apache.flink.streaming.api.graph
An edge in the streaming topology.
StreamEdge(StreamNode, StreamNode, int, List<String>, StreamPartitioner<?>, OutputTag) - Constructor for class org.apache.flink.streaming.api.graph.StreamEdge
 
StreamElement - Class in org.apache.flink.streaming.runtime.streamrecord
An element in a data stream.
StreamElement() - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamElement
 
StreamElementQueue - Interface in org.apache.flink.streaming.api.operators.async.queue
Interface for blocking stream element queues for the AsyncWaitOperator.
StreamElementQueueEntry<T> - Class in org.apache.flink.streaming.api.operators.async.queue
Entry class for the StreamElementQueue.
StreamElementQueueEntry(StreamElement) - Constructor for class org.apache.flink.streaming.api.operators.async.queue.StreamElementQueueEntry
 
StreamElementSerializer<T> - Class in org.apache.flink.streaming.runtime.streamrecord
StreamElementSerializer(TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer
 
StreamElementSerializer.StreamElementSerializerConfigSnapshot<T> - Class in org.apache.flink.streaming.runtime.streamrecord
Configuration snapshot specific to the StreamElementSerializer.
StreamElementSerializerConfigSnapshot() - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
StreamElementSerializerConfigSnapshot(TypeSerializer<T>) - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamElementSerializer.StreamElementSerializerConfigSnapshot
 
StreamExecutionEnvironment - Class in org.apache.flink.streaming.api.environment
The StreamExecutionEnvironment is the context in which a streaming program is executed.
StreamExecutionEnvironment() - Constructor for class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
 
StreamExecutionEnvironment - Class in org.apache.flink.streaming.api.scala
 
StreamExecutionEnvironment(StreamExecutionEnvironment) - Constructor for class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment
 
StreamExecutionEnvironment$ - Class in org.apache.flink.streaming.api.scala
 
StreamExecutionEnvironment$() - Constructor for class org.apache.flink.streaming.api.scala.StreamExecutionEnvironment$
 
StreamExecutionEnvironmentFactory - Interface in org.apache.flink.streaming.api.environment
Factory class for stream execution environments.
streamFactory - Variable in class org.apache.flink.runtime.checkpoint.AbstractAsyncSnapshotIOCallable
 
StreamFilter<IN> - Class in org.apache.flink.streaming.api.operators
StreamFilter(FilterFunction<IN>) - Constructor for class org.apache.flink.streaming.api.operators.StreamFilter
 
StreamFlatMap<IN,OUT> - Class in org.apache.flink.streaming.api.operators
StreamFlatMap(FlatMapFunction<IN, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.StreamFlatMap
 
StreamGraph - Class in org.apache.flink.streaming.api.graph
Class representing the streaming topology.
StreamGraph(StreamExecutionEnvironment) - Constructor for class org.apache.flink.streaming.api.graph.StreamGraph
 
StreamGraphGenerator - Class in org.apache.flink.streaming.api.graph
A generator that generates a StreamGraph from a graph of StreamTransformations.
StreamGraphHasher - Interface in org.apache.flink.streaming.api.graph
Interface for different implementations of generating hashes over a stream graph.
StreamGraphHasherV1 - Class in org.apache.flink.migration.streaming.api.graph
StreamGraphHasher from Flink 1.1.
StreamGraphHasherV1() - Constructor for class org.apache.flink.migration.streaming.api.graph.StreamGraphHasherV1
 
StreamGraphHasherV2 - Class in org.apache.flink.streaming.api.graph
StreamGraphHasher from Flink 1.2.
StreamGraphHasherV2() - Constructor for class org.apache.flink.streaming.api.graph.StreamGraphHasherV2
 
StreamGraphUserHashHasher - Class in org.apache.flink.streaming.api.graph
StreamGraphHasher that works with user provided hashes.
StreamGraphUserHashHasher() - Constructor for class org.apache.flink.streaming.api.graph.StreamGraphUserHashHasher
 
StreamGroupedFold<IN,OUT,KEY> - Class in org.apache.flink.streaming.api.operators
Deprecated.
will be removed in a future version
StreamGroupedFold(FoldFunction<IN, OUT>, OUT) - Constructor for class org.apache.flink.streaming.api.operators.StreamGroupedFold
Deprecated.
 
StreamGroupedReduce<IN> - Class in org.apache.flink.streaming.api.operators
A StreamOperator for executing a ReduceFunction on a KeyedStream.
StreamGroupedReduce(ReduceFunction<IN>, TypeSerializer<IN>) - Constructor for class org.apache.flink.streaming.api.operators.StreamGroupedReduce
 
streamId - Variable in class org.apache.flink.storm.util.SplitStreamType
The stream ID this tuple belongs to.
STREAMING_COUNTS_AS_TUPLES - Static variable in class org.apache.flink.streaming.examples.twitter.util.TwitterExampleData
 
STREAMING_COUNTS_AS_TUPLES - Static variable in class org.apache.flink.test.testdata.WordCountData
 
StreamingFunctionUtils - Class in org.apache.flink.streaming.util.functions
Utility class that contains helper methods to work with Flink Streaming Functions.
StreamingJobGraphGenerator - Class in org.apache.flink.streaming.api.graph
The StreamingJobGraphGenerator converts a StreamGraph into a JobGraph.
StreamingMultipleProgramsTestBase - Class in org.apache.flink.streaming.util
Base class for streaming unit tests that run multiple tests and want to reuse the same Flink cluster.
StreamingMultipleProgramsTestBase() - Constructor for class org.apache.flink.streaming.util.StreamingMultipleProgramsTestBase
 
StreamingPlan - Class in org.apache.flink.optimizer.plan
Abstract class representing Flink Streaming plans
StreamingPlan() - Constructor for class org.apache.flink.optimizer.plan.StreamingPlan
 
StreamingProgramTestBase - Class in org.apache.flink.streaming.util
 
StreamingProgramTestBase() - Constructor for class org.apache.flink.streaming.util.StreamingProgramTestBase
 
StreamingRuntimeContext - Class in org.apache.flink.streaming.api.operators
Implementation of the RuntimeContext, for streaming operators.
StreamingRuntimeContext(AbstractStreamOperator<?>, Environment, Map<String, Accumulator<?, ?>>) - Constructor for class org.apache.flink.streaming.api.operators.StreamingRuntimeContext
 
StreamInputProcessor<IN> - Class in org.apache.flink.streaming.runtime.io
Input reader for OneInputStreamTask.
StreamInputProcessor(InputGate[], TypeSerializer<IN>, StatefulTask, CheckpointingMode, Object, IOManager, Configuration, StreamStatusMaintainer, OneInputStreamOperator<IN, ?>) - Constructor for class org.apache.flink.streaming.runtime.io.StreamInputProcessor
 
StreamIterationHead<OUT> - Class in org.apache.flink.streaming.runtime.tasks
A special StreamTask that is used for executing feedback edges.
StreamIterationHead() - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamIterationHead
 
StreamIterationTail<IN> - Class in org.apache.flink.streaming.runtime.tasks
A special StreamTask that is used for executing feedback edges.
StreamIterationTail() - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamIterationTail
 
StreamMap<IN,OUT> - Class in org.apache.flink.streaming.api.operators
A StreamOperator for executing MapFunctions.
StreamMap(MapFunction<IN, OUT>) - Constructor for class org.apache.flink.streaming.api.operators.StreamMap
 
StreamNode - Class in org.apache.flink.streaming.api.graph
Class representing the operators in the streaming programs, with all their properties.
StreamNode(StreamExecutionEnvironment, Integer, String, StreamOperator<?>, String, List<OutputSelector<?>>, Class<? extends AbstractInvokable>) - Constructor for class org.apache.flink.streaming.api.graph.StreamNode
 
StreamOperator<OUT> - Interface in org.apache.flink.streaming.api.operators
Basic interface for stream operators.
StreamPartitioner<T> - Class in org.apache.flink.streaming.runtime.partitioner
A special ChannelSelector for use in streaming programs.
StreamPartitioner() - Constructor for class org.apache.flink.streaming.runtime.partitioner.StreamPartitioner
 
StreamPlanEnvironment - Class in org.apache.flink.streaming.api.environment
A special StreamExecutionEnvironment that is used in the web frontend when generating a user-inspectable graph of a streaming job.
StreamPlanEnvironment(ExecutionEnvironment) - Constructor for class org.apache.flink.streaming.api.environment.StreamPlanEnvironment
 
StreamPrinter - Class in org.apache.flink.python.api.streaming.util
Simple utility class to print all contents of an inputstream to stdout.
StreamPrinter(InputStream) - Constructor for class org.apache.flink.python.api.streaming.util.StreamPrinter
 
StreamPrinter(InputStream, AtomicReference<String>) - Constructor for class org.apache.flink.python.api.streaming.util.StreamPrinter
 
StreamProject<IN,OUT extends Tuple> - Class in org.apache.flink.streaming.api.operators
A StreamOperator for executing projections on streams.
StreamProject(int[], TypeSerializer<OUT>) - Constructor for class org.apache.flink.streaming.api.operators.StreamProject
 
StreamProjection<IN> - Class in org.apache.flink.streaming.api.datastream
StreamProjection(DataStream<IN>, int[]) - Constructor for class org.apache.flink.streaming.api.datastream.StreamProjection
 
StreamQueryConfig - Class in org.apache.flink.table.api
The StreamQueryConfig holds parameters to configure the behavior of streaming queries.
StreamQueryConfig() - Constructor for class org.apache.flink.table.api.StreamQueryConfig
 
StreamRecord<T> - Class in org.apache.flink.streaming.runtime.streamrecord
One value in a data stream.
StreamRecord(T) - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
Creates a new StreamRecord.
StreamRecord(T, long) - Constructor for class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
Creates a new StreamRecord wrapping the given value.
StreamRecordComparator<IN> - Class in org.apache.flink.cep.operator
Compares two StreamRecords based on their timestamp
StreamRecordComparator() - Constructor for class org.apache.flink.cep.operator.StreamRecordComparator
 
StreamRecordQueueEntry<OUT> - Class in org.apache.flink.streaming.api.operators.async.queue
StreamRecordQueueEntry(StreamRecord<?>) - Constructor for class org.apache.flink.streaming.api.operators.async.queue.StreamRecordQueueEntry
 
StreamRecordSerializer<T> - Class in org.apache.flink.migration.streaming.runtime.streamrecord
Serializer for StreamRecord.
StreamRecordSerializer(TypeSerializer<T>) - Constructor for class org.apache.flink.migration.streaming.runtime.streamrecord.StreamRecordSerializer
 
StreamRecordSerializer.StreamRecordSerializerConfigSnapshot<T> - Class in org.apache.flink.migration.streaming.runtime.streamrecord
Configuration snapshot specific to the StreamRecordSerializer.
StreamRecordSerializerConfigSnapshot() - Constructor for class org.apache.flink.migration.streaming.runtime.streamrecord.StreamRecordSerializer.StreamRecordSerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
StreamRecordSerializerConfigSnapshot(TypeSerializer<T>) - Constructor for class org.apache.flink.migration.streaming.runtime.streamrecord.StreamRecordSerializer.StreamRecordSerializerConfigSnapshot
 
StreamRecordWriter<T extends IOReadableWritable> - Class in org.apache.flink.streaming.runtime.io
This record writer keeps data in buffers at most for a certain timeout.
StreamRecordWriter(ResultPartitionWriter, ChannelSelector<T>, long) - Constructor for class org.apache.flink.streaming.runtime.io.StreamRecordWriter
 
StreamRecordWriter(ResultPartitionWriter, ChannelSelector<T>, long, String) - Constructor for class org.apache.flink.streaming.runtime.io.StreamRecordWriter
 
StreamScan - Interface in org.apache.flink.table.plan.nodes.datastream
 
StreamSink<IN> - Class in org.apache.flink.streaming.api.operators
A StreamOperator for executing SinkFunctions.
StreamSink(SinkFunction<IN>) - Constructor for class org.apache.flink.streaming.api.operators.StreamSink
 
StreamSource<OUT,SRC extends SourceFunction<OUT>> - Class in org.apache.flink.streaming.api.operators
StreamOperator for streaming sources.
StreamSource(SRC) - Constructor for class org.apache.flink.streaming.api.operators.StreamSource
 
StreamSourceContexts - Class in org.apache.flink.streaming.api.operators
Source contexts for various stream time characteristics.
StreamSourceContexts() - Constructor for class org.apache.flink.streaming.api.operators.StreamSourceContexts
 
StreamSQLExample - Class in org.apache.flink.table.examples.scala
Simple example for demonstrating the use of SQL on a Stream Table.
StreamSQLExample() - Constructor for class org.apache.flink.table.examples.scala.StreamSQLExample
 
StreamSQLExample$ - Class in org.apache.flink.table.examples.scala
Simple example for demonstrating the use of SQL on a Stream Table.
StreamSQLExample$() - Constructor for class org.apache.flink.table.examples.scala.StreamSQLExample$
 
StreamSQLExample.Order - Class in org.apache.flink.table.examples.scala
 
StreamSQLExample.Order$ - Class in org.apache.flink.table.examples.scala
 
StreamStateHandle - Interface in org.apache.flink.migration.runtime.state
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
StreamStateHandle - Interface in org.apache.flink.runtime.state
A StateObject that represents state that was written to a stream.
streamStatus - Variable in class org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve.InputChannelStatus
 
StreamStatus - Class in org.apache.flink.streaming.runtime.streamstatus
A Stream Status element informs stream tasks whether or not they should continue to expect records and watermarks from the input stream that sent them.
StreamStatus(int) - Constructor for class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
StreamStatusMaintainer - Interface in org.apache.flink.streaming.runtime.streamstatus
Interface that allows toggling the current StreamStatus as well as retrieving it.
StreamStatusProvider - Interface in org.apache.flink.streaming.runtime.streamstatus
Interface for retrieving the current StreamStatus.
StreamTableEnvironment - Class in org.apache.flink.table.api.java
The TableEnvironment for a Java StreamExecutionEnvironment.
StreamTableEnvironment(StreamExecutionEnvironment, TableConfig) - Constructor for class org.apache.flink.table.api.java.StreamTableEnvironment
 
StreamTableEnvironment - Class in org.apache.flink.table.api.scala
The TableEnvironment for a Scala StreamExecutionEnvironment.
StreamTableEnvironment(StreamExecutionEnvironment, TableConfig) - Constructor for class org.apache.flink.table.api.scala.StreamTableEnvironment
 
StreamTableEnvironment - Class in org.apache.flink.table.api
The base class for stream TableEnvironments.
StreamTableEnvironment(StreamExecutionEnvironment, TableConfig) - Constructor for class org.apache.flink.table.api.StreamTableEnvironment
 
StreamTableExample - Class in org.apache.flink.table.examples.scala
Simple example for demonstrating the use of Table API on a Stream Table.
StreamTableExample() - Constructor for class org.apache.flink.table.examples.scala.StreamTableExample
 
StreamTableExample$ - Class in org.apache.flink.table.examples.scala
Simple example for demonstrating the use of Table API on a Stream Table.
StreamTableExample$() - Constructor for class org.apache.flink.table.examples.scala.StreamTableExample$
 
StreamTableExample.Order - Class in org.apache.flink.table.examples.scala
 
StreamTableExample.Order$ - Class in org.apache.flink.table.examples.scala
 
StreamTableSource<T> - Interface in org.apache.flink.table.sources
Defines an external stream table and provides access to its data.
StreamTableSourceScan - Class in org.apache.flink.table.plan.nodes.datastream
Flink RelNode to read data from an external source defined by a StreamTableSource.
StreamTableSourceScan(RelOptCluster, RelTraitSet, RelOptTable, StreamTableSource<?>) - Constructor for class org.apache.flink.table.plan.nodes.datastream.StreamTableSourceScan
 
StreamTableSourceScanRule - Class in org.apache.flink.table.plan.rules.datastream
 
StreamTableSourceScanRule() - Constructor for class org.apache.flink.table.plan.rules.datastream.StreamTableSourceScanRule
 
StreamTableSourceScanRule$ - Class in org.apache.flink.table.plan.rules.datastream
 
StreamTableSourceScanRule$() - Constructor for class org.apache.flink.table.plan.rules.datastream.StreamTableSourceScanRule$
 
StreamTableSourceTable<T> - Class in org.apache.flink.table.plan.schema
 
StreamTableSourceTable(TableSource<T>, FlinkStatistic) - Constructor for class org.apache.flink.table.plan.schema.StreamTableSourceTable
 
StreamTableSourceTable$ - Class in org.apache.flink.table.plan.schema
 
StreamTableSourceTable$() - Constructor for class org.apache.flink.table.plan.schema.StreamTableSourceTable$
 
StreamTask<OUT,OP extends StreamOperator<OUT>> - Class in org.apache.flink.streaming.runtime.tasks
Base class for all streaming tasks.
StreamTask() - Constructor for class org.apache.flink.streaming.runtime.tasks.StreamTask
 
StreamTaskException - Exception in org.apache.flink.streaming.runtime.tasks
An exception that is thrown by the stream vertices when encountering an illegal condition.
StreamTaskException() - Constructor for exception org.apache.flink.streaming.runtime.tasks.StreamTaskException
Creates a compiler exception with no message and no cause.
StreamTaskException(String) - Constructor for exception org.apache.flink.streaming.runtime.tasks.StreamTaskException
Creates a compiler exception with the given message and no cause.
StreamTaskException(Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.StreamTaskException
Creates a compiler exception with the given cause and no message.
StreamTaskException(String, Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.StreamTaskException
Creates a compiler exception with the given message and cause.
StreamTaskState - Class in org.apache.flink.migration.streaming.runtime.tasks
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
StreamTaskState() - Constructor for class org.apache.flink.migration.streaming.runtime.tasks.StreamTaskState
Deprecated.
 
StreamTaskStateList - Class in org.apache.flink.migration.streaming.runtime.tasks
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
StreamTaskStateList(StreamTaskState[]) - Constructor for class org.apache.flink.migration.streaming.runtime.tasks.StreamTaskStateList
Deprecated.
 
StreamTransformation<T> - Class in org.apache.flink.streaming.api.transformations
A StreamTransformation represents the operation that creates a DataStream.
StreamTransformation(String, TypeInformation<T>, int) - Constructor for class org.apache.flink.streaming.api.transformations.StreamTransformation
Creates a new StreamTransformation with the given name, output type and parallelism.
StreamTwoInputProcessor<IN1,IN2> - Class in org.apache.flink.streaming.runtime.io
Input reader for TwoInputStreamTask.
StreamTwoInputProcessor(Collection<InputGate>, Collection<InputGate>, TypeSerializer<IN1>, TypeSerializer<IN2>, StatefulTask, CheckpointingMode, Object, IOManager, Configuration, StreamStatusMaintainer, TwoInputStreamOperator<IN1, IN2, ?>) - Constructor for class org.apache.flink.streaming.runtime.io.StreamTwoInputProcessor
 
StreamWriterBase<T> - Class in org.apache.flink.streaming.connectors.fs
Base class for Writers that write to a FSDataOutputStream.
StreamWriterBase() - Constructor for class org.apache.flink.streaming.connectors.fs.StreamWriterBase
 
STRING - Static variable in class org.apache.flink.api.common.typeinfo.Types
 
STRING() - Method in class org.apache.flink.table.api.Types$
 
STRING() - Static method in class org.apache.flink.table.api.Types
 
STRING() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
STRING() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
string2Literal(String) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionConversions
 
STRING_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
STRING_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
STRING_VALUE_ARRAY_TYPE_INFO - Static variable in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
 
STRING_VALUE_TYPE_INFO - Static variable in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
StringArraySerializer - Class in org.apache.flink.api.common.typeutils.base.array
A serializer for String arrays.
StringArraySerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.array.StringArraySerializer
 
StringBasedID - Class in org.apache.flink.util
Base class for typed IDs that are internally represented by a string.
StringBasedID(String) - Constructor for class org.apache.flink.util.StringBasedID
Protected constructor to enfore that subclassing.
StringColumnSummary - Class in org.apache.flink.api.java.summarize
Summary for a column of Strings
StringColumnSummary(long, long, long, Integer, Integer, Double) - Constructor for class org.apache.flink.api.java.summarize.StringColumnSummary
 
StringComparator - Class in org.apache.flink.api.common.typeutils.base
 
StringComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.StringComparator
 
StringDeserializerMap - Class in org.apache.flink.python.api.functions.util
 
StringDeserializerMap() - Constructor for class org.apache.flink.python.api.functions.util.StringDeserializerMap
 
STRINGIFIED_NULL_EXCEPTION - Static variable in class org.apache.flink.util.ExceptionUtils
The stringified representation of a null exception reference
StringifiedAccumulatorResult - Class in org.apache.flink.runtime.accumulators
Container class that transports the result of an accumulator as set of strings.
StringifiedAccumulatorResult(String, String, String) - Constructor for class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
 
stringifyAccumulatorResults(Map<String, Accumulator<?, ?>>) - Static method in class org.apache.flink.runtime.accumulators.StringifiedAccumulatorResult
Flatten a map of accumulator names to Accumulator instances into an array of StringifiedAccumulatorResult values
stringifyException(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
Makes a string representation of the exception's stack trace, or "(null)", if the exception is null.
stringLiteral() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
stringLiteralFlink() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
stringLiteralFlink() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
StringMaxAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in String Max aggregate function
StringMaxAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.StringMaxAggFunction
 
StringMaxWithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in String Max with retraction aggregate function
StringMaxWithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.StringMaxWithRetractAggFunction
 
StringMinAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in String Min aggregate function
StringMinAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.StringMinAggFunction
 
StringMinWithRetractAggFunction - Class in org.apache.flink.table.functions.aggfunctions
Built-in String Min with retraction aggregate function
StringMinWithRetractAggFunction() - Constructor for class org.apache.flink.table.functions.aggfunctions.StringMinWithRetractAggFunction
 
StringParameter - Class in org.apache.flink.graph.drivers.parameter
A Parameter storing a String.
StringParameter(ParameterizedBase, String) - Constructor for class org.apache.flink.graph.drivers.parameter.StringParameter
Set the parameter name and add this parameter to the list of parameters stored by owner.
StringParser - Class in org.apache.flink.types.parser
Converts a variable length field of a byte array into a String.
StringParser() - Constructor for class org.apache.flink.types.parser.StringParser
 
StringSerializer - Class in org.apache.flink.api.common.typeutils.base
 
StringSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.StringSerializer
 
StringSerializer() - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.StringSerializer
 
StringSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
 
StringSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.StringSummaryAggregator
 
StringTriple() - Constructor for class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator.StringTriple
 
StringTriple(String, String, String) - Constructor for class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator.StringTriple
 
StringTupleDeserializerMap - Class in org.apache.flink.python.api.functions.util
 
StringTupleDeserializerMap() - Constructor for class org.apache.flink.python.api.functions.util.StringTupleDeserializerMap
 
StringUtils - Class in org.apache.flink.util
Utility class to convert objects into strings in vice-versa.
StringValue - Class in org.apache.flink.types
Mutable string data type that implements the Key interface.
StringValue() - Constructor for class org.apache.flink.types.StringValue
Initializes the encapsulated String object with an empty string.
StringValue(CharSequence) - Constructor for class org.apache.flink.types.StringValue
Initializes this StringValue to the value of the given string.
StringValue(StringValue) - Constructor for class org.apache.flink.types.StringValue
Initializes this StringValue to a copy the given StringValue.
StringValue(StringValue, int, int) - Constructor for class org.apache.flink.types.StringValue
Initializes the StringValue to a sub-string of the given StringValue.
StringValueArray - Class in org.apache.flink.graph.types.valuearray
An array of StringValue.
StringValueArray() - Constructor for class org.apache.flink.graph.types.valuearray.StringValueArray
Initializes an expandable array with default capacity.
StringValueArray(int) - Constructor for class org.apache.flink.graph.types.valuearray.StringValueArray
Initializes a fixed-size array with the provided number of bytes.
StringValueArrayComparator - Class in org.apache.flink.graph.types.valuearray
Specialized comparator for StringValueArray based on CopyableValueComparator.
StringValueArrayComparator(boolean) - Constructor for class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
 
StringValueArraySerializer - Class in org.apache.flink.graph.types.valuearray
Specialized serializer for StringValueArray.
StringValueArraySerializer() - Constructor for class org.apache.flink.graph.types.valuearray.StringValueArraySerializer
 
StringValueComparator - Class in org.apache.flink.api.common.typeutils.base
Specialized comparator for StringValue based on CopyableValueComparator.
StringValueComparator(boolean) - Constructor for class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
StringValueParser - Class in org.apache.flink.types.parser
Converts a variable length field of a byte array into a StringValue.
StringValueParser() - Constructor for class org.apache.flink.types.parser.StringValueParser
 
StringValueSerializer - Class in org.apache.flink.api.common.typeutils.base
 
StringValueSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.StringValueSerializer
 
StringValueSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator.StringValueSummaryAggregator
 
StringValueUtils - Class in org.apache.flink.util
Utility class for efficient operations on StringValue.
StringValueUtils.WhitespaceTokenizer - Class in org.apache.flink.util
A tokenizer for string values that uses whitespace characters as token delimiters.
StringWriter<T> - Class in org.apache.flink.streaming.connectors.fs
A Writer that uses toString() on the input elements and writes them to the output bucket file separated by newline.
StringWriter() - Constructor for class org.apache.flink.streaming.connectors.fs.StringWriter
Creates a new StringWriter that uses "UTF-8" charset to convert strings to bytes.
StringWriter(String) - Constructor for class org.apache.flink.streaming.connectors.fs.StringWriter
Creates a new StringWriter that uses the given charset to convert strings to bytes.
stripProxy(T) - Static method in class org.apache.flink.util.WrappingProxyUtil
 
stub - Variable in class org.apache.flink.runtime.operators.BatchTask
The instantiated user code of this task's main operator (driver).
subComponents() - Method in class org.apache.flink.runtime.metrics.groups.ComponentMetricGroup
Gets all component metric groups that are contained in this component metric group.
subComponents() - Method in class org.apache.flink.runtime.metrics.groups.JobManagerJobMetricGroup
 
subComponents() - Method in class org.apache.flink.runtime.metrics.groups.JobManagerMetricGroup
 
subComponents() - Method in class org.apache.flink.runtime.metrics.groups.OperatorMetricGroup
 
subComponents() - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerJobMetricGroup
 
subComponents() - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
 
subComponents() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
subgraph(FilterFunction<Vertex<K, VV>>, FilterFunction<Edge<K, EV>>) - Method in class org.apache.flink.graph.Graph
Apply filtering functions to the graph and return a sub-graph that satisfies the predicates for both vertices and edges.
subgraph(FilterFunction<Vertex<K, VV>>, FilterFunction<Edge<K, EV>>) - Method in class org.apache.flink.graph.scala.Graph
Apply filtering functions to the graph and return a sub-graph that satisfies the predicates for both vertices and edges.
subgraph(Function1<Vertex<K, VV>, Object>, Function1<Edge<K, EV>, Object>) - Method in class org.apache.flink.graph.scala.Graph
Apply filtering functions to the graph and return a sub-graph that satisfies the predicates for both vertices and edges.
subject - Variable in class org.apache.flink.examples.java.misc.CollectionExecutionExample.EMail
 
subList(int, int) - Method in class org.apache.flink.types.ListValue
 
SubmissionTimeout$() - Constructor for class org.apache.flink.runtime.messages.JobClientMessages.SubmissionTimeout$
 
SUBMIT_BLOCKING - Static variable in class org.apache.flink.storm.api.FlinkLocalCluster
Configuration key to submit topology in blocking mode if flag is set to true.
submitJar(Map, String) - Static method in class org.apache.flink.storm.api.FlinkSubmitter
In Flink, jar files are submitted directly when a program is started.
submitJar(String) - Static method in class org.apache.flink.storm.api.FlinkSubmitter
In Flink, jar files are submitted directly when a program is started.
submitJob(JobGraph, ClassLoader) - Method in class org.apache.flink.client.program.ClusterClient
Calls the subclasses' submitJob method.
submitJob(JobGraph, ClassLoader) - Method in class org.apache.flink.client.program.StandaloneClusterClient
 
submitJob(ActorSystem, Configuration, HighAvailabilityServices, JobGraph, FiniteDuration, boolean, ClassLoader) - Static method in class org.apache.flink.runtime.client.JobClient
Submits a job to a Flink cluster (non-blocking) and returns a JobListeningContext which can be passed to awaitJobResult to get the result of the submission.
SubmitJob(JobGraph, ListeningBehaviour) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.SubmitJob
 
submitJob(JobGraph, ClassLoader) - Method in class org.apache.flink.yarn.YarnClusterClient
 
submitJob(JobGraph, ClassLoader) - Method in class org.apache.flink.yarn.YarnClusterClientV2
 
SubmitJob$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.SubmitJob$
 
submitJobAndWait(ActorSystem, Configuration, HighAvailabilityServices, JobGraph, FiniteDuration, boolean, ClassLoader) - Static method in class org.apache.flink.runtime.client.JobClient
Sends a [[JobGraph]] to the JobClient actor specified by jobClient which submits it then to the JobManager.
SubmitJobAndWait(JobGraph) - Constructor for class org.apache.flink.runtime.messages.JobClientMessages.SubmitJobAndWait
 
submitJobAndWait(JobGraph, boolean) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
submitJobAndWait(JobGraph, boolean, FiniteDuration) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
SubmitJobAndWait$() - Constructor for class org.apache.flink.runtime.messages.JobClientMessages.SubmitJobAndWait$
 
submitJobDetached(ActorGateway, Configuration, JobGraph, FiniteDuration, ClassLoader) - Static method in class org.apache.flink.runtime.client.JobClient
Submits a job in detached mode.
submitJobDetached(JobGraph) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
submitTask(TaskDeploymentDescriptor, Time) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
submitTask(TaskDeploymentDescriptor, Time) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Submit a task to the task manager.
submitTask(TaskDeploymentDescriptor, Time) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
SubmitTask(TaskDeploymentDescriptor) - Constructor for class org.apache.flink.runtime.messages.TaskMessages.SubmitTask
 
submitTask(TaskDeploymentDescriptor, UUID) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
submitTask(TaskDeploymentDescriptor, UUID, Time) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Submit a Task to the TaskExecutor.
SubmitTask$() - Constructor for class org.apache.flink.runtime.messages.TaskMessages.SubmitTask$
 
SubmittedJobGraph - Class in org.apache.flink.runtime.jobmanager
A recoverable JobGraph and JobInfo.
SubmittedJobGraph(JobGraph, JobInfo) - Constructor for class org.apache.flink.runtime.jobmanager.SubmittedJobGraph
submittedJobGraph() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RecoverSubmittedJob
 
submittedJobGraphs() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
SubmittedJobGraphStore - Interface in org.apache.flink.runtime.jobmanager
SubmittedJobGraph instances for recovery.
SubmittedJobGraphStore.SubmittedJobGraphListener - Interface in org.apache.flink.runtime.jobmanager
A listener for SubmittedJobGraph instances.
submitTopology(String, String, FlinkTopology) - Method in class org.apache.flink.storm.api.FlinkClient
Parameter uploadedJarLocation is actually used to point to the local jar, because Flink does not support uploading a jar file before hand.
submitTopology(String, Map, FlinkTopology) - Method in class org.apache.flink.storm.api.FlinkLocalCluster
 
submitTopology(String, Map<?, ?>, FlinkTopology, SubmitOptions) - Static method in class org.apache.flink.storm.api.FlinkSubmitter
Submits a topology to run on the cluster.
submitTopology(String, Map, FlinkTopology) - Static method in class org.apache.flink.storm.api.FlinkSubmitter
Submits a topology to run on the cluster.
submitTopologyWithOpts(String, String, FlinkTopology) - Method in class org.apache.flink.storm.api.FlinkClient
Parameter uploadedJarLocation is actually used to point to the local jar, because Flink does not support uploading a jar file before hand.
submitTopologyWithOpts(String, Map, FlinkTopology, SubmitOptions) - Method in class org.apache.flink.storm.api.FlinkLocalCluster
 
submitTopologyWithProgressBar(String, Map<?, ?>, FlinkTopology) - Static method in class org.apache.flink.storm.api.FlinkSubmitter
SUBMULTISET_OF - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Submultiset.
subscribe(EventListener<TaskEvent>, Class<? extends TaskEvent>) - Method in class org.apache.flink.runtime.io.network.api.TaskEventHandler
 
subscribedPartitionStates() - Method in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
Gets all partitions (with partition state) that this fetcher is subscribed to.
subscribeToEvent(EventListener<TaskEvent>, Class<? extends TaskEvent>) - Method in class org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
 
subSequence(int, int) - Method in class org.apache.flink.types.StringValue
 
substituteDeprecatedConfigKey(Configuration, String, String) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
Sets the value of a new config key to the value of a deprecated config key.
substituteDeprecatedConfigPrefix(Configuration, String, String) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
Sets the value of of a new config key to the value of a deprecated config key.
SUBSTRING - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The character substring function: SUBSTRING(string FROM start [FOR length]).
substring(Expression, Expression) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Creates a substring of the given string at given index for a given length.
substring(Expression) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Creates a substring of the given string beginning at the given index to the end.
Substring - Class in org.apache.flink.table.expressions
Returns substring of str from begin(inclusive) for length.
Substring(Expression, Expression, Expression) - Constructor for class org.apache.flink.table.expressions.Substring
 
Substring(Expression, Expression) - Constructor for class org.apache.flink.table.expressions.Substring
 
substring(int) - Method in class org.apache.flink.types.StringValue
Returns a new StringValuestring that is a substring of this string.
substring(int, int) - Method in class org.apache.flink.types.StringValue
Returns a new StringValuestring that is a substring of this string.
substring(StringValue, int) - Method in class org.apache.flink.types.StringValue
Copies a substring of this string into the given target StringValue.
substring(StringValue, int, int) - Method in class org.apache.flink.types.StringValue
Copies a substring of this string into the given target StringValue.
Substring$ - Class in org.apache.flink.table.expressions
 
Substring$() - Constructor for class org.apache.flink.table.expressions.Substring$
 
SUBTASK_CURRENT_ATTEMPT_DETAILS_REST_PATH - Static variable in class org.apache.flink.runtime.webmonitor.handlers.SubtaskCurrentAttemptDetailsHandler
 
SubtaskCurrentAttemptDetailsHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Request handler providing details about a single task execution attempt.
SubtaskCurrentAttemptDetailsHandler(ExecutionGraphHolder, MetricFetcher) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.SubtaskCurrentAttemptDetailsHandler
 
SubtaskExecutionAttemptAccumulatorsHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Base class for request handlers whose response depends on a specific job vertex (defined via the "vertexid" parameter) in a specific job, defined via (defined voa the "jobid" parameter).
SubtaskExecutionAttemptAccumulatorsHandler(ExecutionGraphHolder) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.SubtaskExecutionAttemptAccumulatorsHandler
 
SubtaskExecutionAttemptAccumulatorsHandler.SubtaskExecutionAttemptAccumulatorsJsonArchivist - Class in org.apache.flink.runtime.webmonitor.handlers
 
SubtaskExecutionAttemptAccumulatorsJsonArchivist() - Constructor for class org.apache.flink.runtime.webmonitor.handlers.SubtaskExecutionAttemptAccumulatorsHandler.SubtaskExecutionAttemptAccumulatorsJsonArchivist
 
SubtaskExecutionAttemptDetailsHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Request handler providing details about a single task execution attempt.
SubtaskExecutionAttemptDetailsHandler(ExecutionGraphHolder, MetricFetcher) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.SubtaskExecutionAttemptDetailsHandler
 
SubtaskExecutionAttemptDetailsHandler.SubtaskExecutionAttemptDetailsJsonArchivist - Class in org.apache.flink.runtime.webmonitor.handlers
 
SubtaskExecutionAttemptDetailsJsonArchivist() - Constructor for class org.apache.flink.runtime.webmonitor.handlers.SubtaskExecutionAttemptDetailsHandler.SubtaskExecutionAttemptDetailsJsonArchivist
 
subtaskIndex() - Method in class org.apache.flink.runtime.messages.ExecutionGraphMessages.ExecutionStateChanged
 
subtaskIndex - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
 
subtaskIndex - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
 
subtaskIndex - Variable in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
subtaskIndex() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
SubtaskMetricStore() - Constructor for class org.apache.flink.runtime.webmonitor.metrics.MetricStore.SubtaskMetricStore
 
SubtasksAllAccumulatorsHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Request handler that returns the accumulators for all subtasks of job vertex.
SubtasksAllAccumulatorsHandler(ExecutionGraphHolder) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.SubtasksAllAccumulatorsHandler
 
SubtasksAllAccumulatorsHandler.SubtasksAllAccumulatorsJsonArchivist - Class in org.apache.flink.runtime.webmonitor.handlers
 
SubtasksAllAccumulatorsJsonArchivist() - Constructor for class org.apache.flink.runtime.webmonitor.handlers.SubtasksAllAccumulatorsHandler.SubtasksAllAccumulatorsJsonArchivist
 
SubtaskState - Class in org.apache.flink.migration.runtime.checkpoint
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
SubtaskState(SerializedValue<StateHandle<?>>, long, long) - Constructor for class org.apache.flink.migration.runtime.checkpoint.SubtaskState
Deprecated.
 
SubtaskState - Class in org.apache.flink.runtime.checkpoint
Container for the chained state of one parallel subtask of an operator/task.
SubtaskState(ChainedStateHandle<StreamStateHandle>, ChainedStateHandle<OperatorStateHandle>, ChainedStateHandle<OperatorStateHandle>, KeyedStateHandle, KeyedStateHandle) - Constructor for class org.apache.flink.runtime.checkpoint.SubtaskState
 
SubtaskStateStats - Class in org.apache.flink.runtime.checkpoint
Statistics for a single subtask that is part of a checkpoint.
SubtasksTimesHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Request handler that returns the state transition timestamps for all subtasks, plus their location and duration.
SubtasksTimesHandler(ExecutionGraphHolder) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.SubtasksTimesHandler
 
SubtasksTimesHandler.SubtasksTimesJsonArchivist - Class in org.apache.flink.runtime.webmonitor.handlers
 
SubtasksTimesJsonArchivist() - Constructor for class org.apache.flink.runtime.webmonitor.handlers.SubtasksTimesHandler.SubtasksTimesJsonArchivist
 
subtract(DistributedRowMatrix) - Method in class org.apache.flink.ml.math.distributed.DistributedRowMatrix
Subtracts another matrix from this matrix.
subtractCosts(Costs) - Method in class org.apache.flink.optimizer.costs.Costs
Subtracts the given costs from these costs.
subtype(Class<S>) - Method in class org.apache.flink.cep.pattern.Pattern
Applies a subtype constraint on the current pattern.
subtype(Class<S>) - Method in class org.apache.flink.cep.scala.pattern.Pattern
Applies a subtype constraint on the current pattern.
SubtypeCondition<T> - Class in org.apache.flink.cep.pattern.conditions
A condition which filters elements of the given type.
SubtypeCondition(Class<? extends T>) - Constructor for class org.apache.flink.cep.pattern.conditions.SubtypeCondition
 
SubtypeFilterFunction<T> - Class in org.apache.flink.cep.pattern
Deprecated.
This is only used when migrating from an older Flink version. Use the SubtypeCondition instead.

A filter function which filters elements of the given type. A element if filtered out iff it is not assignable to the given subtype of T.

SubtypeFilterFunction(Class<? extends T>) - Constructor for class org.apache.flink.cep.pattern.SubtypeFilterFunction
Deprecated.
 
SubUpdate() - Constructor for class org.apache.flink.examples.java.ml.LinearRegression.SubUpdate
 
SubUpdate() - Constructor for class org.apache.flink.examples.scala.ml.LinearRegression.SubUpdate
 
Success() - Constructor for class org.apache.flink.runtime.registration.RegistrationResponse.Success
 
success(T) - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
suffix(String) - Method in class org.apache.flink.core.fs.Path
Adds a suffix to the final name in the path.
suffixAs() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
suffixAs() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
suffixAsc() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
suffixAsc() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
suffixCast() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
suffixCast() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
suffixCeil() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
suffixCeil() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
suffixDesc() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
suffixDesc() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
suffixed() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
suffixed() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
suffixExtract() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
suffixExtract() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
suffixFlattening() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
suffixFlattening() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
suffixFloor() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
suffixFloor() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
suffixFunctionCall() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
suffixFunctionCall() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
suffixFunctionCallOneArg() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
suffixFunctionCallOneArg() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
suffixGet() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
suffixGet() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
suffixIf() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
suffixIf() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
suffixRowInterval() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
suffixRowInterval() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
suffixTimeInterval() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
suffixTimeInterval() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
suffixToDate() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
suffixToDate() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
suffixToTime() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
suffixToTime() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
suffixToTimestamp() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
suffixToTimestamp() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
suffixTrim() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
suffixTrim() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
suffixTrimWithoutArgs() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
suffixTrimWithoutArgs() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
SUM - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
SUM aggregate function.
sum(int) - Method in class org.apache.flink.api.java.DataSet
Syntactic sugar for aggregate (SUM, field)
sum(int) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Syntactic sugar for aggregate (SUM, field)
sum(int) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
sum(String) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
sum(int) - Method in class org.apache.flink.api.scala.DataSet
Syntactic sugar for aggregate with SUM
sum(String) - Method in class org.apache.flink.api.scala.DataSet
Syntactic sugar for aggregate with SUM
sum(int) - Method in class org.apache.flink.api.scala.GroupedDataSet
Syntactic sugar for aggregate with SUM
sum(String) - Method in class org.apache.flink.api.scala.GroupedDataSet
Syntactic sugar for aggregate with SUM
sum(M, M) - Method in class org.apache.flink.graph.gsa.SumFunction
This method is invoked once per superstep, after the GatherFunction in a GatherSumApplyIteration.
sum(int) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies an aggregation that sums every window of the data stream at the given position.
sum(String) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Applies an aggregation that sums every window of the pojo data stream at the given field for every window.
sum(int) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Applies an aggregation that gives a rolling sum of the data stream at the given position grouped by the given key.
sum(String) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Applies an aggregation that gives the current sum of the data stream at the given field by the given key.
sum(int) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies an aggregation that sums every window of the data stream at the given position.
sum(String) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Applies an aggregation that sums every window of the pojo data stream at the given field for every window.
sum(int) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Applies an aggregation that sums the elements in the window at the given position.
sum(String) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Applies an aggregation that sums the elements in the window at the given field.
sum(int) - Method in class org.apache.flink.streaming.api.scala.KeyedStream
Applies an aggregation that sums the data stream at the given position by the given key.
sum(String) - Method in class org.apache.flink.streaming.api.scala.KeyedStream
Applies an aggregation that sums the data stream at the given field by the given key.
sum(int) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Applies an aggregation that sums the elements in the window at the given position.
sum(String) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Applies an aggregation that sums the elements in the window at the given field.
sum() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Returns the sum of the numeric field across all input values.
sum(boolean, String, RexNode) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
Sum - Class in org.apache.flink.table.expressions
 
Sum(Expression) - Constructor for class org.apache.flink.table.expressions.Sum
 
Sum() - Constructor for class org.apache.flink.table.runtime.triggers.StateCleaningCountTrigger.Sum
 
Sum$ - Class in org.apache.flink.table.expressions
 
Sum$() - Constructor for class org.apache.flink.table.expressions.Sum$
 
SUM0 - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
SUM0 aggregate function.
sum0() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Returns the sum of the numeric field across all input values.
Sum0 - Class in org.apache.flink.table.expressions
 
Sum0(Expression) - Constructor for class org.apache.flink.table.expressions.Sum0
 
Sum0$ - Class in org.apache.flink.table.expressions
 
Sum0$() - Constructor for class org.apache.flink.table.expressions.Sum0$
 
Sum0AggFunction<T> - Class in org.apache.flink.table.functions.aggfunctions
Base class for built-in Sum0 aggregate function.
Sum0AggFunction(Numeric<T>) - Constructor for class org.apache.flink.table.functions.aggfunctions.Sum0AggFunction
 
Sum0WithRetractAggFunction<T> - Class in org.apache.flink.table.functions.aggfunctions
Base class for built-in Sum0 with retract aggregate function.
Sum0WithRetractAggFunction(Numeric<T>) - Constructor for class org.apache.flink.table.functions.aggfunctions.Sum0WithRetractAggFunction
 
SumAccumulator<T> - Class in org.apache.flink.table.functions.aggfunctions
The initial accumulator for Sum aggregate function
SumAccumulator() - Constructor for class org.apache.flink.table.functions.aggfunctions.SumAccumulator
 
SumAggFunction<T> - Class in org.apache.flink.table.functions.aggfunctions
Base class for built-in Sum aggregate function
SumAggFunction(Numeric<T>) - Constructor for class org.apache.flink.table.functions.aggfunctions.SumAggFunction
 
SumAggregationFunction<T> - Class in org.apache.flink.api.java.aggregation
 
SumAggregationFunction() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction
 
SumAggregationFunction.ByteSumAgg - Class in org.apache.flink.api.java.aggregation
 
SumAggregationFunction.ByteValueSumAgg - Class in org.apache.flink.api.java.aggregation
 
SumAggregationFunction.DoubleSumAgg - Class in org.apache.flink.api.java.aggregation
 
SumAggregationFunction.DoubleValueSumAgg - Class in org.apache.flink.api.java.aggregation
 
SumAggregationFunction.FloatSumAgg - Class in org.apache.flink.api.java.aggregation
 
SumAggregationFunction.FloatValueSumAgg - Class in org.apache.flink.api.java.aggregation
 
SumAggregationFunction.IntSumAgg - Class in org.apache.flink.api.java.aggregation
 
SumAggregationFunction.IntValueSumAgg - Class in org.apache.flink.api.java.aggregation
 
SumAggregationFunction.LongSumAgg - Class in org.apache.flink.api.java.aggregation
 
SumAggregationFunction.LongValueSumAgg - Class in org.apache.flink.api.java.aggregation
 
SumAggregationFunction.ShortSumAgg - Class in org.apache.flink.api.java.aggregation
 
SumAggregationFunction.ShortValueSumAgg - Class in org.apache.flink.api.java.aggregation
 
SumAggregationFunction.SumAggregationFunctionFactory - Class in org.apache.flink.api.java.aggregation
 
SumAggregationFunctionFactory() - Constructor for class org.apache.flink.api.java.aggregation.SumAggregationFunction.SumAggregationFunctionFactory
 
SumAggregator<T> - Class in org.apache.flink.streaming.api.functions.aggregation
An AggregationFunction that sums up fields.
SumAggregator(int, TypeInformation<T>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumAggregator
 
SumAggregator(String, TypeInformation<T>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumAggregator
 
SumDoubleAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.DoubleSummaryAggregator.SumDoubleAggregator
 
SumFloatAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.FloatSummaryAggregator.SumFloatAggregator
 
SumFunction<VV,EV,M> - Class in org.apache.flink.graph.gsa
The base class for the second step of a GatherSumApplyIteration.
SumFunction() - Constructor for class org.apache.flink.graph.gsa.SumFunction
 
SumFunction - Class in org.apache.flink.streaming.api.functions.aggregation
Internal function for summing up contents of fields.
SumFunction() - Constructor for class org.apache.flink.streaming.api.functions.aggregation.SumFunction
 
SumIntegerAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.IntegerSummaryAggregator.SumIntegerAggregator
 
SumLongAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.LongSummaryAggregator.SumLongAggregator
 
Summarization<K,VV,EV> - Class in org.apache.flink.graph.library
The summarization algorithm computes a condensed version of the input graph
by grouping vertices and edges based on their values.
Summarization() - Constructor for class org.apache.flink.graph.library.Summarization
 
Summarization.EdgeValue<EV> - Class in org.apache.flink.graph.library
Value that is stored at a summarized edge.
Summarization.VertexGroupItem<K,VGV> - Class in org.apache.flink.graph.library
Represents a single vertex in a vertex group.
Summarization.VertexValue<VV> - Class in org.apache.flink.graph.library
Value that is stored at a summarized vertex.
Summarization.VertexWithRepresentative<K> - Class in org.apache.flink.graph.library
Represents a vertex identifier and its corresponding vertex group identifier.
SummarizationData - Class in org.apache.flink.graph.examples.data
Provides the default data set used for Summarization tests.
summarize(DataSet<T>) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Summarize a DataSet of Tuples by collecting single pass statistics for all columns Example usage:
SummaryAggregatorFactory - Class in org.apache.flink.api.java.summarize.aggregation
Factory for creating Summary Aggregators
SummaryAggregatorFactory() - Constructor for class org.apache.flink.api.java.summarize.aggregation.SummaryAggregatorFactory
 
SummingReducer() - Constructor for class org.apache.flink.streaming.examples.windowing.GroupedProcessingTimeWindowExample.SummingReducer
 
SummingWindowFunction() - Constructor for class org.apache.flink.streaming.examples.windowing.GroupedProcessingTimeWindowExample.SummingWindowFunction
 
SumReducer() - Constructor for class org.apache.flink.examples.java.misc.PiEstimation.SumReducer
 
SumShortAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ShortSummaryAggregator.SumShortAggregator
 
SumWithRetractAccumulator<T> - Class in org.apache.flink.table.functions.aggfunctions
The initial accumulator for Sum with retract aggregate function
SumWithRetractAccumulator() - Constructor for class org.apache.flink.table.functions.aggfunctions.SumWithRetractAccumulator
 
SumWithRetractAggFunction<T> - Class in org.apache.flink.table.functions.aggfunctions
Base class for built-in Sum with retract aggregate function
SumWithRetractAggFunction(Numeric<T>) - Constructor for class org.apache.flink.table.functions.aggfunctions.SumWithRetractAggFunction
 
superPrimitive(TypeInformation<?>) - Method in class org.apache.flink.table.codegen.CodeGenUtils$
 
superPrimitive(TypeInformation<?>) - Static method in class org.apache.flink.table.codegen.CodeGenUtils
 
SuperstepBarrier - Class in org.apache.flink.runtime.iterative.concurrent
A resettable one-shot latch.
SuperstepBarrier(ClassLoader) - Constructor for class org.apache.flink.runtime.iterative.concurrent.SuperstepBarrier
 
SuperstepKickoffLatch - Class in org.apache.flink.runtime.iterative.concurrent
 
SuperstepKickoffLatch() - Constructor for class org.apache.flink.runtime.iterative.concurrent.SuperstepKickoffLatch
 
SuperstepKickoffLatchBroker - Class in org.apache.flink.runtime.iterative.concurrent
 
supervisorStrategy() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
supervisorStrategy() - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
supervisorStrategy() - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
supervisorStrategy() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
supervisorStrategy() - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
supervisorStrategy() - Method in class org.apache.flink.mesos.scheduler.Tasks
 
supervisorStrategy() - Static method in class org.apache.flink.runtime.jobmanager.JobManager
 
supervisorStrategy() - Static method in class org.apache.flink.runtime.taskmanager.TaskManager
 
supervisorStrategy() - Static method in class org.apache.flink.yarn.ApplicationClient
 
supervisorStrategy() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
supplyAsync(Callable<T>, Executor) - Static method in class org.apache.flink.runtime.concurrent.impl.FlinkFuture
Creates a future whose value is determined by the asynchronously executed callable.
supportsAsynchronousSnapshots() - Method in class org.apache.flink.contrib.streaming.state.RocksDBKeyedStateBackend
 
supportsAsynchronousSnapshots() - Method in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
supportsAsynchronousSnapshots() - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
supportsCompareAgainstReference() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
 
supportsCompareAgainstReference() - Static method in class org.apache.flink.api.scala.typeutils.OptionTypeComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.BigDecComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.BigIntComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.BooleanComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.ByteComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.CharComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.DateComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.DoubleComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.EnumComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.FloatComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.IntComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.LongComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.ShortComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.SqlTimestampComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Checks whether the data type supports the creation of a normalized key for comparison.
supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.scala.typeutils.EnumValueComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.api.scala.typeutils.OptionTypeComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
 
supportsNormalizedKey() - Method in class org.apache.flink.table.runtime.types.CRowComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.BigDecComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.BigIntComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.StringComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Check whether this comparator supports to serialize the record in a format that replaces its keys by a normalized key.
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.scala.typeutils.EnumValueComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.api.scala.typeutils.OptionTypeComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
 
supportsSerializationWithKeyNormalization() - Method in class org.apache.flink.table.runtime.types.CRowComparator
 
SuppressRestartsException - Exception in org.apache.flink.runtime.execution
Exception thrown in order to suppress job restarts.
SuppressRestartsException(Throwable) - Constructor for exception org.apache.flink.runtime.execution.SuppressRestartsException
 
suspend(Throwable) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Suspends the current ExecutionGraph.
suspend() - Method in class org.apache.flink.runtime.instance.SlotPool
Suspends this pool, meaning it has lost its authority to accept and distribute slots.
suspend() - Method in interface org.apache.flink.runtime.instance.SlotPoolGateway
 
suspend() - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Suspends the component.
Suspended$() - Constructor for class org.apache.flink.mesos.scheduler.LaunchCoordinator.Suspended$
 
Suspended$() - Constructor for class org.apache.flink.mesos.scheduler.ReconciliationCoordinator.Suspended$
 
Suspended$() - Constructor for class org.apache.flink.mesos.scheduler.TaskMonitor.Suspended$
 
suspendExecution(Throwable) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
Suspending job, all the running tasks will be cancelled, and communication with other components will be disposed.
suspendExecution(Throwable) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
 
SVM - Class in org.apache.flink.ml.classification
Implements a soft-margin SVM using the communication-efficient distributed dual coordinate ascent algorithm (CoCoA) with hinge-loss function.
SVM() - Constructor for class org.apache.flink.ml.classification.SVM
 
SVM$ - Class in org.apache.flink.ml.classification
Companion object of SVM.
SVM$() - Constructor for class org.apache.flink.ml.classification.SVM$
 
SVM.Blocks$ - Class in org.apache.flink.ml.classification
 
SVM.Iterations$ - Class in org.apache.flink.ml.classification
 
SVM.LocalIterations$ - Class in org.apache.flink.ml.classification
 
SVM.OutputDecisionFunction$ - Class in org.apache.flink.ml.classification
 
SVM.Regularization$ - Class in org.apache.flink.ml.classification
 
SVM.Seed$ - Class in org.apache.flink.ml.classification
 
SVM.Stepsize$ - Class in org.apache.flink.ml.classification
 
SVM.ThresholdValue$ - Class in org.apache.flink.ml.classification
 
swap() - Method in class org.apache.flink.api.java.tuple.Tuple2
Returns a shallow copy of the tuple with swapped values.
swap(int, int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
swap(int, int, int, int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
swap(int, int) - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
Swap items at the given addresses.
swap(int, int, int, int) - Method in interface org.apache.flink.runtime.operators.sort.IndexedSortable
Swap records at the given addresses.
swap(int, int) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
swap(int, int, int, int) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
swapBytes(byte[], MemorySegment, int, int, int) - Method in class org.apache.flink.core.memory.MemorySegment
Swaps bytes between two memory segments, using the given auxiliary buffer.
swapUnionNodes(PlanNode) - Method in class org.apache.flink.optimizer.plan.Channel
Utility method used while swapping binary union nodes for n-ary union nodes.
switchBuffers() - Method in class org.apache.flink.runtime.iterative.io.SerializedUpdateBuffer
 
Symbol - Class in org.apache.flink.contrib.tweetinputformat.model.tweet.entities
An array of financial symbols starting with the dollar sign extracted from the Tweet text.
Symbol() - Constructor for class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.Symbol
 
symbol() - Method in class org.apache.flink.table.expressions.SymbolExpression
 
symbol2FieldExpression(Symbol) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionConversions
 
SymbolExpression - Class in org.apache.flink.table.expressions
General expression class to represent a symbol.
SymbolExpression(TableSymbol) - Constructor for class org.apache.flink.table.expressions.SymbolExpression
 
SymbolExpression$ - Class in org.apache.flink.table.expressions
 
SymbolExpression$() - Constructor for class org.apache.flink.table.expressions.SymbolExpression$
 
symbols() - Method in interface org.apache.flink.table.expressions.TableSymbol
 
symbols() - Method in class org.apache.flink.table.expressions.TableSymbols.TableSymbolValue
 
symbolToExpression(TableSymbols.TableSymbolValue) - Method in class org.apache.flink.table.expressions.TableSymbols
 
symbolToExpression(TableSymbols.TableSymbolValue) - Static method in class org.apache.flink.table.expressions.TimeIntervalUnit
 
symbolToExpression(TableSymbols.TableSymbolValue) - Static method in class org.apache.flink.table.expressions.TimePointUnit
 
symbolToExpression(TableSymbols.TableSymbolValue) - Static method in class org.apache.flink.table.expressions.TrimMode
 
SYMMETRIC_BETWEEN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
SYMMETRIC_NOT_BETWEEN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
sync() - Method in class org.apache.flink.core.fs.FSDataOutputStream
Flushes the data all the way to the persistent non-volatile storage (for example disks).
sync() - Method in class org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
sync() - Method in class org.apache.flink.core.fs.local.LocalDataOutputStream
 
sync() - Method in class org.apache.flink.core.testutils.CheckedThread
Waits until the thread is completed and checks whether any error occurred during the execution.
sync() - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataOutputStream
 
sync() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
 
sync() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
 
SyncEventHandler - Class in org.apache.flink.runtime.iterative.task
 
SyncEventHandler(int, Map<String, Aggregator<?>>, ClassLoader) - Constructor for class org.apache.flink.runtime.iterative.task.SyncEventHandler
 
SynchronousBufferFileReader - Class in org.apache.flink.runtime.io.disk.iomanager
A synchronous BufferFileReader implementation.
SynchronousBufferFileReader(FileIOChannel.ID, boolean) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.SynchronousBufferFileReader
 
SynchronousChainedCombineDriver<IN,OUT> - Class in org.apache.flink.runtime.operators.chaining
The chained variant of the combine driver which is also implemented in GroupReduceCombineDriver.
SynchronousChainedCombineDriver() - Constructor for class org.apache.flink.runtime.operators.chaining.SynchronousChainedCombineDriver
 
SynchronousFileIOChannel - Class in org.apache.flink.runtime.io.disk.iomanager
A base class for synchronous readers and writers.
SynchronousFileIOChannel(FileIOChannel.ID, boolean) - Constructor for class org.apache.flink.runtime.io.disk.iomanager.SynchronousFileIOChannel
 
syr(double, Vector, DenseMatrix) - Method in class org.apache.flink.ml.math.BLAS$
A := alpha * x * x^T^ + A
syr(double, Vector, DenseMatrix) - Static method in class org.apache.flink.ml.math.BLAS
A := alpha * x * x^T^ + A
SYSTEM_USER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The SYSTEM_USER function.
SystemClock - Class in org.apache.flink.runtime.util.clock
A clock that returns the time of the system / process.
SystemClock - Class in org.apache.flink.streaming.connectors.fs
A Clock that uses System.currentTimeMillis() to determine the system time.
SystemClock() - Constructor for class org.apache.flink.streaming.connectors.fs.SystemClock
 
SystemProcessingTimeService - Class in org.apache.flink.streaming.runtime.tasks
A ProcessingTimeService which assigns as current processing time the result of calling System.currentTimeMillis() and registers timers using a ScheduledThreadPoolExecutor.
SystemProcessingTimeService(AsyncExceptionHandler, Object) - Constructor for class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
 
SystemProcessingTimeService(AsyncExceptionHandler, Object, ThreadFactory) - Constructor for class org.apache.flink.streaming.runtime.tasks.SystemProcessingTimeService
 

T

table - Variable in class org.apache.flink.addons.hbase.AbstractTableInputFormat
 
table() - Method in class org.apache.flink.table.api.GroupedTable
 
table() - Method in class org.apache.flink.table.api.OverWindowedTable
 
Table - Class in org.apache.flink.table.api
A Table is the core component of the Table API.
Table(TableEnvironment, LogicalNode) - Constructor for class org.apache.flink.table.api.Table
 
Table(TableEnvironment, String) - Constructor for class org.apache.flink.table.api.Table
Creates a Table for a TableFunction call from a String expression.
table() - Method in exception org.apache.flink.table.api.TableAlreadyExistException
 
table() - Method in exception org.apache.flink.table.api.TableNotExistException
 
table() - Method in class org.apache.flink.table.api.WindowedTable
 
table() - Method in class org.apache.flink.table.api.WindowGroupedTable
 
TABLE_CONV_RULES() - Method in class org.apache.flink.table.plan.rules.FlinkRuleSets$
Convert a logical table scan to a relational expression.
TABLE_CONV_RULES() - Static method in class org.apache.flink.table.plan.rules.FlinkRuleSets
Convert a logical table scan to a relational expression.
TableAlreadyExistException - Exception in org.apache.flink.table.api
Exception for adding an already existent table
TableAlreadyExistException(String, String, Throwable) - Constructor for exception org.apache.flink.table.api.TableAlreadyExistException
 
TableAlreadyExistException(String, String) - Constructor for exception org.apache.flink.table.api.TableAlreadyExistException
 
TableAlreadyExistException$ - Class in org.apache.flink.table.api
 
TableAlreadyExistException$() - Constructor for class org.apache.flink.table.api.TableAlreadyExistException$
 
TableConfig - Class in org.apache.flink.table.api
A config to define the runtime behavior of the Table API.
TableConfig() - Constructor for class org.apache.flink.table.api.TableConfig
 
TableConfig$ - Class in org.apache.flink.table.api
 
TableConfig$() - Constructor for class org.apache.flink.table.api.TableConfig$
 
TableConversions - Class in org.apache.flink.table.api.scala
Holds methods to convert a Table into a DataSet or a DataStream.
TableConversions(Table) - Constructor for class org.apache.flink.table.api.scala.TableConversions
 
tableEnv() - Method in class org.apache.flink.table.api.Table
 
TableEnvironment - Class in org.apache.flink.table.api
The abstract base class for batch and stream TableEnvironments.
TableEnvironment(TableConfig) - Constructor for class org.apache.flink.table.api.TableEnvironment
 
TableEnvironment$ - Class in org.apache.flink.table.api
Object to instantiate a TableEnvironment depending on the batch or stream execution environment.
TableEnvironment$() - Constructor for class org.apache.flink.table.api.TableEnvironment$
 
TableException - Exception in org.apache.flink.table.api
General Exception for all errors during table handling.
TableException(String, Throwable) - Constructor for exception org.apache.flink.table.api.TableException
 
TableException(String) - Constructor for exception org.apache.flink.table.api.TableException
 
TableException$ - Class in org.apache.flink.table.api
 
TableException$() - Constructor for class org.apache.flink.table.api.TableException$
 
tableFunction() - Method in class org.apache.flink.table.expressions.TableFunctionCall
 
TableFunction<T> - Class in org.apache.flink.table.functions
Base class for a user-defined table function (UDTF).
TableFunction() - Constructor for class org.apache.flink.table.functions.TableFunction
 
tableFunction() - Method in class org.apache.flink.table.plan.logical.LogicalTableFunctionCall
 
TableFunctionCall - Class in org.apache.flink.table.expressions
Expression for calling a user-defined table function with actual parameters.
TableFunctionCall(String, TableFunction<?>, Seq<Expression>, TypeInformation<?>) - Constructor for class org.apache.flink.table.expressions.TableFunctionCall
 
TableFunctionCall$ - Class in org.apache.flink.table.expressions
 
TableFunctionCall$() - Constructor for class org.apache.flink.table.expressions.TableFunctionCall$
 
TableFunctionCallGen - Class in org.apache.flink.table.codegen.calls
Generates a call to user-defined TableFunction.
TableFunctionCallGen(TableFunction<?>, Seq<TypeInformation<?>>, TypeInformation<?>) - Constructor for class org.apache.flink.table.codegen.calls.TableFunctionCallGen
 
TableFunctionCollector<T> - Class in org.apache.flink.table.runtime
The basic implementation of collector for TableFunction.
TableFunctionCollector() - Constructor for class org.apache.flink.table.runtime.TableFunctionCollector
 
TableFunctionConversions<T> - Class in org.apache.flink.table.api.scala
Holds methods to convert a TableFunction call in the Scala Table API into a Table.
TableFunctionConversions(TableFunction<T>) - Constructor for class org.apache.flink.table.api.scala.TableFunctionConversions
 
TableInputFormat<T extends Tuple> - Class in org.apache.flink.addons.hbase
InputFormat subclass that wraps the access for HTables.
TableInputFormat() - Constructor for class org.apache.flink.addons.hbase.TableInputFormat
 
TableInputSplit - Class in org.apache.flink.addons.hbase
This class implements a input splits for HBase.
tableName() - Method in class org.apache.flink.table.api.Table
 
TableNotExistException - Exception in org.apache.flink.table.api
Exception for an operation on a nonexistent table
TableNotExistException(String, String, Throwable) - Constructor for exception org.apache.flink.table.api.TableNotExistException
 
TableNotExistException(String, String) - Constructor for exception org.apache.flink.table.api.TableNotExistException
 
TableNotExistException$ - Class in org.apache.flink.table.api
 
TableNotExistException$() - Constructor for class org.apache.flink.table.api.TableNotExistException$
 
tablePath() - Method in class org.apache.flink.table.plan.logical.CatalogNode
 
TABLESAMPLE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The TABLESAMPLE operator.
TableSchema - Class in org.apache.flink.table.api
A TableSchema represents a Table's structure.
TableSchema(String[], TypeInformation<?>[]) - Constructor for class org.apache.flink.table.api.TableSchema
 
TableSink<T> - Interface in org.apache.flink.table.sinks
A TableSink specifies how to emit a Table to an external system or location.
TableSinkBase<T> - Interface in org.apache.flink.table.sinks
 
tableSource() - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
tableSource() - Method in class org.apache.flink.table.plan.nodes.PhysicalTableSourceScan
 
tableSource() - Method in class org.apache.flink.table.plan.schema.StreamTableSourceTable
 
tableSource() - Method in class org.apache.flink.table.plan.schema.TableSourceTable
 
TableSource<T> - Interface in org.apache.flink.table.sources
Defines an external table by providing schema information and used to produce a DataSet or DataStream.
TableSourceConverter<T extends TableSource<?>> - Interface in org.apache.flink.table.catalog
Creates a TableSource from the properties of an ExternalCatalogTable.
TableSourceTable<T> - Class in org.apache.flink.table.plan.schema
Table which defines an external table via a TableSource
TableSourceTable(TableSource<T>, FlinkStatistic) - Constructor for class org.apache.flink.table.plan.schema.TableSourceTable
 
TableSourceTable$ - Class in org.apache.flink.table.plan.schema
 
TableSourceTable$() - Constructor for class org.apache.flink.table.plan.schema.TableSourceTable$
 
TableSqlFunction - Class in org.apache.flink.table.functions.utils
Calcite wrapper for user-defined table functions.
TableSqlFunction(String, TableFunction<?>, TypeInformation<?>, SqlReturnTypeInference, SqlOperandTypeInference, SqlOperandTypeChecker, List<RelDataType>, FlinkTableFunctionImpl<?>) - Constructor for class org.apache.flink.table.functions.utils.TableSqlFunction
 
TableSqlFunction$ - Class in org.apache.flink.table.functions.utils
 
TableSqlFunction$() - Constructor for class org.apache.flink.table.functions.utils.TableSqlFunction$
 
TableStats - Class in org.apache.flink.table.plan.stats
Table statistics
TableStats(Long, Map<String, ColumnStats>) - Constructor for class org.apache.flink.table.plan.stats.TableStats
 
TableStats$ - Class in org.apache.flink.table.plan.stats
 
TableStats$() - Constructor for class org.apache.flink.table.plan.stats.TableStats$
 
TableSymbol - Interface in org.apache.flink.table.expressions
Symbol that wraps a Calcite symbol in form of a Java enum.
TableSymbols - Class in org.apache.flink.table.expressions
Enumeration of symbols.
TableSymbols() - Constructor for class org.apache.flink.table.expressions.TableSymbols
 
TableSymbols.TableSymbolValue - Class in org.apache.flink.table.expressions
 
TableSymbolValue(Enum<?>) - Constructor for class org.apache.flink.table.expressions.TableSymbols.TableSymbolValue
 
TableType - Annotation Type in org.apache.flink.table.annotation
Annotates a table type of a TableSourceConverter.
tableType() - Method in exception org.apache.flink.table.api.AmbiguousTableSourceConverterException
 
tableType() - Method in exception org.apache.flink.table.api.NoMatchedTableSourceConverterException
 
tableType() - Method in class org.apache.flink.table.catalog.ExternalCatalogTable
 
tagAsEvent() - Method in class org.apache.flink.runtime.io.network.buffer.Buffer
 
tagged(Value) - Static method in class org.apache.flink.api.java.sca.UdfAnalyzerUtils
 
TaggedValue - Class in org.apache.flink.api.java.sca
Extension of ASM's BasicValue that allows to assign "tags" to values and add additional information depending on the tag to the Value.
TaggedValue(Type) - Constructor for class org.apache.flink.api.java.sca.TaggedValue
 
TaggedValue(Type, TaggedValue.Tag) - Constructor for class org.apache.flink.api.java.sca.TaggedValue
 
TaggedValue(Type, TaggedValue.Input, String, boolean, boolean) - Constructor for class org.apache.flink.api.java.sca.TaggedValue
 
TaggedValue(Type, Map<String, TaggedValue>) - Constructor for class org.apache.flink.api.java.sca.TaggedValue
 
TaggedValue(int) - Constructor for class org.apache.flink.api.java.sca.TaggedValue
 
TaggedValue.Input - Enum in org.apache.flink.api.java.sca
 
TaggedValue.Tag - Enum in org.apache.flink.api.java.sca
 
TAGS - Static variable in class org.apache.flink.metrics.datadog.DatadogHttpReporter
 
takeNext(BlockingQueue<UnilateralSortMerger.CircularElement<E>>, Queue<UnilateralSortMerger.CircularElement<E>>) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 
takeStep(Vector, Vector, RegularizationPenalty, double, double) - Method in class org.apache.flink.ml.optimization.GradientDescent
Calculates the new weights based on the gradient
takeStep(Vector, Vector, double, double) - Method in class org.apache.flink.ml.optimization.L1Regularization$
Calculates the new weights based on the gradient and L1 regularization penalty
takeStep(Vector, Vector, double, double) - Static method in class org.apache.flink.ml.optimization.L1Regularization
Calculates the new weights based on the gradient and L1 regularization penalty
takeStep(Vector, Vector, double, double) - Method in class org.apache.flink.ml.optimization.L2Regularization$
Calculates the new weights based on the gradient and L2 regularization penalty
takeStep(Vector, Vector, double, double) - Static method in class org.apache.flink.ml.optimization.L2Regularization
Calculates the new weights based on the gradient and L2 regularization penalty
takeStep(Vector, Vector, double, double) - Method in class org.apache.flink.ml.optimization.NoRegularization$
Calculates the new weights based on the gradient
takeStep(Vector, Vector, double, double) - Static method in class org.apache.flink.ml.optimization.NoRegularization
Calculates the new weights based on the gradient
takeStep(Vector, Vector, double, double) - Method in interface org.apache.flink.ml.optimization.RegularizationPenalty
Calculates the new weights based on the gradient and regularization penalty
TAN - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
tan() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Calculates the tangent of a given number.
TAN() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
TAN() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
Tan - Class in org.apache.flink.table.expressions
 
Tan(Expression) - Constructor for class org.apache.flink.table.expressions.Tan
 
Tan$ - Class in org.apache.flink.table.expressions
 
Tan$() - Constructor for class org.apache.flink.table.expressions.Tan$
 
TAN_DEC() - Method in class org.apache.flink.table.codegen.calls.BuiltInMethods$
 
TAN_DEC() - Static method in class org.apache.flink.table.codegen.calls.BuiltInMethods
 
TanimotoDistanceMetric - Class in org.apache.flink.ml.metrics.distances
This class implements a Tanimoto distance metric.
TanimotoDistanceMetric() - Constructor for class org.apache.flink.ml.metrics.distances.TanimotoDistanceMetric
 
TanimotoDistanceMetric$ - Class in org.apache.flink.ml.metrics.distances
 
TanimotoDistanceMetric$() - Constructor for class org.apache.flink.ml.metrics.distances.TanimotoDistanceMetric$
 
targetId() - Method in class org.apache.flink.examples.scala.graph.PageRankBasic.Link
 
targetIds() - Method in class org.apache.flink.examples.scala.graph.PageRankBasic.AdjacencyList
 
targetPartition - Variable in class org.apache.flink.runtime.io.network.api.writer.RecordWriter
 
task() - Method in class org.apache.flink.mesos.runtime.clusterframework.RegisteredMesosWorkerNode
 
Task - Class in org.apache.flink.runtime.taskmanager
The Task represents one execution of a parallel subtask on a TaskManager.
Task(JobInformation, TaskInformation, ExecutionAttemptID, AllocationID, int, int, Collection<ResultPartitionDeploymentDescriptor>, Collection<InputGateDeploymentDescriptor>, int, TaskStateHandles, MemoryManager, IOManager, NetworkEnvironment, BroadcastVariableManager, TaskManagerActions, InputSplitProvider, CheckpointResponder, LibraryCacheManager, FileCache, TaskManagerRuntimeInfo, TaskMetricGroup, ResultPartitionConsumableNotifier, PartitionProducerStateChecker, Executor) - Constructor for class org.apache.flink.runtime.taskmanager.Task
IMPORTANT: This constructor may not start any work that would need to be undone in the case of a failing task deployment.
TASK_CANCELLATION_INTERVAL - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Time interval in milliseconds between two successive task cancellation attempts.
TASK_CANCELLATION_INTERVAL_MILLIS - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
TASK_CANCELLATION_TIMEOUT - Static variable in class org.apache.flink.configuration.TaskManagerOptions
Timeout in milliseconds after which a task cancellation times out and leads to a fatal TaskManager error.
TASK_CHECKPOINT_ALIGNMENT_BYTES_LIMIT - Static variable in class org.apache.flink.configuration.TaskManagerOptions
The maximum number of bytes that a checkpoint alignment may buffer.
TASK_ID_PATTERN - Static variable in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
Pattern replaced in the MesosTaskManagerParameters.MESOS_TM_HOSTNAME by the actual task id of the Mesos task
TASK_MANAGER_DATA_PORT_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
The config parameter defining the task manager's data port from the configuration.
TASK_MANAGER_DATA_SSL_ENABLED - Static variable in class org.apache.flink.configuration.ConfigConstants
Config parameter to override SSL support for taskmanager's data transport
TASK_MANAGER_DEBUG_MEMORY_USAGE_LOG_INTERVAL_MS - Static variable in class org.apache.flink.configuration.ConfigConstants
The interval (in ms) for the log thread to log the current memory usage.
TASK_MANAGER_DEBUG_MEMORY_USAGE_START_LOG_THREAD - Static variable in class org.apache.flink.configuration.ConfigConstants
Flag indicating whether to start a thread, which repeatedly logs the memory usage of the JVM.
TASK_MANAGER_HEAP_MEMORY - Static variable in class org.apache.flink.configuration.TaskManagerOptions
JVM heap size (in megabytes) for the TaskManagers
TASK_MANAGER_HOSTNAME_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
The config parameter defining the task manager's hostname.
TASK_MANAGER_ID_KEY - Static variable in class org.apache.flink.runtime.webmonitor.handlers.TaskManagersHandler
 
TASK_MANAGER_INITIAL_REGISTRATION_PAUSE - Static variable in class org.apache.flink.configuration.ConfigConstants
The initial registration pause between two consecutive registration attempts.
TASK_MANAGER_IPC_PORT_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
The config parameter defining the task manager's IPC port from the configuration.
TASK_MANAGER_LOG_PATH_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
The config parameter defining the taskmanager log file location
TASK_MANAGER_MAX_REGISTARTION_PAUSE - Static variable in class org.apache.flink.configuration.ConfigConstants
The maximum registration pause between two consecutive registration attempts.
TASK_MANAGER_MAX_REGISTRATION_DURATION - Static variable in class org.apache.flink.configuration.ConfigConstants
Defines the maximum time it can take for the TaskManager registration.
TASK_MANAGER_MEMORY_FRACTION_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
TASK_MANAGER_MEMORY_OFF_HEAP_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
TASK_MANAGER_MEMORY_PRE_ALLOCATE_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
TASK_MANAGER_MEMORY_SEGMENT_SIZE_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
TASK_MANAGER_MEMORY_SIZE - Static variable in class org.apache.flink.test.util.TestBaseUtils
 
TASK_MANAGER_MEMORY_SIZE_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
TASK_MANAGER_NAME - Static variable in class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
TASK_MANAGER_NETWORK_DEFAULT_IO_MODE - Static variable in class org.apache.flink.configuration.ConfigConstants
The implementation to use for spillable/spilled intermediate results, which have both synchronous and asynchronous implementations: "sync" or "async".
TASK_MANAGER_NETWORK_NUM_BUFFERS_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
TASK_MANAGER_NUM_TASK_SLOTS - Static variable in class org.apache.flink.configuration.ConfigConstants
The config parameter defining the number of task slots of a task manager.
TASK_MANAGER_REFUSED_REGISTRATION_PAUSE - Static variable in class org.apache.flink.configuration.ConfigConstants
The pause after a registration has been refused by the job manager before retrying to connect.
TASK_MANAGER_TMP_DIR_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
The config parameter defining the directories for temporary files.
TaskActions - Interface in org.apache.flink.runtime.taskmanager
Actions which can be performed on a Task.
TaskConfig - Class in org.apache.flink.runtime.operators.util
Configuration class which stores all relevant parameters required to set up the Pact tasks.
TaskConfig(Configuration) - Constructor for class org.apache.flink.runtime.operators.util.TaskConfig
Creates a new Task Config that wraps the given configuration.
taskContext - Variable in class org.apache.flink.runtime.operators.AbstractOuterJoinDriver
 
taskContext - Variable in class org.apache.flink.runtime.operators.JoinDriver
 
TaskContext<S,OT> - Interface in org.apache.flink.runtime.operators
The task context gives a driver (e.g., MapDriver, or JoinDriver) access to the runtime components and configuration that they can use to fulfil their task.
TaskDeploymentDescriptor - Class in org.apache.flink.runtime.deployment
A task deployment descriptor contains all the information necessary to deploy a task on a task manager.
TaskDeploymentDescriptor(SerializedValue<JobInformation>, SerializedValue<TaskInformation>, ExecutionAttemptID, AllocationID, int, int, int, TaskStateHandles, Collection<ResultPartitionDeploymentDescriptor>, Collection<InputGateDeploymentDescriptor>) - Constructor for class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
 
TaskEvent - Class in org.apache.flink.runtime.event
Subclasses of this event are recognized as custom events that are not part of the core flink runtime.
TaskEvent() - Constructor for class org.apache.flink.runtime.event.TaskEvent
 
TaskEventDispatcher - Class in org.apache.flink.runtime.io.network
The task event dispatcher dispatches events flowing backwards from a consuming task to the task producing the consumed result.
TaskEventDispatcher() - Constructor for class org.apache.flink.runtime.io.network.TaskEventDispatcher
 
TaskEventHandler - Class in org.apache.flink.runtime.io.network.api
The event handler manages EventListener instances and allows to to publish events to them.
TaskEventHandler() - Constructor for class org.apache.flink.runtime.io.network.api.TaskEventHandler
 
TaskException - Exception in org.apache.flink.runtime.taskexecutor.exceptions
Exception indicating a task related problem on the TaskExecutor.
TaskException(String) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.TaskException
 
TaskException(String, Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.TaskException
 
TaskException(Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.TaskException
 
taskExecutionState() - Method in class org.apache.flink.runtime.messages.TaskMessages.UpdateTaskExecutionState
 
TaskExecutionState - Class in org.apache.flink.runtime.taskmanager
This class represents an update about a task's execution state.
TaskExecutionState(JobID, ExecutionAttemptID, ExecutionState) - Constructor for class org.apache.flink.runtime.taskmanager.TaskExecutionState
Creates a new task execution state update, with no attached exception and no accumulators.
TaskExecutionState(JobID, ExecutionAttemptID, ExecutionState, Throwable) - Constructor for class org.apache.flink.runtime.taskmanager.TaskExecutionState
Creates a new task execution state update, with an attached exception but no accumulators.
TaskExecutionState(JobID, ExecutionAttemptID, ExecutionState, Throwable, AccumulatorSnapshot, IOMetrics) - Constructor for class org.apache.flink.runtime.taskmanager.TaskExecutionState
Creates a new task execution state update, with an attached exception.
TaskExecutionStateListener - Interface in org.apache.flink.runtime.taskmanager
 
TaskExecutor - Class in org.apache.flink.runtime.taskexecutor
TaskExecutor implementation.
TaskExecutor(RpcService, TaskManagerConfiguration, TaskManagerLocation, MemoryManager, IOManager, NetworkEnvironment, HighAvailabilityServices, HeartbeatServices, MetricRegistry, TaskManagerMetricGroup, BroadcastVariableManager, FileCache, TaskSlotTable, JobManagerTable, JobLeaderService, FatalErrorHandler) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
TaskExecutorConnection - Class in org.apache.flink.runtime.resourcemanager.registration
This class is responsible for grouping the TaskExecutorGateway and the InstanceID of a registered task executor.
TaskExecutorConnection(TaskExecutorGateway) - Constructor for class org.apache.flink.runtime.resourcemanager.registration.TaskExecutorConnection
 
TaskExecutorGateway - Interface in org.apache.flink.runtime.taskexecutor
TaskExecutor RPC gateway interface
TaskExecutorMetricsInitializer - Class in org.apache.flink.runtime.taskexecutor.utils
Utility class ot initialize TaskExecutor specific metrics.
TaskExecutorMetricsInitializer() - Constructor for class org.apache.flink.runtime.taskexecutor.utils.TaskExecutorMetricsInitializer
 
TaskExecutorRegistrationSuccess - Class in org.apache.flink.runtime.taskexecutor
Base class for responses from the ResourceManager to a registration attempt by a TaskExecutor.
TaskExecutorRegistrationSuccess(InstanceID, ResourceID, long) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
Create a new TaskExecutorRegistrationSuccess message.
TaskExecutorToResourceManagerConnection - Class in org.apache.flink.runtime.taskexecutor
The connection between a TaskExecutor and the ResourceManager.
TaskExecutorToResourceManagerConnection(Logger, RpcService, String, ResourceID, SlotReport, String, UUID, Executor, RegistrationConnectionListener<TaskExecutorRegistrationSuccess>) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskExecutorToResourceManagerConnection
 
TaskGoalStateUpdated(TaskMonitor.TaskGoalState) - Constructor for class org.apache.flink.mesos.scheduler.TaskMonitor.TaskGoalStateUpdated
 
TaskGoalStateUpdated$() - Constructor for class org.apache.flink.mesos.scheduler.TaskMonitor.TaskGoalStateUpdated$
 
taskID() - Method in class org.apache.flink.mesos.runtime.clusterframework.LaunchableMesosWorker
 
taskID() - Method in class org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore.Worker
Get the worker's task ID.
taskID() - Method in class org.apache.flink.mesos.scheduler.LaunchCoordinator.Unassign
 
taskID() - Method in class org.apache.flink.mesos.scheduler.TaskMonitor.Launched
 
taskID() - Method in class org.apache.flink.mesos.scheduler.TaskMonitor.New
 
taskID() - Method in class org.apache.flink.mesos.scheduler.TaskMonitor.Released
 
taskID() - Method in interface org.apache.flink.mesos.scheduler.TaskMonitor.TaskGoalState
 
taskID() - Method in class org.apache.flink.mesos.scheduler.TaskMonitor.TaskTerminated
 
taskID - Variable in class org.apache.flink.runtime.accumulators.AccumulatorRegistry
 
TASKID_FORMAT - Static variable in interface org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore
The template for naming the worker.
TaskInFinalState(ExecutionAttemptID) - Constructor for class org.apache.flink.runtime.messages.TaskMessages.TaskInFinalState
 
TaskInFinalState$() - Constructor for class org.apache.flink.runtime.messages.TaskMessages.TaskInFinalState$
 
TaskInfo - Class in org.apache.flink.api.common
Encapsulates task-specific information: name, index of subtask, parallelism and attempt number.
TaskInfo(String, int, int, int, int) - Constructor for class org.apache.flink.api.common.TaskInfo
 
TaskInformation - Class in org.apache.flink.runtime.executiongraph
Container class for operator/task specific information which are stored at the ExecutionJobVertex.
TaskInformation(JobVertexID, String, int, int, String, Configuration) - Constructor for class org.apache.flink.runtime.executiongraph.TaskInformation
 
TaskInputSplitProvider - Class in org.apache.flink.runtime.taskmanager
Implementation using ActorGateway to forward the messages.
TaskInputSplitProvider(ActorGateway, JobID, JobVertexID, ExecutionAttemptID, FiniteDuration) - Constructor for class org.apache.flink.runtime.taskmanager.TaskInputSplitProvider
 
TaskIOMetricGroup - Class in org.apache.flink.runtime.metrics.groups
Metric group that contains shareable pre-defined IO-related metrics.
TaskIOMetricGroup(TaskMetricGroup) - Constructor for class org.apache.flink.runtime.metrics.groups.TaskIOMetricGroup
 
TaskKvStateRegistry - Class in org.apache.flink.runtime.query
A helper for KvState registrations of a single task.
TaskManager - Class in org.apache.flink.runtime.taskmanager
The TaskManager is responsible for executing the individual tasks of a Flink job.
TaskManager(TaskManagerConfiguration, ResourceID, TaskManagerLocation, MemoryManager, IOManager, NetworkEnvironment, int, HighAvailabilityServices, MetricRegistry) - Constructor for class org.apache.flink.runtime.taskmanager.TaskManager
 
TaskManager$ - Class in org.apache.flink.runtime.taskmanager
TaskManager companion object.
TaskManager$() - Constructor for class org.apache.flink.runtime.taskmanager.TaskManager$
 
TaskManagerActions - Interface in org.apache.flink.runtime.taskmanager
Interface for the communication of the Task with the TaskManager.
taskManagerActors() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
taskManagerActorSystems() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
taskManagerClass() - Method in class org.apache.flink.runtime.minicluster.LocalFlinkMiniCluster
 
TaskManagerCliOptions - Class in org.apache.flink.runtime.taskmanager
The command line parameters passed to the TaskManager.
TaskManagerCliOptions() - Constructor for class org.apache.flink.runtime.taskmanager.TaskManagerCliOptions
 
TaskManagerConfiguration - Class in org.apache.flink.runtime.taskexecutor
Configuration object for TaskExecutor.
TaskManagerConfiguration(int, String[], Time, Time, Time, Time, Time, long, Configuration, boolean) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskManagerConfiguration
 
taskManagerDirectMemoryLimitMB() - Method in class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
 
taskManagerEnv() - Method in class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
 
TaskManagerException - Exception in org.apache.flink.runtime.taskexecutor.exceptions
Base exception thrown by the TaskExecutor.
TaskManagerException(String) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.TaskManagerException
 
TaskManagerException(String, Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.TaskManagerException
 
TaskManagerException(Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.TaskManagerException
 
TaskManagerGateway - Interface in org.apache.flink.runtime.jobmanager.slots
Task manager gateway interface to communicate with the task manager.
taskManagerHeapSizeMB() - Method in class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
 
taskManagerID - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskManagerQueryScopeInfo
 
taskManagerId() - Method in class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
 
TaskManagerInstance(Option<Instance>) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.TaskManagerInstance
 
TaskManagerInstance$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.TaskManagerInstance$
 
TaskManagerJobMetricGroup - Class in org.apache.flink.runtime.metrics.groups
Special MetricGroup representing everything belonging to a specific job, running on the TaskManager.
TaskManagerJobMetricGroup(MetricRegistry, TaskManagerMetricGroup, JobID, String) - Constructor for class org.apache.flink.runtime.metrics.groups.TaskManagerJobMetricGroup
 
TaskManagerJobScopeFormat - Class in org.apache.flink.runtime.metrics.scope
The scope format for the JobMetricGroup.
TaskManagerJobScopeFormat(String, TaskManagerScopeFormat) - Constructor for class org.apache.flink.runtime.metrics.scope.TaskManagerJobScopeFormat
 
TaskManagerLocation - Class in org.apache.flink.runtime.taskmanager
This class encapsulates the connection information of a TaskManager.
TaskManagerLocation(ResourceID, InetAddress, int) - Constructor for class org.apache.flink.runtime.taskmanager.TaskManagerLocation
Constructs a new instance connection info object.
TaskManagerLogHandler - Class in org.apache.flink.runtime.webmonitor.handlers
Request handler that returns the TaskManager log/out files.
TaskManagerLogHandler(JobManagerRetriever, ExecutionContextExecutor, Future<String>, FiniteDuration, TaskManagerLogHandler.FileMode, Configuration, boolean, BlobView) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.TaskManagerLogHandler
 
TaskManagerLogHandler.FileMode - Enum in org.apache.flink.runtime.webmonitor.handlers
 
taskManagerMap() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
taskManagerMemory() - Method in class org.apache.flink.api.scala.FlinkShell.YarnConfig
 
TaskManagerMessages - Class in org.apache.flink.runtime.messages
Miscellaneous actor messages exchanged with the TaskManager.
TaskManagerMessages() - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages
 
TaskManagerMessages$ - Class in org.apache.flink.runtime.messages
Miscellaneous actor messages exchanged with the TaskManager.
TaskManagerMessages$() - Constructor for class org.apache.flink.runtime.messages.TaskManagerMessages$
 
TaskManagerMessages.FatalError - Class in org.apache.flink.runtime.messages
This message informs the TaskManager about a fatal error that prevents it from continuing.
TaskManagerMessages.FatalError$ - Class in org.apache.flink.runtime.messages
 
TaskManagerMessages.Heartbeat - Class in org.apache.flink.runtime.messages
Reports liveliness of the TaskManager instance with the given instance ID to the This message is sent to the job.
TaskManagerMessages.Heartbeat$ - Class in org.apache.flink.runtime.messages
 
TaskManagerMessages.JobManagerLeaderAddress - Class in org.apache.flink.runtime.messages
Tells the address of the new leading JobManager and the new leader session ID.
TaskManagerMessages.JobManagerLeaderAddress$ - Class in org.apache.flink.runtime.messages
 
TaskManagerMessages.LogFileRequest$ - Class in org.apache.flink.runtime.messages
Indicates a request for the .log file
TaskManagerMessages.LogTypeRequest - Interface in org.apache.flink.runtime.messages
Trait do differentiate which log file is requested
TaskManagerMessages.NotifyWhenRegisteredAtJobManager$ - Class in org.apache.flink.runtime.messages
Requests a notification from the task manager as soon as the task manager has been registered at a job manager.
TaskManagerMessages.RegisteredAtJobManager - Class in org.apache.flink.runtime.messages
Acknowledges that the task manager has been successfully registered at any job manager.
TaskManagerMessages.RegisteredAtJobManager$ - Class in org.apache.flink.runtime.messages
 
TaskManagerMessages.RequestBroadcastVariablesWithReferences$ - Class in org.apache.flink.runtime.messages
Requests the number of broadcast variables with references
TaskManagerMessages.RequestNumActiveConnections$ - Class in org.apache.flink.runtime.messages
Requests the number of active connections at the ConnectionManager
TaskManagerMessages.RequestTaskManagerLog - Class in org.apache.flink.runtime.messages
Requests the TaskManager to upload either his log/stdout file to the Blob store param requestType LogTypeRequest indicating which file is requested
TaskManagerMessages.RequestTaskManagerLog$ - Class in org.apache.flink.runtime.messages
 
TaskManagerMessages.ResponseBroadcastVariablesWithReferences - Class in org.apache.flink.runtime.messages
 
TaskManagerMessages.ResponseBroadcastVariablesWithReferences$ - Class in org.apache.flink.runtime.messages
 
TaskManagerMessages.ResponseNumActiveConnections - Class in org.apache.flink.runtime.messages
 
TaskManagerMessages.ResponseNumActiveConnections$ - Class in org.apache.flink.runtime.messages
 
TaskManagerMessages.SendHeartbeat$ - Class in org.apache.flink.runtime.messages
Tells the task manager to send a heartbeat message to the job manager.
TaskManagerMessages.SendStackTrace$ - Class in org.apache.flink.runtime.messages
Tells the TaskManager to send a stack trace of all threads to the sender.
TaskManagerMessages.StackTrace - Class in org.apache.flink.runtime.messages
Communicates the stack trace of the TaskManager with the given ID.
TaskManagerMessages.StackTrace$ - Class in org.apache.flink.runtime.messages
 
TaskManagerMessages.StdOutFileRequest$ - Class in org.apache.flink.runtime.messages
Indicates a request for the .out file
TaskManagerMetricGroup - Class in org.apache.flink.runtime.metrics.groups
Special MetricGroup representing a TaskManager.
TaskManagerMetricGroup(MetricRegistry, String, String) - Constructor for class org.apache.flink.runtime.metrics.groups.TaskManagerMetricGroup
 
TaskManagerMetricsHandler - Class in org.apache.flink.runtime.webmonitor.metrics
Request handler that returns for a given task manager a list of all available metrics or the values for a set of metrics.
TaskManagerMetricsHandler(MetricFetcher) - Constructor for class org.apache.flink.runtime.webmonitor.metrics.TaskManagerMetricsHandler
 
TaskManagerMetricStore() - Constructor for class org.apache.flink.runtime.webmonitor.metrics.MetricStore.TaskManagerMetricStore
 
taskManagerNumSlots - Variable in class org.apache.flink.test.util.AbstractTestBase
 
TaskManagerOptions - Class in org.apache.flink.configuration
The set of configuration options relating to TaskManager and Task settings.
TaskManagerQueryScopeInfo(String) - Constructor for class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskManagerQueryScopeInfo
 
TaskManagerQueryScopeInfo(String, String) - Constructor for class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskManagerQueryScopeInfo
 
TaskManagerRegistration - Class in org.apache.flink.runtime.resourcemanager.slotmanager
 
TaskManagerRegistration(TaskExecutorConnection, Collection<SlotID>) - Constructor for class org.apache.flink.runtime.resourcemanager.slotmanager.TaskManagerRegistration
 
TaskManagerRunner - Class in org.apache.flink.runtime.taskexecutor
This class is the executable entry point for the task manager in yarn or standalone mode.
TaskManagerRunner(Configuration, ResourceID, RpcService, HighAvailabilityServices, HeartbeatServices, MetricRegistry) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
 
TaskManagerRunner(Configuration, ResourceID, RpcService, HighAvailabilityServices, HeartbeatServices, MetricRegistry, boolean) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskManagerRunner
 
TaskManagerRuntimeInfo - Interface in org.apache.flink.runtime.taskmanager
Interface to access TaskManager information.
taskManagers() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RegisteredTaskManagers
 
TaskManagerScopeFormat - Class in org.apache.flink.runtime.metrics.scope
The scope format for the TaskManagerMetricGroup.
TaskManagerScopeFormat(String) - Constructor for class org.apache.flink.runtime.metrics.scope.TaskManagerScopeFormat
 
TaskManagerServices - Class in org.apache.flink.runtime.taskexecutor
Container for TaskExecutor services such as the MemoryManager, IOManager, NetworkEnvironment and the MetricRegistry.
TaskManagerServicesConfiguration - Class in org.apache.flink.runtime.taskexecutor
Configuration for the task manager services such as the network environment, the memory manager, the io manager and the metric registry
TaskManagerServicesConfiguration(InetAddress, String[], NetworkEnvironmentConfiguration, QueryableStateConfiguration, int, long, boolean, float, MetricRegistryConfiguration, long) - Constructor for class org.apache.flink.runtime.taskexecutor.TaskManagerServicesConfiguration
 
TaskManagersHandler - Class in org.apache.flink.runtime.webmonitor.handlers
 
TaskManagersHandler(FiniteDuration, MetricFetcher) - Constructor for class org.apache.flink.runtime.webmonitor.handlers.TaskManagersHandler
 
TaskManagerSlot - Class in org.apache.flink.runtime.clusterframework.types
A TaskManagerSlot represents a slot located in a TaskManager.
TaskManagerSlot(SlotID, ResourceProfile, TaskExecutorConnection, AllocationID) - Constructor for class org.apache.flink.runtime.clusterframework.types.TaskManagerSlot
 
taskManagerTotalMemoryMB() - Method in class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
 
taskMap() - Method in class org.apache.flink.mesos.scheduler.Tasks
A map of task monitors by task ID.
TaskMessages - Class in org.apache.flink.runtime.messages
A set of messages that control the deployment and the state of Tasks executed on the TaskManager.
TaskMessages() - Constructor for class org.apache.flink.runtime.messages.TaskMessages
 
TaskMessages$ - Class in org.apache.flink.runtime.messages
A set of messages that control the deployment and the state of Tasks executed on the TaskManager.
TaskMessages$() - Constructor for class org.apache.flink.runtime.messages.TaskMessages$
 
TaskMessages.CancelTask - Class in org.apache.flink.runtime.messages
Cancels the task associated with attemptID.
TaskMessages.CancelTask$ - Class in org.apache.flink.runtime.messages
 
TaskMessages.FailIntermediateResultPartitions - Class in org.apache.flink.runtime.messages
Fails (and releases) all intermediate result partitions identified by executionID from the task manager.
TaskMessages.FailIntermediateResultPartitions$ - Class in org.apache.flink.runtime.messages
 
TaskMessages.FailTask - Class in org.apache.flink.runtime.messages
Triggers a fail of specified task from the outside (as opposed to the task throwing an exception itself) with the given exception as the cause.
TaskMessages.FailTask$ - Class in org.apache.flink.runtime.messages
 
TaskMessages.StopTask - Class in org.apache.flink.runtime.messages
Stops the task associated with attemptID.
TaskMessages.StopTask$ - Class in org.apache.flink.runtime.messages
 
TaskMessages.SubmitTask - Class in org.apache.flink.runtime.messages
Submits a task to the task manager.
TaskMessages.SubmitTask$ - Class in org.apache.flink.runtime.messages
 
TaskMessages.TaskInFinalState - Class in org.apache.flink.runtime.messages
Notifies the TaskManager that the task has reached its final state, either FINISHED, CANCELED, or FAILED.
TaskMessages.TaskInFinalState$ - Class in org.apache.flink.runtime.messages
 
TaskMessages.TaskMessage - Interface in org.apache.flink.runtime.messages
Marker trait for task messages.
TaskMessages.UpdatePartitionInfo - Class in org.apache.flink.runtime.messages
Base class for messages that update the information about location of input partitions
TaskMessages.UpdateTaskExecutionState - Class in org.apache.flink.runtime.messages
Denotes a state change of a task at the JobManager.
TaskMessages.UpdateTaskExecutionState$ - Class in org.apache.flink.runtime.messages
 
TaskMessages.UpdateTaskMultiplePartitionInfos - Class in org.apache.flink.runtime.messages
param: executionID The task's execution attempt ID.
TaskMessages.UpdateTaskMultiplePartitionInfos$ - Class in org.apache.flink.runtime.messages
 
TaskMessages.UpdateTaskSinglePartitionInfo - Class in org.apache.flink.runtime.messages
param: executionID The task's execution attempt ID.
TaskMessages.UpdateTaskSinglePartitionInfo$ - Class in org.apache.flink.runtime.messages
 
TaskMetricGroup - Class in org.apache.flink.runtime.metrics.groups
Special MetricGroup representing a Flink runtime Task.
TaskMetricGroup(MetricRegistry, TaskManagerJobMetricGroup, AbstractID, AbstractID, String, int, int) - Constructor for class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
TaskMetricStore() - Constructor for class org.apache.flink.runtime.webmonitor.metrics.MetricStore.TaskMetricStore
 
TaskMonitor - Class in org.apache.flink.mesos.scheduler
Monitors a Mesos task throughout its lifecycle.
TaskMonitor(Configuration, SchedulerDriver, TaskMonitor.TaskGoalState) - Constructor for class org.apache.flink.mesos.scheduler.TaskMonitor
 
TaskMonitor$ - Class in org.apache.flink.mesos.scheduler
 
TaskMonitor$() - Constructor for class org.apache.flink.mesos.scheduler.TaskMonitor$
 
TaskMonitor.Killing$ - Class in org.apache.flink.mesos.scheduler
 
TaskMonitor.Launched - Class in org.apache.flink.mesos.scheduler
 
TaskMonitor.Launched$ - Class in org.apache.flink.mesos.scheduler
 
TaskMonitor.New - Class in org.apache.flink.mesos.scheduler
 
TaskMonitor.New$ - Class in org.apache.flink.mesos.scheduler
 
TaskMonitor.Reconciling$ - Class in org.apache.flink.mesos.scheduler
 
TaskMonitor.Released - Class in org.apache.flink.mesos.scheduler
 
TaskMonitor.Released$ - Class in org.apache.flink.mesos.scheduler
 
TaskMonitor.Running$ - Class in org.apache.flink.mesos.scheduler
 
TaskMonitor.Staging$ - Class in org.apache.flink.mesos.scheduler
 
TaskMonitor.StateData - Class in org.apache.flink.mesos.scheduler
 
TaskMonitor.StateData$ - Class in org.apache.flink.mesos.scheduler
 
TaskMonitor.Suspended$ - Class in org.apache.flink.mesos.scheduler
 
TaskMonitor.TaskGoalState - Interface in org.apache.flink.mesos.scheduler
 
TaskMonitor.TaskGoalStateUpdated - Class in org.apache.flink.mesos.scheduler
Conveys an update to the goal (intentional) state of a given task.
TaskMonitor.TaskGoalStateUpdated$ - Class in org.apache.flink.mesos.scheduler
 
TaskMonitor.TaskMonitorState - Interface in org.apache.flink.mesos.scheduler
An FSM state of the task monitor, roughly corresponding to the task status.
TaskMonitor.TaskTerminated - Class in org.apache.flink.mesos.scheduler
Indicates that the Mesos task has terminated for whatever reason.
TaskMonitor.TaskTerminated$ - Class in org.apache.flink.mesos.scheduler
 
taskName() - Method in class org.apache.flink.runtime.messages.ExecutionGraphMessages.ExecutionStateChanged
 
taskName() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
taskName - Variable in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
taskNumber - Variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormatBase
 
TaskQueryScopeInfo(String, String, int) - Constructor for class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
 
TaskQueryScopeInfo(String, String, int, String) - Constructor for class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
 
taskRequest() - Method in class org.apache.flink.mesos.runtime.clusterframework.LaunchableMesosWorker
 
taskRequest() - Method in interface org.apache.flink.mesos.scheduler.LaunchableTask
Get a representation of the task requirements as understood by Fenzo.
tasks() - Method in class org.apache.flink.mesos.scheduler.LaunchCoordinator.Assign
 
tasks() - Method in class org.apache.flink.mesos.scheduler.LaunchCoordinator.GatherData
 
tasks() - Method in class org.apache.flink.mesos.scheduler.LaunchCoordinator.Launch
 
tasks() - Method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator.Reconcile
 
Tasks - Class in org.apache.flink.mesos.scheduler
Aggregate of monitored tasks.
Tasks(Configuration, SchedulerDriver, Function2<ActorRefFactory, TaskMonitor.TaskGoalState, ActorRef>) - Constructor for class org.apache.flink.mesos.scheduler.Tasks
 
tasks() - Method in class org.apache.flink.runtime.messages.TaskMessages.SubmitTask
 
Tasks$ - Class in org.apache.flink.mesos.scheduler
 
Tasks$() - Constructor for class org.apache.flink.mesos.scheduler.Tasks$
 
TaskSchedulerBuilder - Interface in org.apache.flink.mesos.scheduler
A builder for the Fenzo task scheduler.
TaskScopeFormat - Class in org.apache.flink.runtime.metrics.scope
The scope format for the TaskMetricGroup.
TaskScopeFormat(String, TaskManagerJobScopeFormat) - Constructor for class org.apache.flink.runtime.metrics.scope.TaskScopeFormat
 
TaskSlot - Class in org.apache.flink.runtime.taskexecutor.slot
Container for multiple Task belonging to the same slot.
TaskSlotTable - Class in org.apache.flink.runtime.taskexecutor.slot
Container for multiple TaskSlot instances.
TaskSlotTable(Collection<ResourceProfile>, TimerService<AllocationID>) - Constructor for class org.apache.flink.runtime.taskexecutor.slot.TaskSlotTable
 
TaskState - Class in org.apache.flink.migration.runtime.checkpoint
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
TaskState(JobVertexID, int) - Constructor for class org.apache.flink.migration.runtime.checkpoint.TaskState
Deprecated.
 
TaskState - Class in org.apache.flink.runtime.checkpoint
Deprecated.
Internal class for savepoint backwards compatibility. Don't use for other purposes.
TaskState(JobVertexID, int, int, int) - Constructor for class org.apache.flink.runtime.checkpoint.TaskState
Deprecated.
 
TaskStateHandles - Class in org.apache.flink.runtime.state
This class encapsulates all state handles for a task.
TaskStateHandles() - Constructor for class org.apache.flink.runtime.state.TaskStateHandles
 
TaskStateHandles(SubtaskState) - Constructor for class org.apache.flink.runtime.state.TaskStateHandles
 
TaskStateHandles(ChainedStateHandle<StreamStateHandle>, List<Collection<OperatorStateHandle>>, List<Collection<OperatorStateHandle>>, Collection<KeyedStateHandle>, Collection<KeyedStateHandle>) - Constructor for class org.apache.flink.runtime.state.TaskStateHandles
 
TaskStateStats - Class in org.apache.flink.runtime.checkpoint
Statistics for a single task/operator that gathers all statistics of its subtasks and provides summary statistics about all subtasks.
TaskStateStats.TaskStateStatsSummary - Class in org.apache.flink.runtime.checkpoint
Summary of the subtask stats of a single task/operator.
TaskStateStatsSummary() - Constructor for class org.apache.flink.runtime.checkpoint.TaskStateStats.TaskStateStatsSummary
 
TaskSubmissionException - Exception in org.apache.flink.runtime.taskexecutor.exceptions
Exception indicating a problem with the Task submission at the TaskException.
TaskSubmissionException(String) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.TaskSubmissionException
 
TaskSubmissionException(String, Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.TaskSubmissionException
 
TaskSubmissionException(Throwable) - Constructor for exception org.apache.flink.runtime.taskexecutor.exceptions.TaskSubmissionException
 
TaskTerminated(Protos.TaskID, Protos.TaskStatus) - Constructor for class org.apache.flink.mesos.scheduler.TaskMonitor.TaskTerminated
 
TaskTerminated$() - Constructor for class org.apache.flink.mesos.scheduler.TaskMonitor.TaskTerminated$
 
teardown() - Method in class org.apache.flink.runtime.operators.AbstractCachedBuildSideJoinDriver
 
teardown() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetFirstDriver
 
teardown() - Method in class org.apache.flink.runtime.operators.CoGroupWithSolutionSetSecondDriver
 
teardown() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetFirstDriver
 
teardown() - Method in class org.apache.flink.runtime.operators.JoinWithSolutionSetSecondDriver
 
teardown() - Method in interface org.apache.flink.runtime.operators.ResettableDriver
 
teardown() - Static method in class org.apache.flink.streaming.util.StreamingMultipleProgramsTestBase
 
teardown() - Static method in class org.apache.flink.test.util.MultipleProgramsTestBase
 
teardownEnvironment() - Method in class org.apache.flink.test.util.MultipleProgramsTestBase
 
tell() - Method in class org.apache.flink.api.avro.FSDataInputStreamWrapper
 
tell(Object) - Method in interface org.apache.flink.runtime.instance.ActorGateway
Sends a message asynchronously without a result.
tell(Object, ActorGateway) - Method in interface org.apache.flink.runtime.instance.ActorGateway
Sends a message asynchronously without a result with sender being the sender.
tell(Object) - Method in class org.apache.flink.runtime.instance.AkkaActorGateway
Sends a message asynchronously without a result.
tell(Object, ActorGateway) - Method in class org.apache.flink.runtime.instance.AkkaActorGateway
Sends a message asynchronously without a result with sender being the sender.
TempBarrier<T> - Class in org.apache.flink.runtime.operators
 
TempBarrier(AbstractInvokable, MutableObjectIterator<T>, TypeSerializerFactory<T>, MemoryManager, IOManager, int) - Constructor for class org.apache.flink.runtime.operators.TempBarrier
 
tempBarriers - Variable in class org.apache.flink.runtime.operators.BatchTask
The optional temp barriers on the inputs for dead-lock breaking.
template - Variable in class org.apache.flink.optimizer.plan.PlanNode
 
TempMode - Enum in org.apache.flink.optimizer.dag
Enumeration to indicate the mode of temporarily materializing the data that flows across a connection.
temporal() - Method in class org.apache.flink.table.expressions.Extract
 
temporal() - Method in class org.apache.flink.table.expressions.TemporalCeil
 
temporal() - Method in class org.apache.flink.table.expressions.TemporalFloor
 
TemporalCeil - Class in org.apache.flink.table.expressions
 
TemporalCeil(Expression, Expression) - Constructor for class org.apache.flink.table.expressions.TemporalCeil
 
TemporalCeil$ - Class in org.apache.flink.table.expressions
 
TemporalCeil$() - Constructor for class org.apache.flink.table.expressions.TemporalCeil$
 
TemporalCeilFloor - Class in org.apache.flink.table.expressions
 
TemporalCeilFloor(Expression, Expression) - Constructor for class org.apache.flink.table.expressions.TemporalCeilFloor
 
TemporalFloor - Class in org.apache.flink.table.expressions
 
TemporalFloor(Expression, Expression) - Constructor for class org.apache.flink.table.expressions.TemporalFloor
 
TemporalFloor$ - Class in org.apache.flink.table.expressions
 
TemporalFloor$() - Constructor for class org.apache.flink.table.expressions.TemporalFloor$
 
temporalOverlaps - Class in org.apache.flink.table.api.scala
Determines whether two anchored time intervals overlap.
temporalOverlaps() - Constructor for class org.apache.flink.table.api.scala.temporalOverlaps
 
TemporalOverlaps - Class in org.apache.flink.table.expressions
Determines whether two anchored time intervals overlap.
TemporalOverlaps(Expression, Expression, Expression, Expression) - Constructor for class org.apache.flink.table.expressions.TemporalOverlaps
 
temporalOverlaps$ - Class in org.apache.flink.table.api.scala
Determines whether two anchored time intervals overlap.
temporalOverlaps$() - Constructor for class org.apache.flink.table.api.scala.temporalOverlaps$
 
TemporalOverlaps$ - Class in org.apache.flink.table.expressions
 
TemporalOverlaps$() - Constructor for class org.apache.flink.table.expressions.TemporalOverlaps$
 
temporaryFolder - Static variable in class org.apache.flink.test.util.AbstractTestBase
 
TemporaryPath$() - Constructor for class org.apache.flink.ml.recommendation.ALS.TemporaryPath$
 
term() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
term() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
Terminable - Interface in org.apache.flink.runtime.iterative.task
Models the functionality that the termination of an iterative task can be requested from outside
terminate() - Method in class org.apache.flink.runtime.client.JobClientActor
 
TERMINATION_CRITERION_AGGREGATOR_NAME - Static variable in class org.apache.flink.api.common.operators.base.BulkIterationBase
 
terminationCriterion - Variable in class org.apache.flink.api.common.operators.base.BulkIterationBase
 
TerminationCriterionAggregationConvergence() - Constructor for class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregationConvergence
 
TerminationCriterionAggregator() - Constructor for class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionAggregator
 
TerminationCriterionMapper() - Constructor for class org.apache.flink.api.common.operators.base.BulkIterationBase.TerminationCriterionMapper
 
TerminationEvent - Class in org.apache.flink.runtime.iterative.event
Signals that the iteration is completely executed, participating tasks must terminate now
TerminationEvent() - Constructor for class org.apache.flink.runtime.iterative.event.TerminationEvent
 
terminationRequested() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
terminationRequested() - Method in class org.apache.flink.runtime.iterative.task.IterationSynchronizationSinkTask
 
terminationRequested() - Method in interface org.apache.flink.runtime.iterative.task.Terminable
 
terminationSignaled() - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepBarrier
 
ternaryOperation(AbstractInsnNode, BasicValue, BasicValue, BasicValue) - Method in class org.apache.flink.api.java.sca.NestedMethodAnalyzer
 
TertiaryResult<T> - Interface in org.apache.flink.graph.asm.result
A GraphAlgorithm result for three vertices.
TestBaseUtils - Class in org.apache.flink.test.util
 
TestBaseUtils() - Constructor for class org.apache.flink.test.util.TestBaseUtils
 
TestBaseUtils.TupleComparator<T extends Tuple> - Class in org.apache.flink.test.util
 
testDispatcherConfig() - Method in class org.apache.flink.runtime.akka.AkkaUtils$
 
testDispatcherConfig() - Static method in class org.apache.flink.runtime.akka.AkkaUtils
 
TestEnvironment - Class in org.apache.flink.test.util
A ExecutionEnvironment implementation which executes its jobs on a LocalFlinkMiniCluster.
TestEnvironment(LocalFlinkMiniCluster, int, boolean, Collection<Path>, Collection<URL>) - Constructor for class org.apache.flink.test.util.TestEnvironment
 
TestEnvironment(LocalFlinkMiniCluster, int, boolean) - Constructor for class org.apache.flink.test.util.TestEnvironment
 
testForUnsplittable(FileStatus) - Method in class org.apache.flink.api.common.io.FileInputFormat
 
testHash(int) - Method in class org.apache.flink.runtime.operators.util.BloomFilter
 
testing() - Method in class org.apache.flink.ml.preprocessing.Splitter.TrainTestDataSet
 
testing() - Method in class org.apache.flink.ml.preprocessing.Splitter.TrainTestHoldoutDataSet
 
TestingSecurityContext - Class in org.apache.flink.test.util
 
TestingSecurityContext() - Constructor for class org.apache.flink.test.util.TestingSecurityContext
 
TestingSecurityContext.ClientSecurityConfiguration - Class in org.apache.flink.test.util
 
testJob() - Method in class org.apache.flink.streaming.util.StreamingProgramTestBase
 
testJobCollectionExecution() - Method in class org.apache.flink.test.util.JavaProgramTestBase
 
testJobWithObjectReuse() - Method in class org.apache.flink.test.util.JavaProgramTestBase
 
testJobWithoutObjectReuse() - Method in class org.apache.flink.test.util.JavaProgramTestBase
 
TestLogger - Class in org.apache.flink.util
Adds automatic test name logging.
TestLogger() - Constructor for class org.apache.flink.util.TestLogger
 
TestMeter - Class in org.apache.flink.metrics.util
 
TestMeter() - Constructor for class org.apache.flink.metrics.util.TestMeter
 
TestProcessingTimeService - Class in org.apache.flink.streaming.runtime.tasks
This is a ProcessingTimeService used strictly for testing the processing time functionality.
TestProcessingTimeService() - Constructor for class org.apache.flink.streaming.runtime.tasks.TestProcessingTimeService
 
testProgram() - Method in class org.apache.flink.streaming.util.StreamingProgramTestBase
 
testProgram() - Method in class org.apache.flink.test.util.JavaProgramTestBase
 
TestStreamEnvironment - Class in org.apache.flink.streaming.util
TestStreamEnvironment(LocalFlinkMiniCluster, int, Collection<Path>, Collection<URL>) - Constructor for class org.apache.flink.streaming.util.TestStreamEnvironment
 
TestStreamEnvironment(LocalFlinkMiniCluster, int) - Constructor for class org.apache.flink.streaming.util.TestStreamEnvironment
 
TEXT - Static variable in class org.apache.flink.test.testdata.WordCountData
 
TextInputFormat - Class in org.apache.flink.api.java.io
 
TextInputFormat(Path) - Constructor for class org.apache.flink.api.java.io.TextInputFormat
 
TextOutputFormat<T> - Class in org.apache.flink.api.java.io
 
TextOutputFormat(Path) - Constructor for class org.apache.flink.api.java.io.TextOutputFormat
 
TextOutputFormat(Path, String) - Constructor for class org.apache.flink.api.java.io.TextOutputFormat
 
TextOutputFormat.TextFormatter<IN> - Interface in org.apache.flink.api.java.io
 
TEXTS - Static variable in class org.apache.flink.streaming.examples.twitter.util.TwitterExampleData
 
TextValueInputFormat - Class in org.apache.flink.api.java.io
 
TextValueInputFormat(Path) - Constructor for class org.apache.flink.api.java.io.TextValueInputFormat
 
thenAccept(AcceptFunction<? super T>) - Method in interface org.apache.flink.runtime.concurrent.Future
Applies the accept function to the value of the future.
thenAccept(AcceptFunction<? super T>) - Method in class org.apache.flink.runtime.concurrent.impl.FlinkFuture
 
thenAcceptAsync(AcceptFunction<? super T>, Executor) - Method in interface org.apache.flink.runtime.concurrent.Future
Applies the accept function to the value of the future.
thenAcceptAsync(AcceptFunction<? super T>, Executor) - Method in class org.apache.flink.runtime.concurrent.impl.FlinkFuture
 
thenApply(ApplyFunction<? super T, ? extends R>) - Method in interface org.apache.flink.runtime.concurrent.Future
Applies the given function to the value of the future.
thenApply(ApplyFunction<? super T, ? extends R>) - Method in class org.apache.flink.runtime.concurrent.impl.FlinkFuture
 
thenApplyAsync(ApplyFunction<? super T, ? extends R>, Executor) - Method in interface org.apache.flink.runtime.concurrent.Future
Applies the given function to the value of the future.
thenApplyAsync(ApplyFunction<? super T, ? extends R>, Executor) - Method in class org.apache.flink.runtime.concurrent.impl.FlinkFuture
 
thenCombine(Future<U>, BiFunction<? super T, ? super U, ? extends R>) - Method in interface org.apache.flink.runtime.concurrent.Future
Applies the given function to the result of this and the other future after both futures have completed.
thenCombine(Future<U>, BiFunction<? super T, ? super U, ? extends R>) - Method in class org.apache.flink.runtime.concurrent.impl.FlinkFuture
 
thenCombineAsync(Future<U>, BiFunction<? super T, ? super U, ? extends R>, Executor) - Method in interface org.apache.flink.runtime.concurrent.Future
Applies the given function to the result of this and the other future after both futures have completed.
thenCombineAsync(Future<U>, BiFunction<? super T, ? super U, ? extends R>, Executor) - Method in class org.apache.flink.runtime.concurrent.impl.FlinkFuture
 
thenCompose(ApplyFunction<? super T, ? extends Future<R>>) - Method in interface org.apache.flink.runtime.concurrent.Future
Applies the given function to the value of the future.
thenCompose(ApplyFunction<? super T, ? extends Future<R>>) - Method in class org.apache.flink.runtime.concurrent.impl.FlinkFuture
 
thenComposeAsync(ApplyFunction<? super T, ? extends Future<R>>, Executor) - Method in interface org.apache.flink.runtime.concurrent.Future
Applies the given function to the value of the future.
thenComposeAsync(ApplyFunction<? super T, ? extends Future<R>>, Executor) - Method in class org.apache.flink.runtime.concurrent.impl.FlinkFuture
 
theta0() - Method in class org.apache.flink.examples.scala.ml.LinearRegression.Params
 
theta1() - Method in class org.apache.flink.examples.scala.ml.LinearRegression.Params
 
ThreadBase(ExceptionHandler<IOException>, String, UnilateralSortMerger.CircularQueues<E>, AbstractInvokable) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
Creates a new thread.
ThresholdValue$() - Constructor for class org.apache.flink.ml.classification.SVM.ThresholdValue$
 
ThrottledIterator<T> - Class in org.apache.flink.streaming.examples.utils
A variant of the collection source (emits a sequence of elements as a stream) that supports throttling the emission rate.
ThrottledIterator(Iterator<T>, long) - Constructor for class org.apache.flink.streaming.examples.utils.ThrottledIterator
 
THROW - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
throwableSerializer() - Method in class org.apache.flink.api.scala.typeutils.TrySerializer
 
ticketCacheEntry() - Static method in class org.apache.flink.runtime.security.KerberosUtils
 
Time - Class in org.apache.flink.api.common.time
The definition of a time interval.
TIME - Static variable in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
Time - Class in org.apache.flink.streaming.api.windowing.time
The definition of a time interval for windowing.
time() - Method in class org.apache.flink.streaming.scala.examples.windowing.TopSpeedWindowing.CarEvent
 
TimeAttribute - Class in org.apache.flink.table.expressions
 
TimeAttribute(Expression) - Constructor for class org.apache.flink.table.expressions.TimeAttribute
 
timeAttribute() - Method in class org.apache.flink.table.plan.logical.LogicalWindow
 
timeAttribute() - Static method in class org.apache.flink.table.plan.logical.SessionGroupWindow
 
timeAttribute() - Static method in class org.apache.flink.table.plan.logical.SlidingGroupWindow
 
timeAttribute() - Static method in class org.apache.flink.table.plan.logical.TumblingGroupWindow
 
TimeCharacteristic - Enum in org.apache.flink.streaming.api
The time characteristic defines how the system determines time for time-dependent order and operations that depend on time (such as time windows).
timeDomain() - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction.OnTimerContext
The TimeDomain of the firing timer.
timeDomain() - Method in class org.apache.flink.streaming.api.functions.ProcessFunction.OnTimerContext
The TimeDomain of the firing timer.
TimeDomain - Enum in org.apache.flink.streaming.api
TimeDomain specifies whether a firing timer is based on event time or processing time.
TimeEvictor<W extends Window> - Class in org.apache.flink.streaming.api.windowing.evictors
An Evictor that keeps elements for a certain amount of time.
TimeEvictor(long) - Constructor for class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
 
TimeEvictor(long, boolean) - Constructor for class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
 
timeField() - Method in class org.apache.flink.table.api.Window
 
timeField() - Method in class org.apache.flink.table.plan.logical.SessionGroupWindow
 
timeField() - Method in class org.apache.flink.table.plan.logical.SlidingGroupWindow
 
timeField() - Method in class org.apache.flink.table.plan.logical.TumblingGroupWindow
 
timeIndicator() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
timeIndicator() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
TimeIndicatorRelDataType - Class in org.apache.flink.table.plan.schema
Creates a time indicator type for event-time or processing-time, but with similar properties as a basic SQL type.
TimeIndicatorRelDataType(RelDataTypeSystem, BasicSqlType, boolean) - Constructor for class org.apache.flink.table.plan.schema.TimeIndicatorRelDataType
 
TimeIndicatorTypeInfo - Class in org.apache.flink.table.typeutils
Type information for indicating event or processing time.
TimeIndicatorTypeInfo(boolean) - Constructor for class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
 
TimeIndicatorTypeInfo$ - Class in org.apache.flink.table.typeutils
 
TimeIndicatorTypeInfo$() - Constructor for class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo$
 
TimeIntervalTypeInfo<T> - Class in org.apache.flink.table.typeutils
TypeInformation for SQL INTERVAL types.
TimeIntervalTypeInfo(Class<T>, TypeSerializer<T>, Class<? extends TypeComparator<T>>) - Constructor for class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
 
TimeIntervalTypeInfo$ - Class in org.apache.flink.table.typeutils
 
TimeIntervalTypeInfo$() - Constructor for class org.apache.flink.table.typeutils.TimeIntervalTypeInfo$
 
timeIntervalUnit() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
timeIntervalUnit() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
timeIntervalUnit() - Method in class org.apache.flink.table.expressions.Extract
 
timeIntervalUnit() - Method in class org.apache.flink.table.expressions.TemporalCeil
 
timeIntervalUnit() - Method in class org.apache.flink.table.expressions.TemporalFloor
 
TimeIntervalUnit - Class in org.apache.flink.table.expressions
Units for working with time intervals.
TimeIntervalUnit() - Constructor for class org.apache.flink.table.expressions.TimeIntervalUnit
 
TimeIntervalUnit$ - Class in org.apache.flink.table.expressions
Units for working with time intervals.
TimeIntervalUnit$() - Constructor for class org.apache.flink.table.expressions.TimeIntervalUnit$
 
TimeMaterializationSqlFunction - Class in org.apache.flink.table.functions
Function that materializes a time attribute to the metadata timestamp.
TimeMaterializationSqlFunction() - Constructor for class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
TimeMaterializationSqlFunction$ - Class in org.apache.flink.table.functions
Function that materializes a time attribute to the metadata timestamp.
TimeMaterializationSqlFunction$() - Constructor for class org.apache.flink.table.functions.TimeMaterializationSqlFunction$
 
timeout(Map<String, List<IN>>, long, Collector<OUT>) - Method in interface org.apache.flink.cep.PatternFlatTimeoutFunction
Generates zero or more resulting timeout elements given a map of partial pattern events and the timestamp of the timeout.
timeout(Map<String, List<IN>>, long) - Method in interface org.apache.flink.cep.PatternTimeoutFunction
Generates a timeout result from the given map of events and timeout timestamp.
timeout - Variable in class org.apache.flink.client.program.ClusterClient
Timeout for futures
timeout - Variable in class org.apache.flink.runtime.client.JobClientActor
timeout for futures
timeout() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
timeout() - Method in class org.apache.flink.runtime.messages.RegistrationMessages.TriggerTaskManagerRegistration
 
timeout() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
timeout - Variable in class org.apache.flink.runtime.webmonitor.RuntimeMonitorHandlerBase
 
TimeoutKeyedCEPPatternOperator<IN,KEY> - Class in org.apache.flink.cep.operator
CEP pattern operator which returns fully and partially matched (timed-out) event patterns stored in a Map.
TimeoutKeyedCEPPatternOperator(TypeSerializer<IN>, boolean, TypeSerializer<KEY>, NFACompiler.NFAFactory<IN>, boolean) - Constructor for class org.apache.flink.cep.operator.TimeoutKeyedCEPPatternOperator
 
TimeoutListener<K> - Interface in org.apache.flink.runtime.taskexecutor.slot
Listener for timeout events by the TimerService.
timeoutSlot(AllocationID, UUID) - Method in interface org.apache.flink.runtime.taskexecutor.slot.SlotActions
Timeout the task slot for the given allocation id.
timePointToInternalCode(TypeInformation<?>, String) - Method in class org.apache.flink.table.codegen.CodeGenUtils$
 
timePointToInternalCode(TypeInformation<?>, String) - Static method in class org.apache.flink.table.codegen.CodeGenUtils
 
timePointUnit() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
timePointUnit() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
TimePointUnit - Class in org.apache.flink.table.expressions
Units for working with time points.
TimePointUnit() - Constructor for class org.apache.flink.table.expressions.TimePointUnit
 
TimePointUnit$ - Class in org.apache.flink.table.expressions
Units for working with time points.
TimePointUnit$() - Constructor for class org.apache.flink.table.expressions.TimePointUnit$
 
Timer(long, K, W) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
 
TimerException - Exception in org.apache.flink.streaming.runtime.tasks
RuntimeException for wrapping exceptions that are thrown in the timer callback of the timer service in StreamTask.
TimerException(Throwable) - Constructor for exception org.apache.flink.streaming.runtime.tasks.TimerException
 
TimerService<K> - Class in org.apache.flink.runtime.taskexecutor.slot
Service to register timeouts for a given key.
TimerService(ScheduledExecutorService, long) - Constructor for class org.apache.flink.runtime.taskexecutor.slot.TimerService
 
timerService() - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction.Context
A TimerService for querying time and registering timers.
timerService() - Method in class org.apache.flink.streaming.api.functions.ProcessFunction.Context
A TimerService for querying time and registering timers.
TimerService - Interface in org.apache.flink.streaming.api
Interface for working with time and timers.
times(int) - Method in class org.apache.flink.cep.pattern.Pattern
Specifies exact number of times that this pattern should be matched.
TIMES(Quantifier.ConsumingStrategy) - Static method in class org.apache.flink.cep.pattern.Quantifier
 
times(int) - Method in class org.apache.flink.cep.scala.pattern.Pattern
Specifies exact number of times that this pattern should be matched.
TIMESTAMP - Static variable in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
timestamp - Variable in class org.apache.flink.runtime.checkpoint.AbstractAsyncSnapshotIOCallable
 
timestamp() - Method in class org.apache.flink.runtime.messages.ExecutionGraphMessages.ExecutionStateChanged
 
timestamp() - Method in class org.apache.flink.runtime.messages.ExecutionGraphMessages.JobStatusChanged
 
timestamp() - Method in class org.apache.flink.streaming.api.functions.co.CoProcessFunction.Context
Timestamp of the element currently being processed or timestamp of a firing timer.
timestamp() - Method in class org.apache.flink.streaming.api.functions.ProcessFunction.Context
Timestamp of the element currently being processed or timestamp of a firing timer.
timestamp - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
 
timestamp() - Method in class org.apache.flink.yarn.YarnContainerInLaunch
 
TIMESTAMP_ADD - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The TIMESTAMPADD function.
TIMESTAMP_DIFF - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The TIMESTAMPDIFF function.
TimestampAssigner<T> - Interface in org.apache.flink.streaming.api.functions
A TimestampAssigner assigns event time timestamps to elements.
TimestampedCollector<T> - Class in org.apache.flink.streaming.api.operators
Wrapper around an Output for user functions that expect a Collector.
TimestampedCollector(Output<StreamRecord<T>>) - Constructor for class org.apache.flink.streaming.api.operators.TimestampedCollector
Creates a new TimestampedCollector that wraps the given Output.
timestampedCollector - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
This is given to the InternalWindowFunction for emitting elements with a given timestamp.
TimestampedFileInputSplit - Class in org.apache.flink.streaming.api.functions.source
An extended FileInputSplit that also includes information about: The modification time of the file this split belongs to. When checkpointing, the state of the split at the moment of the checkpoint. This class is used by the ContinuousFileMonitoringFunction and the ContinuousFileReaderOperator to perform continuous file processing.
TimestampedFileInputSplit(long, int, Path, long, long, String[]) - Constructor for class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
Creates a TimestampedFileInputSplit based on the file modification time and the rest of the information of the FileInputSplit, as returned by the underlying filesystem.
TimestampedValue<T> - Class in org.apache.flink.streaming.runtime.operators.windowing
Stores the value and the timestamp of the record.
TimestampedValue(T) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
Creates a new TimestampedValue.
TimestampedValue(T, long) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.TimestampedValue
Creates a new TimestampedValue wrapping the given value.
TimestampExtractor<T> - Interface in org.apache.flink.streaming.api.functions
Deprecated.
TimestampsAndPeriodicWatermarksOperator<T> - Class in org.apache.flink.streaming.runtime.operators
A stream operator that extracts timestamps from stream elements and generates periodic watermarks.
TimestampsAndPeriodicWatermarksOperator(AssignerWithPeriodicWatermarks<T>) - Constructor for class org.apache.flink.streaming.runtime.operators.TimestampsAndPeriodicWatermarksOperator
 
TimestampsAndPunctuatedWatermarksOperator<T> - Class in org.apache.flink.streaming.runtime.operators
A stream operator that extracts timestamps from stream elements and generates watermarks based on punctuation elements.
TimestampsAndPunctuatedWatermarksOperator(AssignerWithPunctuatedWatermarks<T>) - Constructor for class org.apache.flink.streaming.runtime.operators.TimestampsAndPunctuatedWatermarksOperator
 
timestampWatermarkMode - Variable in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
The mode describing whether the fetcher also generates timestamps and watermarks
timeWindow(Time) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Windows this KeyedStream into tumbling time windows.
timeWindow(Time, Time) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Windows this KeyedStream into sliding time windows.
timeWindow(Time) - Method in class org.apache.flink.streaming.api.scala.KeyedStream
Windows this KeyedStream into tumbling time windows.
timeWindow(Time, Time) - Method in class org.apache.flink.streaming.api.scala.KeyedStream
Windows this KeyedStream into sliding time windows.
TimeWindow - Class in org.apache.flink.streaming.api.windowing.windows
A Window that represents a time interval from start (inclusive) to end (exclusive).
TimeWindow(long, long) - Constructor for class org.apache.flink.streaming.api.windowing.windows.TimeWindow
 
TimeWindow.Serializer - Class in org.apache.flink.streaming.api.windowing.windows
The serializer used to write the TimeWindow type.
timeWindowAll(Time) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Windows this DataStream into tumbling time windows.
timeWindowAll(Time, Time) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Windows this DataStream into sliding time windows.
timeWindowAll(Time) - Method in class org.apache.flink.streaming.api.scala.DataStream
Windows this DataStream into tumbling time windows.
timeWindowAll(Time, Time) - Method in class org.apache.flink.streaming.api.scala.DataStream
Windows this DataStream into sliding time windows.
TimeWindowPropertyCollector<T> - Class in org.apache.flink.table.runtime.aggregate
Adds TimeWindow properties to specified fields of a row before it emits the row to a wrapped collector.
TimeWindowPropertyCollector(Option<Object>, Option<Object>) - Constructor for class org.apache.flink.table.runtime.aggregate.TimeWindowPropertyCollector
 
Tiny() - Method in class org.apache.flink.table.plan.cost.DataSetCost$
 
Tiny() - Static method in class org.apache.flink.table.plan.cost.DataSetCost
 
to - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
TO_DATE() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
TO_DATE() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
TO_TIME() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
TO_TIME() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
TO_TIMESTAMP() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
TO_TIMESTAMP() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
toAggCall(String, RelBuilder) - Method in class org.apache.flink.table.expressions.AggFunctionCall
 
toAggCall(String, RelBuilder) - Method in class org.apache.flink.table.expressions.Aggregation
Convert Aggregate to its counterpart in Calcite, i.e.
toAggCall(String, RelBuilder) - Method in class org.apache.flink.table.expressions.Avg
 
toAggCall(String, RelBuilder) - Method in class org.apache.flink.table.expressions.Count
 
toAggCall(String, RelBuilder) - Method in class org.apache.flink.table.expressions.Max
 
toAggCall(String, RelBuilder) - Method in class org.apache.flink.table.expressions.Min
 
toAggCall(String, RelBuilder) - Method in class org.apache.flink.table.expressions.StddevPop
 
toAggCall(String, RelBuilder) - Method in class org.apache.flink.table.expressions.StddevSamp
 
toAggCall(String, RelBuilder) - Method in class org.apache.flink.table.expressions.Sum
 
toAggCall(String, RelBuilder) - Method in class org.apache.flink.table.expressions.Sum0
 
toAggCall(String, RelBuilder) - Method in class org.apache.flink.table.expressions.VarPop
 
toAggCall(String, RelBuilder) - Method in class org.apache.flink.table.expressions.VarSamp
 
toAppendStream(Table, Class<T>) - Method in class org.apache.flink.table.api.java.StreamTableEnvironment
Converts the given Table into an append DataStream of a specified type.
toAppendStream(Table, TypeInformation<T>) - Method in class org.apache.flink.table.api.java.StreamTableEnvironment
Converts the given Table into an append DataStream of a specified type.
toAppendStream(Table, Class<T>, StreamQueryConfig) - Method in class org.apache.flink.table.api.java.StreamTableEnvironment
Converts the given Table into an append DataStream of a specified type.
toAppendStream(Table, TypeInformation<T>, StreamQueryConfig) - Method in class org.apache.flink.table.api.java.StreamTableEnvironment
Converts the given Table into an append DataStream of a specified type.
toAppendStream(Table, TypeInformation<T>) - Method in class org.apache.flink.table.api.scala.StreamTableEnvironment
Converts the given Table into an append DataStream of a specified type.
toAppendStream(Table, StreamQueryConfig, TypeInformation<T>) - Method in class org.apache.flink.table.api.scala.StreamTableEnvironment
Converts the given Table into an append DataStream of a specified type.
toAppendStream(TypeInformation<T>) - Method in class org.apache.flink.table.api.scala.TableConversions
Converts the given Table into an append DataStream of a specified type.
toAppendStream(StreamQueryConfig, TypeInformation<T>) - Method in class org.apache.flink.table.api.scala.TableConversions
Converts the given Table into an append DataStream of a specified type.
toArray() - Method in class org.apache.flink.api.common.operators.util.FieldSet
Transforms the field set into an array of field IDs.
toArray() - Method in class org.apache.flink.runtime.util.IntArrayList
 
toArray() - Method in class org.apache.flink.runtime.util.LongArrayList
 
toArray() - Method in class org.apache.flink.types.ListValue
 
toArray(T[]) - Method in class org.apache.flink.types.ListValue
 
toAttribute() - Method in class org.apache.flink.table.expressions.Alias
 
toAttribute() - Method in class org.apache.flink.table.expressions.Attribute
 
toAttribute() - Method in interface org.apache.flink.table.expressions.NamedExpression
 
toAttribute() - Static method in class org.apache.flink.table.expressions.ResolvedFieldReference
 
toAttribute() - Method in class org.apache.flink.table.expressions.UnresolvedAlias
 
toAttribute() - Static method in class org.apache.flink.table.expressions.UnresolvedFieldReference
 
toAttribute() - Static method in class org.apache.flink.table.expressions.WindowReference
 
toBinary(Object) - Method in class org.apache.flink.runtime.akka.serialization.IOReadableWritableSerializer
 
toBinary(Object) - Method in class org.apache.flink.runtime.akka.serialization.WritableSerializer
 
toBooleanMask(int[]) - Static method in class org.apache.flink.api.java.io.CsvInputFormat
 
toBuffer(AbstractEvent) - Static method in class org.apache.flink.runtime.io.network.api.serialization.EventSerializer
 
toByteArray() - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
toCOO() - Method in class org.apache.flink.ml.math.distributed.DistributedRowMatrix
Collects the data in the form of a sequence of coordinates associated with their values.
toDataSet(Table, Class<T>) - Method in class org.apache.flink.table.api.java.BatchTableEnvironment
Converts the given Table into a DataSet of a specified type.
toDataSet(Table, TypeInformation<T>) - Method in class org.apache.flink.table.api.java.BatchTableEnvironment
Converts the given Table into a DataSet of a specified type.
toDataSet(Table, TypeInformation<T>) - Method in class org.apache.flink.table.api.scala.BatchTableEnvironment
Converts the given Table into a DataSet of a specified type.
toDataSet(TypeInformation<T>) - Method in class org.apache.flink.table.api.scala.TableConversions
Converts the given Table into a DataSet of a specified type.
toDataStream(Table, Class<T>) - Method in class org.apache.flink.table.api.java.StreamTableEnvironment
Deprecated.
This method only supports conversion of append-only tables. In order to make this more explicit in the future, please use toAppendStream() instead.
toDataStream(Table, TypeInformation<T>) - Method in class org.apache.flink.table.api.java.StreamTableEnvironment
Deprecated.
This method only supports conversion of append-only tables. In order to make this more explicit in the future, please use toAppendStream() instead.
toDataStream(Table, Class<T>, StreamQueryConfig) - Method in class org.apache.flink.table.api.java.StreamTableEnvironment
Deprecated.
This method only supports conversion of append-only tables. In order to make this more explicit in the future, please use toAppendStream() instead.
toDataStream(Table, TypeInformation<T>, StreamQueryConfig) - Method in class org.apache.flink.table.api.java.StreamTableEnvironment
Deprecated.
This method only supports conversion of append-only tables. In order to make this more explicit in the future, please use toAppendStream() instead.
toDataStream(Table, TypeInformation<T>) - Method in class org.apache.flink.table.api.scala.StreamTableEnvironment
Deprecated.
This method only supports conversion of append-only tables. In order to make this more explicit in the future, please use toAppendStream() instead. Since .
toDataStream(Table, StreamQueryConfig, TypeInformation<T>) - Method in class org.apache.flink.table.api.scala.StreamTableEnvironment
Deprecated.
This method only supports conversion of append-only tables. In order to make this more explicit in the future, please use toAppendStream() instead. Since .
toDataStream(TypeInformation<T>) - Method in class org.apache.flink.table.api.scala.TableConversions
Deprecated.
This method only supports conversion of append-only tables. In order to make this more explicit in the future, please use toAppendStream() instead. Since .
toDataStream(StreamQueryConfig, TypeInformation<T>) - Method in class org.apache.flink.table.api.scala.TableConversions
Deprecated.
This method only supports conversion of append-only tables. In order to make this more explicit in the future, please use toAppendStream() instead. Since .
toDate() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Parses a date string in the form "yy-mm-dd" to a SQL Date.
toDenseMatrix() - Method in class org.apache.flink.ml.math.SparseMatrix
 
toDenseVector() - Method in class org.apache.flink.ml.math.SparseVector
Converts the SparseVector to a DenseVector
toDeque(SerializedCheckpointData[], TypeSerializer<T>) - Static method in class org.apache.flink.runtime.state.SerializedCheckpointData
De-serializes an array of SerializedCheckpointData back into an ArrayDeque of element checkpoints.
toError - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
toExpr() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Enables literals on left side of binary expressions.
toExpr() - Method in class org.apache.flink.table.expressions.SymbolExpression
 
toFieldList() - Method in class org.apache.flink.api.common.operators.util.FieldList
 
toFieldList() - Method in class org.apache.flink.api.common.operators.util.FieldSet
Turns the FieldSet into an ordered FieldList.
toForwardedFieldsExpression(TaggedValue.Input) - Method in class org.apache.flink.api.java.sca.TaggedValue
 
toggleStreamStatus(StreamStatus) - Method in interface org.apache.flink.streaming.runtime.streamstatus.StreamStatusMaintainer
Toggles the current stream status.
toggleStreamStatus(StreamStatus) - Method in class org.apache.flink.streaming.runtime.tasks.OperatorChain
 
toInternalRowTypeInfo(RelDataType) - Method in class org.apache.flink.table.calcite.FlinkTypeFactory$
Deprecated.
Use the RowSchema class instead because it handles both logical and physical rows. Since .
toInternalRowTypeInfo(RelDataType) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
Deprecated.
Use the RowSchema class instead because it handles both logical and physical rows. Since .
toISC(StringContext) - Method in class org.apache.flink.table.codegen.Indenter$
 
toISC(StringContext) - Static method in class org.apache.flink.table.codegen.Indenter
 
toJobExecutionResult(ClassLoader) - Method in class org.apache.flink.runtime.client.SerializedJobExecutionResult
 
TOKEN - Static variable in class org.apache.flink.streaming.connectors.twitter.TwitterSource
 
TOKEN_SECRET - Static variable in class org.apache.flink.streaming.connectors.twitter.TwitterSource
 
tokenierzerId - Static variable in class org.apache.flink.storm.wordcount.WordCountTopology
 
Tokenizer() - Constructor for class org.apache.flink.examples.java.wordcount.WordCount.Tokenizer
 
Tokenizer() - Constructor for class org.apache.flink.examples.java.wordcount.WordCountPojo.Tokenizer
 
Tokenizer() - Constructor for class org.apache.flink.storm.wordcount.SpoutSourceWordCount.Tokenizer
 
Tokenizer() - Constructor for class org.apache.flink.streaming.examples.sideoutput.SideOutputExample.Tokenizer
 
Tokenizer() - Constructor for class org.apache.flink.streaming.examples.wordcount.PojoExample.Tokenizer
 
Tokenizer() - Constructor for class org.apache.flink.streaming.examples.wordcount.WordCount.Tokenizer
 
toLocalDenseMatrix() - Method in class org.apache.flink.ml.math.distributed.DistributedRowMatrix
Collects the data in the form of a DenseMatrix.
toLocalSparseMatrix() - Method in class org.apache.flink.ml.math.distributed.DistributedRowMatrix
Collects the data in the form of a SparseMatrix.
toLogicalTableFunctionCall(LogicalNode) - Method in class org.apache.flink.table.expressions.TableFunctionCall
Converts an API class to a logical node for planning.
toLogicalWindow() - Method in class org.apache.flink.table.api.SessionWithGapOnTimeWithAlias
Converts an API class to a logical window for planning.
toLogicalWindow() - Method in class org.apache.flink.table.api.SlideWithSizeAndSlideOnTimeWithAlias
Converts an API class to a logical window for planning.
toLogicalWindow() - Method in class org.apache.flink.table.api.TumbleWithSizeOnTimeWithAlias
Converts an API class to a logical window for planning.
toLogicalWindow() - Method in class org.apache.flink.table.api.Window
Converts an API class to a logical window for planning.
toLong(Expression) - Method in class org.apache.flink.table.expressions.ExpressionUtils$
 
toLong(Expression) - Static method in class org.apache.flink.table.expressions.ExpressionUtils
 
toLowerCase(StringValue) - Static method in class org.apache.flink.util.StringValueUtils
Converts the given StringValue into a lower case variant.
toMap() - Method in class org.apache.flink.api.common.ExecutionConfig.GlobalJobParameters
Convert UserConfig into a Map<String, String> representation.
toMap() - Method in class org.apache.flink.api.java.utils.ParameterTool
 
toMap() - Method in class org.apache.flink.configuration.Configuration
 
toMap() - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
toMilliInterval(Expression, long) - Method in class org.apache.flink.table.expressions.ExpressionUtils$
 
toMilliInterval(Expression, long) - Static method in class org.apache.flink.table.expressions.ExpressionUtils
 
toMilliseconds() - Method in class org.apache.flink.api.common.time.Time
Converts the time interval to milliseconds.
toMilliseconds() - Method in class org.apache.flink.streaming.api.windowing.time.Time
Converts the time interval to milliseconds.
toMonthInterval(Expression, int) - Method in class org.apache.flink.table.expressions.ExpressionUtils$
 
toMonthInterval(Expression, int) - Static method in class org.apache.flink.table.expressions.ExpressionUtils
 
toNamedWindowProperty(String) - Method in class org.apache.flink.table.expressions.AbstractWindowProperty
 
toNamedWindowProperty(String) - Method in class org.apache.flink.table.expressions.ProctimeAttribute
 
toNamedWindowProperty(String) - Method in class org.apache.flink.table.expressions.RowtimeAttribute
 
toNamedWindowProperty(String) - Static method in class org.apache.flink.table.expressions.WindowEnd
 
toNamedWindowProperty(String) - Method in interface org.apache.flink.table.expressions.WindowProperty
 
toNamedWindowProperty(String) - Static method in class org.apache.flink.table.expressions.WindowStart
 
ToNullValue<T> - Class in org.apache.flink.graph.asm.translate.translators
Replace any type with NullValue.
ToNullValue() - Constructor for class org.apache.flink.graph.asm.translate.translators.ToNullValue
 
TOP_CASE_CLASS_SPEEDS - Static variable in class org.apache.flink.streaming.examples.windowing.util.TopSpeedWindowingExampleData
 
TOP_SONGS_RESULT - Static variable in class org.apache.flink.graph.examples.data.MusicProfilesData
 
TOP_SPEEDS - Static variable in class org.apache.flink.streaming.examples.windowing.util.TopSpeedWindowingExampleData
 
toParameterList(Configuration...) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
toParameterList(List<Configuration>) - Static method in class org.apache.flink.test.util.TestBaseUtils
 
topic - Variable in class org.apache.flink.streaming.connectors.kafka.KafkaTableSink
 
topicPartitionsMap - Variable in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducerBase
Partitions of each topic
topologyId - Static variable in class org.apache.flink.storm.exclamation.ExclamationLocal
 
topologyId - Static variable in class org.apache.flink.storm.wordcount.WordCountLocal
 
topologyId - Static variable in class org.apache.flink.storm.wordcount.WordCountLocalByName
 
topologyId - Static variable in class org.apache.flink.storm.wordcount.WordCountRemoteByClient
 
topologyId - Static variable in class org.apache.flink.storm.wordcount.WordCountRemoteBySubmitter
 
toPrintableString() - Method in interface org.apache.flink.graph.asm.result.PrintableResult
A human-readable representation of this value.
toPrintableString() - Method in class org.apache.flink.graph.library.clustering.directed.AverageClusteringCoefficient.Result
 
toPrintableString() - Method in class org.apache.flink.graph.library.clustering.directed.GlobalClusteringCoefficient.Result
 
toPrintableString() - Method in class org.apache.flink.graph.library.clustering.directed.LocalClusteringCoefficient.Result
Format values into a human-readable string.
toPrintableString() - Method in class org.apache.flink.graph.library.clustering.directed.TriadicCensus.Result
 
toPrintableString() - Method in class org.apache.flink.graph.library.clustering.directed.TriangleListing.Result
Format values into a human-readable string.
toPrintableString() - Method in class org.apache.flink.graph.library.clustering.undirected.AverageClusteringCoefficient.Result
 
toPrintableString() - Method in class org.apache.flink.graph.library.clustering.undirected.GlobalClusteringCoefficient.Result
 
toPrintableString() - Method in class org.apache.flink.graph.library.clustering.undirected.LocalClusteringCoefficient.Result
Format values into a human-readable string.
toPrintableString() - Method in class org.apache.flink.graph.library.clustering.undirected.TriadicCensus.Result
 
toPrintableString() - Method in class org.apache.flink.graph.library.clustering.undirected.TriangleListing.Result
Format values into a human-readable string.
toPrintableString() - Method in class org.apache.flink.graph.library.link_analysis.HITS.Result
 
toPrintableString() - Method in class org.apache.flink.graph.library.link_analysis.PageRank.Result
 
toPrintableString() - Method in class org.apache.flink.graph.library.metric.directed.EdgeMetrics.Result
 
toPrintableString() - Method in class org.apache.flink.graph.library.metric.directed.VertexMetrics.Result
 
toPrintableString() - Method in class org.apache.flink.graph.library.metric.undirected.EdgeMetrics.Result
 
toPrintableString() - Method in class org.apache.flink.graph.library.metric.undirected.VertexMetrics.Result
 
toPrintableString() - Method in class org.apache.flink.graph.library.similarity.AdamicAdar.Result
 
toPrintableString() - Method in class org.apache.flink.graph.library.similarity.JaccardIndex.Result
 
TopSpeedWindowing - Class in org.apache.flink.streaming.examples.windowing
An example of grouped stream windowing where different eviction and trigger policies can be used.
TopSpeedWindowing() - Constructor for class org.apache.flink.streaming.examples.windowing.TopSpeedWindowing
 
TopSpeedWindowing - Class in org.apache.flink.streaming.scala.examples.windowing
An example of grouped stream windowing where different eviction and trigger policies can be used.
TopSpeedWindowing() - Constructor for class org.apache.flink.streaming.scala.examples.windowing.TopSpeedWindowing
 
TopSpeedWindowing$ - Class in org.apache.flink.streaming.scala.examples.windowing
An example of grouped stream windowing where different eviction and trigger policies can be used.
TopSpeedWindowing$() - Constructor for class org.apache.flink.streaming.scala.examples.windowing.TopSpeedWindowing$
 
TopSpeedWindowing.CarEvent - Class in org.apache.flink.streaming.scala.examples.windowing
 
TopSpeedWindowing.CarEvent$ - Class in org.apache.flink.streaming.scala.examples.windowing
 
TopSpeedWindowingExampleData - Class in org.apache.flink.streaming.examples.windowing.util
 
toRel(RelOptTable) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
 
toRel(RelOptTable.ToRelContext, RelOptTable) - Method in class org.apache.flink.table.plan.schema.RelTable
 
toRelNode(RelBuilder) - Static method in class org.apache.flink.table.plan.logical.Aggregate
 
toRelNode(RelBuilder) - Static method in class org.apache.flink.table.plan.logical.AliasNode
 
toRelNode(RelBuilder) - Static method in class org.apache.flink.table.plan.logical.CatalogNode
 
toRelNode(RelBuilder) - Static method in class org.apache.flink.table.plan.logical.Distinct
 
toRelNode(RelBuilder) - Static method in class org.apache.flink.table.plan.logical.Filter
 
toRelNode(RelBuilder) - Static method in class org.apache.flink.table.plan.logical.Intersect
 
toRelNode(RelBuilder) - Static method in class org.apache.flink.table.plan.logical.Join
 
toRelNode(RelBuilder) - Static method in class org.apache.flink.table.plan.logical.Limit
 
toRelNode(RelBuilder) - Method in class org.apache.flink.table.plan.logical.LogicalNode
 
toRelNode(RelBuilder) - Static method in class org.apache.flink.table.plan.logical.LogicalRelNode
 
toRelNode(RelBuilder) - Static method in class org.apache.flink.table.plan.logical.LogicalTableFunctionCall
 
toRelNode(RelBuilder) - Static method in class org.apache.flink.table.plan.logical.Minus
 
toRelNode(RelBuilder) - Static method in class org.apache.flink.table.plan.logical.Project
 
toRelNode(RelBuilder) - Static method in class org.apache.flink.table.plan.logical.Sort
 
toRelNode(RelBuilder) - Static method in class org.apache.flink.table.plan.logical.Union
 
toRelNode(RelBuilder) - Static method in class org.apache.flink.table.plan.logical.WindowAggregate
 
toResultMap(Map<String, Accumulator<?, ?>>) - Static method in class org.apache.flink.api.common.accumulators.AccumulatorHelper
Transform the Map with accumulators into a Map containing only the results
toRetractStream(Table, Class<T>) - Method in class org.apache.flink.table.api.java.StreamTableEnvironment
Converts the given Table into a DataStream of add and retract messages.
toRetractStream(Table, TypeInformation<T>) - Method in class org.apache.flink.table.api.java.StreamTableEnvironment
Converts the given Table into a DataStream of add and retract messages.
toRetractStream(Table, Class<T>, StreamQueryConfig) - Method in class org.apache.flink.table.api.java.StreamTableEnvironment
Converts the given Table into a DataStream of add and retract messages.
toRetractStream(Table, TypeInformation<T>, StreamQueryConfig) - Method in class org.apache.flink.table.api.java.StreamTableEnvironment
Converts the given Table into a DataStream of add and retract messages.
toRetractStream(Table, TypeInformation<T>) - Method in class org.apache.flink.table.api.scala.StreamTableEnvironment
Converts the given Table into a DataStream of add and retract messages.
toRetractStream(Table, StreamQueryConfig, TypeInformation<T>) - Method in class org.apache.flink.table.api.scala.StreamTableEnvironment
Converts the given Table into a DataStream of add and retract messages.
toRetractStream(TypeInformation<T>) - Method in class org.apache.flink.table.api.scala.TableConversions
Converts the Table to a DataStream of add and retract messages.
toRetractStream(StreamQueryConfig, TypeInformation<T>) - Method in class org.apache.flink.table.api.scala.TableConversions
Converts the Table to a DataStream of add and retract messages.
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.api.CurrentRange
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.api.CurrentRow
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.api.UnboundedRange
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.api.UnboundedRow
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Abs
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.AbstractWindowProperty
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Acos
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.AggFunctionCall
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Aggregation
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Alias
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.And
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.ArrayCardinality
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.ArrayConstructor
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.ArrayElement
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.ArrayElementAt
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Asc
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Asin
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Atan
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.Avg
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.BinaryArithmetic
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.BinaryComparison
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Call
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Cast
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Ceil
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.CharLength
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Cos
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Cot
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.Count
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.CurrentDate
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.CurrentTime
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.CurrentTimePoint
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.CurrentTimestamp
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Degrees
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Desc
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.Div
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.EqualTo
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Exp
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Expression
Convert Expression to its counterpart in Calcite, i.e.
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Extract
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.Flattening
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Floor
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.GetCompositeField
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.GreaterThan
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.GreaterThanOrEqual
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.If
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.InitCap
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.IsFalse
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.IsNotFalse
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.IsNotNull
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.IsNotTrue
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.IsNull
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.IsTrue
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.LessThan
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.LessThanOrEqual
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Like
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Literal
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Ln
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.LocalTime
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.LocalTimestamp
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Log10
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Lower
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.Max
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.Min
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.Minus
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.Mod
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.Mul
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Not
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.NotEqualTo
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Null
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Or
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.OverCall
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Overlay
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Pi
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Plus
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Position
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Power
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.ProctimeAttribute
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Quarter
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Radians
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.ResolvedFieldReference
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Round
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.RowtimeAttribute
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.ScalarFunctionCall
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Sign
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Similar
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Sin
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Sqrt
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.StddevPop
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.StddevSamp
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Substring
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.Sum
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.Sum0
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.SymbolExpression
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.TableFunctionCall
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Tan
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.TemporalCeil
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.TemporalFloor
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.TemporalOverlaps
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Trim
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.UnaryMinus
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.UnresolvedAlias
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.UnresolvedFieldReference
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.UnresolvedOverCall
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.Upper
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.VarPop
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.VarSamp
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.WindowEnd
 
toRexNode(RelBuilder) - Method in class org.apache.flink.table.expressions.WindowReference
 
toRexNode(RelBuilder) - Static method in class org.apache.flink.table.expressions.WindowStart
 
toRowInterval(Expression) - Method in class org.apache.flink.table.expressions.ExpressionUtils$
 
toRowInterval(Expression) - Static method in class org.apache.flink.table.expressions.ExpressionUtils
 
toSerializableHandle() - Method in class org.apache.flink.migration.runtime.state.filesystem.FileStreamStateHandle
Deprecated.
 
toSerializableHandle() - Method in class org.apache.flink.migration.runtime.state.memory.ByteStreamStateHandle
Deprecated.
 
toSerializableHandle() - Method in interface org.apache.flink.migration.runtime.state.StreamStateHandle
Deprecated.
Converts this stream state handle into a state handle that de-serializes the stream into an object using Java's serialization mechanism.
toSerializedEvent(AbstractEvent) - Static method in class org.apache.flink.runtime.io.network.api.serialization.EventSerializer
 
toSparseMatrix() - Method in class org.apache.flink.ml.math.DenseMatrix
Converts the DenseMatrix to a SparseMatrix
toSparseVector() - Method in class org.apache.flink.ml.math.DenseVector
Convert to a SparseVector
toSql(RelDataType) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
toString() - Method in class org.apache.flink.api.common.accumulators.AverageAccumulator
 
toString() - Method in class org.apache.flink.api.common.accumulators.DoubleCounter
 
toString() - Method in class org.apache.flink.api.common.accumulators.DoubleMaximum
 
toString() - Method in class org.apache.flink.api.common.accumulators.DoubleMinimum
 
toString() - Method in class org.apache.flink.api.common.accumulators.Histogram
 
toString() - Method in class org.apache.flink.api.common.accumulators.IntCounter
 
toString() - Method in class org.apache.flink.api.common.accumulators.IntMaximum
 
toString() - Method in class org.apache.flink.api.common.accumulators.IntMinimum
 
toString() - Method in class org.apache.flink.api.common.accumulators.ListAccumulator
 
toString() - Method in class org.apache.flink.api.common.accumulators.LongCounter
 
toString() - Method in class org.apache.flink.api.common.accumulators.LongMaximum
 
toString() - Method in class org.apache.flink.api.common.accumulators.LongMinimum
 
toString() - Method in class org.apache.flink.api.common.accumulators.SerializedListAccumulator
 
toString() - Method in class org.apache.flink.api.common.io.FileInputFormat.FileBaseStatistics
 
toString() - Method in class org.apache.flink.api.common.io.FileInputFormat
 
toString() - Method in class org.apache.flink.api.common.operators.DualInputSemanticProperties
 
toString() - Method in class org.apache.flink.api.common.operators.GenericDataSinkBase
 
toString() - Method in class org.apache.flink.api.common.operators.GenericDataSourceBase
 
toString() - Method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
toString() - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
toString() - Method in class org.apache.flink.api.common.operators.Operator
 
toString() - Method in class org.apache.flink.api.common.operators.OperatorInformation
 
toString() - Method in class org.apache.flink.api.common.operators.Ordering
 
toString() - Method in class org.apache.flink.api.common.operators.ResourceSpec
 
toString() - Method in class org.apache.flink.api.common.operators.SingleInputSemanticProperties
 
toString() - Method in class org.apache.flink.api.common.operators.util.FieldSet
 
toString() - Method in class org.apache.flink.api.common.state.AggregatingStateDescriptor
 
toString() - Method in class org.apache.flink.api.common.state.FoldingStateDescriptor
Deprecated.
 
toString() - Method in class org.apache.flink.api.common.state.ListStateDescriptor
 
toString() - Method in class org.apache.flink.api.common.state.MapStateDescriptor
 
toString() - Method in class org.apache.flink.api.common.state.ReducingStateDescriptor
 
toString() - Method in class org.apache.flink.api.common.state.StateDescriptor
 
toString() - Method in class org.apache.flink.api.common.state.ValueStateDescriptor
 
toString() - Method in class org.apache.flink.api.common.time.Time
 
toString() - Method in class org.apache.flink.api.common.typeinfo.BasicArrayTypeInfo
 
toString() - Method in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
toString() - Method in class org.apache.flink.api.common.typeinfo.NothingTypeInfo
 
toString() - Method in class org.apache.flink.api.common.typeinfo.PrimitiveArrayTypeInfo
 
toString() - Method in class org.apache.flink.api.common.typeinfo.SqlTimeTypeInfo
 
toString() - Method in class org.apache.flink.api.common.typeinfo.TypeHint
 
toString() - Method in class org.apache.flink.api.common.typeinfo.TypeInformation
 
toString() - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializer
 
toString() - Method in class org.apache.flink.api.common.typeutils.CompositeType.FlatFieldDescriptor
 
toString() - Method in class org.apache.flink.api.common.typeutils.CompositeType
 
toString() - Method in class org.apache.flink.api.java.aggregation.MaxAggregationFunction
 
toString() - Method in class org.apache.flink.api.java.aggregation.MinAggregationFunction
 
toString() - Method in class org.apache.flink.api.java.aggregation.SumAggregationFunction
 
toString() - Method in class org.apache.flink.api.java.io.CollectionInputFormat
 
toString() - Method in class org.apache.flink.api.java.io.CsvInputFormat
 
toString() - Method in class org.apache.flink.api.java.io.CsvOutputFormat
 
toString() - Method in class org.apache.flink.api.java.io.PrintingOutputFormat
 
toString() - Method in class org.apache.flink.api.java.io.TextInputFormat
 
toString() - Method in class org.apache.flink.api.java.io.TextOutputFormat
 
toString() - Method in class org.apache.flink.api.java.io.TextValueInputFormat
 
toString() - Method in class org.apache.flink.api.java.LocalEnvironment
 
toString() - Method in class org.apache.flink.api.java.operators.DataSink
 
toString() - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingGroupCombineOperator.TupleUnwrappingGroupCombiner
 
toString() - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingReduceGroupOperator.TupleUnwrappingGroupCombinableGroupReducer
 
toString() - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingReduceGroupOperator.TupleUnwrappingNonCombinableGroupReducer
 
toString() - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingSortedGroupCombineOperator.TupleUnwrappingGroupReducer
 
toString() - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingSortedReduceGroupOperator.TupleUnwrappingGroupCombinableGroupReducer
 
toString() - Method in class org.apache.flink.api.java.operators.translation.PlanUnwrappingSortedReduceGroupOperator.TupleUnwrappingNonCombinableGroupReducer
 
toString() - Method in class org.apache.flink.api.java.RemoteEnvironment
 
toString() - Method in class org.apache.flink.api.java.sca.ModifiedASMFrame
 
toString() - Method in class org.apache.flink.api.java.sca.TaggedValue
 
toString() - Method in class org.apache.flink.api.java.summarize.BooleanColumnSummary
 
toString() - Method in class org.apache.flink.api.java.summarize.NumericColumnSummary
 
toString() - Method in class org.apache.flink.api.java.summarize.ObjectColumnSummary
 
toString() - Method in class org.apache.flink.api.java.summarize.StringColumnSummary
 
toString() - Method in class org.apache.flink.api.java.tuple.Tuple0
Creates a string representation of the tuple in the form "()"
toString() - Method in class org.apache.flink.api.java.tuple.Tuple1
Creates a string representation of the tuple in the form (f0), where the individual fields are the value returned by calling Object.toString() on that field.
toString() - Method in class org.apache.flink.api.java.tuple.Tuple10
Creates a string representation of the tuple in the form (f0, f1, f2, f3, f4, f5, f6, f7, f8, f9), where the individual fields are the value returned by calling Object.toString() on that field.
toString() - Method in class org.apache.flink.api.java.tuple.Tuple11
Creates a string representation of the tuple in the form (f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10), where the individual fields are the value returned by calling Object.toString() on that field.
toString() - Method in class org.apache.flink.api.java.tuple.Tuple12
Creates a string representation of the tuple in the form (f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11), where the individual fields are the value returned by calling Object.toString() on that field.
toString() - Method in class org.apache.flink.api.java.tuple.Tuple13
Creates a string representation of the tuple in the form (f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12), where the individual fields are the value returned by calling Object.toString() on that field.
toString() - Method in class org.apache.flink.api.java.tuple.Tuple14
Creates a string representation of the tuple in the form (f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13), where the individual fields are the value returned by calling Object.toString() on that field.
toString() - Method in class org.apache.flink.api.java.tuple.Tuple15
Creates a string representation of the tuple in the form (f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14), where the individual fields are the value returned by calling Object.toString() on that field.
toString() - Method in class org.apache.flink.api.java.tuple.Tuple16
Creates a string representation of the tuple in the form (f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15), where the individual fields are the value returned by calling Object.toString() on that field.
toString() - Method in class org.apache.flink.api.java.tuple.Tuple17
Creates a string representation of the tuple in the form (f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16), where the individual fields are the value returned by calling Object.toString() on that field.
toString() - Method in class org.apache.flink.api.java.tuple.Tuple18
Creates a string representation of the tuple in the form (f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17), where the individual fields are the value returned by calling Object.toString() on that field.
toString() - Method in class org.apache.flink.api.java.tuple.Tuple19
Creates a string representation of the tuple in the form (f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17, f18), where the individual fields are the value returned by calling Object.toString() on that field.
toString() - Method in class org.apache.flink.api.java.tuple.Tuple2
Creates a string representation of the tuple in the form (f0, f1), where the individual fields are the value returned by calling Object.toString() on that field.
toString() - Method in class org.apache.flink.api.java.tuple.Tuple20
Creates a string representation of the tuple in the form (f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17, f18, f19), where the individual fields are the value returned by calling Object.toString() on that field.
toString() - Method in class org.apache.flink.api.java.tuple.Tuple21
Creates a string representation of the tuple in the form (f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17, f18, f19, f20), where the individual fields are the value returned by calling Object.toString() on that field.
toString() - Method in class org.apache.flink.api.java.tuple.Tuple22
Creates a string representation of the tuple in the form (f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17, f18, f19, f20, f21), where the individual fields are the value returned by calling Object.toString() on that field.
toString() - Method in class org.apache.flink.api.java.tuple.Tuple23
Creates a string representation of the tuple in the form (f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17, f18, f19, f20, f21, f22), where the individual fields are the value returned by calling Object.toString() on that field.
toString() - Method in class org.apache.flink.api.java.tuple.Tuple24
Creates a string representation of the tuple in the form (f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17, f18, f19, f20, f21, f22, f23), where the individual fields are the value returned by calling Object.toString() on that field.
toString() - Method in class org.apache.flink.api.java.tuple.Tuple25
Creates a string representation of the tuple in the form (f0, f1, f2, f3, f4, f5, f6, f7, f8, f9, f10, f11, f12, f13, f14, f15, f16, f17, f18, f19, f20, f21, f22, f23, f24), where the individual fields are the value returned by calling Object.toString() on that field.
toString() - Method in class org.apache.flink.api.java.tuple.Tuple3
Creates a string representation of the tuple in the form (f0, f1, f2), where the individual fields are the value returned by calling Object.toString() on that field.
toString() - Method in class org.apache.flink.api.java.tuple.Tuple4
Creates a string representation of the tuple in the form (f0, f1, f2, f3), where the individual fields are the value returned by calling Object.toString() on that field.
toString() - Method in class org.apache.flink.api.java.tuple.Tuple5
Creates a string representation of the tuple in the form (f0, f1, f2, f3, f4), where the individual fields are the value returned by calling Object.toString() on that field.
toString() - Method in class org.apache.flink.api.java.tuple.Tuple6
Creates a string representation of the tuple in the form (f0, f1, f2, f3, f4, f5), where the individual fields are the value returned by calling Object.toString() on that field.
toString() - Method in class org.apache.flink.api.java.tuple.Tuple7
Creates a string representation of the tuple in the form (f0, f1, f2, f3, f4, f5, f6), where the individual fields are the value returned by calling Object.toString() on that field.
toString() - Method in class org.apache.flink.api.java.tuple.Tuple8
Creates a string representation of the tuple in the form (f0, f1, f2, f3, f4, f5, f6, f7), where the individual fields are the value returned by calling Object.toString() on that field.
toString() - Method in class org.apache.flink.api.java.tuple.Tuple9
Creates a string representation of the tuple in the form (f0, f1, f2, f3, f4, f5, f6, f7, f8), where the individual fields are the value returned by calling Object.toString() on that field.
toString() - Method in class org.apache.flink.api.java.typeutils.EitherTypeInfo
 
toString() - Method in class org.apache.flink.api.java.typeutils.EnumTypeInfo
 
toString() - Method in class org.apache.flink.api.java.typeutils.GenericTypeInfo
 
toString() - Method in class org.apache.flink.api.java.typeutils.ListTypeInfo
 
toString() - Method in class org.apache.flink.api.java.typeutils.MapTypeInfo
 
toString() - Method in class org.apache.flink.api.java.typeutils.MissingTypeInfo
 
toString() - Method in class org.apache.flink.api.java.typeutils.ObjectArrayTypeInfo
 
toString() - Method in class org.apache.flink.api.java.typeutils.PojoField
 
toString() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo.NamedFlatFieldDescriptor
 
toString() - Method in class org.apache.flink.api.java.typeutils.PojoTypeInfo
 
toString() - Method in class org.apache.flink.api.java.typeutils.RowTypeInfo
 
toString() - Method in class org.apache.flink.api.java.typeutils.runtime.Tuple0Serializer
 
toString() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
toString() - Method in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
toString() - Method in class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
toString() - Method in class org.apache.flink.api.java.typeutils.WritableTypeInfo
 
toString() - Method in class org.apache.flink.api.java.Utils.ChecksumHashCode
 
toString() - Method in class org.apache.flink.api.scala.operators.ScalaCsvOutputFormat
 
toString() - Method in class org.apache.flink.api.scala.typeutils.CaseClassTypeInfo
 
toString() - Method in class org.apache.flink.api.scala.typeutils.EitherTypeInfo
 
toString() - Method in class org.apache.flink.api.scala.typeutils.EnumValueTypeInfo
 
toString() - Method in class org.apache.flink.api.scala.typeutils.OptionTypeInfo
 
toString() - Method in class org.apache.flink.api.scala.typeutils.ScalaNothingTypeInfo
 
toString() - Method in class org.apache.flink.api.scala.typeutils.TraversableTypeInfo
 
toString() - Method in class org.apache.flink.api.scala.typeutils.TryTypeInfo
 
toString() - Method in class org.apache.flink.api.scala.typeutils.UnitTypeInfo
 
toString() - Method in class org.apache.flink.cep.nfa.DeweyNumber
 
toString() - Method in class org.apache.flink.cep.nfa.SharedBuffer.SharedBufferEdge
 
toString() - Method in class org.apache.flink.cep.nfa.SharedBuffer
 
toString() - Method in class org.apache.flink.cep.nfa.State
 
toString() - Method in class org.apache.flink.cep.nfa.StateTransition
 
toString() - Method in class org.apache.flink.client.program.ContextEnvironment
 
toString() - Method in class org.apache.flink.configuration.ConfigOption
 
toString() - Method in class org.apache.flink.configuration.Configuration
 
toString() - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
toString() - Method in class org.apache.flink.configuration.MemorySize
 
toString() - Method in class org.apache.flink.contrib.streaming.state.RocksDBStateBackend
 
toString() - Method in class org.apache.flink.contrib.tweetinputformat.model.tweet.Coordinates
 
toString() - Method in class org.apache.flink.core.fs.ClosingFSDataInputStream
 
toString() - Method in class org.apache.flink.core.fs.ClosingFSDataOutputStream
 
toString() - Method in class org.apache.flink.core.fs.FileInputSplit
 
toString() - Method in class org.apache.flink.core.fs.local.LocalFileStatus
 
toString() - Method in class org.apache.flink.core.fs.Path
 
toString() - Method in class org.apache.flink.core.io.GenericInputSplit
 
toString() - Method in class org.apache.flink.core.io.LocatableInputSplit
 
toString() - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
toString() - Method in class org.apache.flink.core.testutils.OneShotLatch
 
toString() - Method in class org.apache.flink.examples.java.clustering.KMeans.Centroid
 
toString() - Method in class org.apache.flink.examples.java.clustering.KMeans.Point
 
toString() - Method in class org.apache.flink.examples.java.distcp.FileCopyTask
 
toString() - Method in class org.apache.flink.examples.java.misc.CollectionExecutionExample.EMail
 
toString() - Method in class org.apache.flink.examples.java.misc.CollectionExecutionExample.User
 
toString() - Method in class org.apache.flink.examples.java.ml.LinearRegression.Data
 
toString() - Method in class org.apache.flink.examples.java.ml.LinearRegression.Params
 
toString() - Method in class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator.VectorAccumulator
 
toString() - Method in class org.apache.flink.examples.java.wordcount.WordCountPojo.Word
 
toString() - Method in class org.apache.flink.examples.scala.clustering.KMeans.Centroid
 
toString() - Method in interface org.apache.flink.examples.scala.clustering.KMeans.Coordinate
 
toString() - Method in class org.apache.flink.graph.asm.dataset.ChecksumHashCode.Checksum
 
toString() - Method in class org.apache.flink.graph.drivers.parameter.BooleanParameter
 
toString() - Method in class org.apache.flink.graph.drivers.parameter.DoubleParameter
 
toString() - Method in class org.apache.flink.graph.drivers.parameter.LongParameter
 
toString() - Method in class org.apache.flink.graph.drivers.parameter.StringParameter
 
toString() - Method in class org.apache.flink.graph.examples.EuclideanGraphWeighing.Point
 
toString() - Method in class org.apache.flink.graph.generator.CirculantGraph.OffsetRange
 
toString() - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
 
toString() - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
 
toString() - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
 
toString() - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
 
toString() - Method in class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
 
toString() - Method in class org.apache.flink.mesos.runtime.clusterframework.LaunchableMesosWorker
 
toString() - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters
 
toString() - Method in class org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore.Worker
 
toString() - Method in class org.apache.flink.mesos.scheduler.messages.AcceptOffers
 
toString() - Method in class org.apache.flink.mesos.scheduler.messages.Disconnected
 
toString() - Method in class org.apache.flink.mesos.scheduler.messages.Error
 
toString() - Method in class org.apache.flink.mesos.scheduler.messages.ExecutorLost
 
toString() - Method in class org.apache.flink.mesos.scheduler.messages.FrameworkMessage
 
toString() - Method in class org.apache.flink.mesos.scheduler.messages.OfferRescinded
 
toString() - Method in class org.apache.flink.mesos.scheduler.messages.Registered
 
toString() - Method in class org.apache.flink.mesos.scheduler.messages.ReRegistered
 
toString() - Method in class org.apache.flink.mesos.scheduler.messages.ResourceOffers
 
toString() - Method in class org.apache.flink.mesos.scheduler.messages.SlaveLost
 
toString() - Method in class org.apache.flink.mesos.scheduler.messages.StatusUpdate
 
toString() - Method in class org.apache.flink.mesos.util.MesosConfiguration
 
toString() - Method in class org.apache.flink.migration.api.common.state.ListStateDescriptor
Deprecated.
 
toString() - Method in class org.apache.flink.migration.runtime.checkpoint.savepoint.SavepointV0
 
toString() - Method in class org.apache.flink.migration.runtime.checkpoint.SubtaskState
Deprecated.
 
toString() - Method in class org.apache.flink.migration.runtime.state.memory.AbstractMemStateSnapshot
Deprecated.
 
toString() - Method in class org.apache.flink.migration.util.SerializedValue
Deprecated.
 
toString() - Method in class org.apache.flink.ml.common.LabeledVector
 
toString() - Method in class org.apache.flink.ml.math.DenseMatrix
 
toString() - Method in class org.apache.flink.ml.math.DenseVector
 
toString() - Method in class org.apache.flink.ml.math.distributed.IndexedRow
 
toString() - Method in class org.apache.flink.ml.math.SparseMatrix
 
toString() - Method in class org.apache.flink.ml.math.SparseVector
 
toString() - Method in class org.apache.flink.ml.recommendation.ALS.BlockRating
 
toString() - Method in class org.apache.flink.ml.recommendation.ALS.Factors
 
toString() - Method in class org.apache.flink.ml.recommendation.ALS.InBlockInformation
 
toString() - Method in class org.apache.flink.ml.recommendation.ALS.OutBlockInformation
 
toString() - Method in class org.apache.flink.ml.recommendation.ALS.OutLinks
 
toString() - Method in class org.apache.flink.optimizer.costs.Costs
 
toString() - Method in class org.apache.flink.optimizer.dag.DagConnection
 
toString() - Method in class org.apache.flink.optimizer.dag.OptimizerNode
 
toString() - Method in class org.apache.flink.optimizer.dag.OptimizerNode.UnclosedBranchDescriptor
 
toString() - Method in class org.apache.flink.optimizer.dataproperties.GlobalProperties
 
toString() - Method in class org.apache.flink.optimizer.dataproperties.InterestingProperties
 
toString() - Method in class org.apache.flink.optimizer.dataproperties.LocalProperties
 
toString() - Method in class org.apache.flink.optimizer.dataproperties.RequestedGlobalProperties
 
toString() - Method in class org.apache.flink.optimizer.dataproperties.RequestedLocalProperties
 
toString() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual.GlobalPropertiesPair
 
toString() - Method in class org.apache.flink.optimizer.operators.OperatorDescriptorDual.LocalPropertiesPair
 
toString() - Method in class org.apache.flink.optimizer.plan.Channel
 
toString() - Method in class org.apache.flink.optimizer.plan.PlanNode
 
toString() - Method in class org.apache.flink.python.api.PythonOperationInfo
 
toString() - Method in class org.apache.flink.runtime.blob.BlobKey
 
toString() - Method in class org.apache.flink.runtime.broadcast.BroadcastVariableKey
 
toString() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetaData
 
toString() - Method in class org.apache.flink.runtime.checkpoint.CheckpointMetrics
 
toString() - Method in class org.apache.flink.runtime.checkpoint.CheckpointOptions
 
toString() - Method in class org.apache.flink.runtime.checkpoint.CheckpointProperties
 
toString() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpoint
 
toString() - Method in class org.apache.flink.runtime.checkpoint.CompletedCheckpointStats
 
toString() - Method in class org.apache.flink.runtime.checkpoint.MasterState
 
toString() - Method in class org.apache.flink.runtime.checkpoint.OperatorState
 
toString() - Method in class org.apache.flink.runtime.checkpoint.OperatorSubtaskState
 
toString() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpoint
 
toString() - Method in class org.apache.flink.runtime.checkpoint.PendingCheckpointStats
 
toString() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
 
toString() - Method in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
 
toString() - Method in class org.apache.flink.runtime.checkpoint.SubtaskState
 
toString() - Method in class org.apache.flink.runtime.checkpoint.TaskState
Deprecated.
 
toString() - Method in class org.apache.flink.runtime.clusterframework.ContaineredTaskManagerParameters
 
toString() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification.Artifact
 
toString() - Method in class org.apache.flink.runtime.clusterframework.ContainerSpecification
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.CheckAndAllocateContainers
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.FatalErrorOccurred
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.GetClusterStatus
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.GetClusterStatusResponse
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.InfoMessage
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.NewLeaderAvailable
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.NotifyResourceStarted
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.ReconnectResourceManager
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.RegisterInfoMessageListener
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.RegisterInfoMessageListenerSuccessful
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.RegisterResourceManager
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.RegisterResourceManagerSuccessful
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.RemoveResource
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.ResourceRemoved
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.SetWorkerPoolSize
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.ShutdownClusterAfterJob
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.StopCluster
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.StopClusterSuccessful
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.TriggerRegistrationAtJobManager
 
toString() - Method in class org.apache.flink.runtime.clusterframework.messages.UnRegisterInfoMessageListener
 
toString() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceID
 
toString() - Method in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
 
toString() - Method in class org.apache.flink.runtime.clusterframework.types.SlotID
 
toString() - Method in class org.apache.flink.runtime.deployment.InputChannelDeploymentDescriptor
 
toString() - Method in class org.apache.flink.runtime.deployment.InputGateDeploymentDescriptor
 
toString() - Method in class org.apache.flink.runtime.deployment.ResultPartitionDeploymentDescriptor
 
toString() - Method in class org.apache.flink.runtime.deployment.ResultPartitionLocation
 
toString() - Method in class org.apache.flink.runtime.deployment.TaskDeploymentDescriptor
 
toString() - Method in class org.apache.flink.runtime.executiongraph.Execution
 
toString() - Method in class org.apache.flink.runtime.executiongraph.ExecutionAndSlot
 
toString() - Method in class org.apache.flink.runtime.executiongraph.ExecutionEdge
 
toString() - Method in class org.apache.flink.runtime.executiongraph.ExecutionVertex
 
toString() - Method in class org.apache.flink.runtime.executiongraph.IntermediateResult
 
toString() - Method in class org.apache.flink.runtime.executiongraph.JobInformation
 
toString() - Method in class org.apache.flink.runtime.executiongraph.restart.FailureRateRestartStrategy
 
toString() - Method in class org.apache.flink.runtime.executiongraph.restart.FixedDelayRestartStrategy
 
toString() - Method in class org.apache.flink.runtime.executiongraph.restart.NoRestartStrategy
 
toString() - Method in class org.apache.flink.runtime.instance.AkkaActorGateway
 
toString() - Method in class org.apache.flink.runtime.instance.HardwareDescription
 
toString() - Method in class org.apache.flink.runtime.instance.Instance
 
toString() - Method in class org.apache.flink.runtime.instance.SharedSlot
 
toString() - Method in class org.apache.flink.runtime.instance.SimpleSlot
 
toString() - Method in class org.apache.flink.runtime.instance.Slot
 
toString() - Method in class org.apache.flink.runtime.io.disk.iomanager.FileIOChannel.ID
 
toString() - Method in class org.apache.flink.runtime.io.network.api.CancelCheckpointMarker
 
toString() - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
 
toString() - Method in class org.apache.flink.runtime.io.network.api.EndOfPartitionEvent
 
toString() - Method in class org.apache.flink.runtime.io.network.api.EndOfSuperstepEvent
 
toString() - Method in class org.apache.flink.runtime.io.network.buffer.Buffer
 
toString() - Method in class org.apache.flink.runtime.io.network.ConnectionID
 
toString() - Method in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
toString() - Method in class org.apache.flink.runtime.io.network.partition.consumer.BufferOrEvent
 
toString() - Method in class org.apache.flink.runtime.io.network.partition.consumer.LocalInputChannel
 
toString() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
toString() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartition
 
toString() - Method in class org.apache.flink.runtime.io.network.partition.ResultPartitionID
 
toString() - Method in class org.apache.flink.runtime.jobgraph.IntermediateDataSet
 
toString() - Method in class org.apache.flink.runtime.jobgraph.JobEdge
 
toString() - Method in class org.apache.flink.runtime.jobgraph.JobGraph
 
toString() - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
toString() - Method in class org.apache.flink.runtime.jobgraph.SavepointRestoreSettings
 
toString() - Method in class org.apache.flink.runtime.jobgraph.tasks.JobCheckpointingSettings
 
toString() - Method in class org.apache.flink.runtime.jobmanager.JobInfo
 
toString() - Method in class org.apache.flink.runtime.jobmanager.scheduler.CoLocationConstraint
 
toString() - Method in class org.apache.flink.runtime.jobmanager.scheduler.ScheduledUnit
 
toString() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SetQueue
 
toString() - Method in class org.apache.flink.runtime.jobmanager.scheduler.SlotSharingGroup
 
toString() - Method in class org.apache.flink.runtime.jobmanager.slots.AllocatedSlot
 
toString() - Method in class org.apache.flink.runtime.jobmanager.slots.SlotAndLocality
 
toString() - Method in class org.apache.flink.runtime.jobmanager.SubmittedJobGraph
 
toString() - Method in class org.apache.flink.runtime.jobmaster.JobMasterRegistrationSuccess
 
toString() - Method in class org.apache.flink.runtime.leaderelection.LeaderAddressAndId
 
toString() - Method in class org.apache.flink.runtime.messages.Acknowledge
 
toString() - Method in class org.apache.flink.runtime.messages.checkpoint.AbstractCheckpointMessage
 
toString() - Method in class org.apache.flink.runtime.messages.checkpoint.AcknowledgeCheckpoint
 
toString() - Method in class org.apache.flink.runtime.messages.checkpoint.DeclineCheckpoint
 
toString() - Method in class org.apache.flink.runtime.messages.checkpoint.NotifyCheckpointComplete
 
toString() - Method in class org.apache.flink.runtime.messages.checkpoint.TriggerCheckpoint
 
toString() - Method in class org.apache.flink.runtime.messages.ExecutionGraphMessages.ExecutionStateChanged
 
toString() - Method in class org.apache.flink.runtime.messages.ExecutionGraphMessages.JobStatusChanged
 
toString() - Method in class org.apache.flink.runtime.messages.webmonitor.JobDetails
 
toString() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsOverview
 
toString() - Method in class org.apache.flink.runtime.messages.webmonitor.JobsWithIDsOverview
 
toString() - Method in class org.apache.flink.runtime.messages.webmonitor.MultipleJobsDetails
 
toString() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobDetails
 
toString() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobsOverview
 
toString() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestJobsWithIDsOverview
 
toString() - Method in class org.apache.flink.runtime.messages.webmonitor.RequestStatusOverview
 
toString() - Method in class org.apache.flink.runtime.messages.webmonitor.StatusOverview
 
toString() - Method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
 
toString() - Method in class org.apache.flink.runtime.minicluster.MiniClusterConfiguration
 
toString() - Method in class org.apache.flink.runtime.operators.hash.InMemoryPartition
 
toString() - Method in class org.apache.flink.runtime.operators.util.BitSet
 
toString() - Method in class org.apache.flink.runtime.operators.util.BloomFilter.BitSet
 
toString() - Method in class org.apache.flink.runtime.operators.util.BloomFilter
 
toString() - Method in class org.apache.flink.runtime.query.KvStateLocation
 
toString() - Method in class org.apache.flink.runtime.query.KvStateMessage.LookupKvStateLocation
 
toString() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateRegistered
 
toString() - Method in class org.apache.flink.runtime.query.KvStateMessage.NotifyKvStateUnregistered
 
toString() - Method in class org.apache.flink.runtime.query.netty.AtomicKvStateRequestStats
 
toString() - Method in class org.apache.flink.runtime.query.netty.message.KvStateRequest
 
toString() - Method in class org.apache.flink.runtime.query.netty.message.KvStateRequestFailure
 
toString() - Method in class org.apache.flink.runtime.query.netty.message.KvStateRequestResult
 
toString() - Method in class org.apache.flink.runtime.registration.RegisteredRpcConnection
 
toString() - Method in class org.apache.flink.runtime.registration.RegistrationResponse.Decline
 
toString() - Method in class org.apache.flink.runtime.registration.RegistrationResponse.Success
 
toString() - Method in class org.apache.flink.runtime.state.BoundedInputStream
 
toString() - Method in class org.apache.flink.runtime.state.filesystem.FileStateHandle
 
toString() - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory
 
toString() - Method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
 
toString() - Method in class org.apache.flink.runtime.state.heap.HeapKeyedStateBackend
 
toString() - Method in class org.apache.flink.runtime.state.IncrementalKeyedStateHandle
 
toString() - Method in class org.apache.flink.runtime.state.KeyGroupRange
 
toString() - Method in class org.apache.flink.runtime.state.KeyGroupRangeOffsets
 
toString() - Method in class org.apache.flink.runtime.state.KeyGroupsStateHandle
 
toString() - Method in class org.apache.flink.runtime.state.memory.ByteStreamStateHandle
 
toString() - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory
 
toString() - Method in class org.apache.flink.runtime.state.memory.MemoryStateBackend
 
toString() - Method in class org.apache.flink.runtime.state.MultiStreamStateHandle
 
toString() - Method in class org.apache.flink.runtime.state.OperatorStateHandle.StateMetaInfo
 
toString() - Method in class org.apache.flink.runtime.state.OperatorStateHandle
 
toString() - Method in class org.apache.flink.runtime.state.RegisteredKeyedBackendStateMetaInfo
 
toString() - Method in class org.apache.flink.runtime.state.RegisteredOperatorBackendStateMetaInfo
 
toString() - Method in class org.apache.flink.runtime.state.SharedStateRegistry.Result
 
toString() - Method in class org.apache.flink.runtime.state.SharedStateRegistry
 
toString() - Method in class org.apache.flink.runtime.state.VoidNamespace
 
toString() - Method in class org.apache.flink.runtime.taskexecutor.QueryableStateConfiguration
 
toString() - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutorRegistrationSuccess
 
toString() - Method in class org.apache.flink.runtime.taskmanager.NetworkEnvironmentConfiguration
 
toString() - Method in class org.apache.flink.runtime.taskmanager.Task
 
toString() - Method in class org.apache.flink.runtime.taskmanager.TaskExecutionState
 
toString() - Method in class org.apache.flink.runtime.taskmanager.TaskManagerLocation
 
toString() - Method in class org.apache.flink.runtime.util.DataOutputSerializer
 
toString() - Method in exception org.apache.flink.runtime.util.SerializedThrowable
 
toString() - Method in class org.apache.flink.runtime.webmonitor.history.ArchivedJson
 
toString() - Method in class org.apache.flink.runtime.webmonitor.OperatorBackPressureStats
 
toString() - Method in class org.apache.flink.runtime.webmonitor.StackTraceSample
 
toString() - Method in class org.apache.flink.storm.util.SplitStreamType
 
toString() - Method in class org.apache.flink.storm.wordcount.operators.WordCountDataPojos.Sentence
 
toString() - Method in class org.apache.flink.storm.wrappers.StormTuple
 
toString() - Method in enum org.apache.flink.streaming.api.datastream.LegacyWindowOperatorType
 
toString() - Method in class org.apache.flink.streaming.api.environment.RemoteStreamEnvironment
 
toString() - Method in class org.apache.flink.streaming.api.functions.sink.PrintSinkFunction
 
toString() - Method in class org.apache.flink.streaming.api.functions.source.TimestampedFileInputSplit
 
toString() - Method in class org.apache.flink.streaming.api.graph.StreamConfig
 
toString() - Method in class org.apache.flink.streaming.api.graph.StreamEdge
 
toString() - Method in class org.apache.flink.streaming.api.graph.StreamNode
 
toString() - Method in class org.apache.flink.streaming.api.operators.InternalTimer
 
toString() - Static method in class org.apache.flink.streaming.api.scala.OutputTag
 
toString() - Method in class org.apache.flink.streaming.api.transformations.StreamTransformation
 
toString() - Method in class org.apache.flink.streaming.api.watermark.Watermark
 
toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
 
toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.GlobalWindows
 
toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
 
toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingEventTimeWindows
 
toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.SlidingProcessingTimeWindows
 
toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
 
toString() - Method in class org.apache.flink.streaming.api.windowing.assigners.TumblingProcessingTimeWindows
 
toString() - Method in class org.apache.flink.streaming.api.windowing.evictors.DeltaEvictor
 
toString() - Method in class org.apache.flink.streaming.api.windowing.evictors.TimeEvictor
 
toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousEventTimeTrigger
 
toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.ContinuousProcessingTimeTrigger
 
toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.CountTrigger
 
toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.DeltaTrigger
 
toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.EventTimeTrigger
 
toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.ProcessingTimeTrigger
 
toString() - Method in class org.apache.flink.streaming.api.windowing.triggers.PurgingTrigger
 
toString() - Method in class org.apache.flink.streaming.api.windowing.windows.GlobalWindow
 
toString() - Method in class org.apache.flink.streaming.api.windowing.windows.TimeWindow
 
toString() - Method in class org.apache.flink.streaming.connectors.fs.bucketing.BasePathBucketer
 
toString() - Method in class org.apache.flink.streaming.connectors.fs.bucketing.DateTimeBucketer
 
toString() - Method in class org.apache.flink.streaming.connectors.fs.DateTimeBucketer
Deprecated.
 
toString() - Method in class org.apache.flink.streaming.connectors.fs.NonRollingBucketer
Deprecated.
 
toString() - Method in class org.apache.flink.streaming.connectors.fs.RollingSink.BucketState
Deprecated.
 
toString() - Method in class org.apache.flink.streaming.connectors.kafka.internals.ClosableBlockingQueue
 
toString() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartition
 
toString(Map<KafkaTopicPartition, Long>) - Static method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartition
 
toString(List<KafkaTopicPartition>) - Static method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartition
 
toString() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionLeader
 
toString() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionState
 
toString() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionStateWithPeriodicWatermarks
 
toString() - Method in class org.apache.flink.streaming.connectors.kafka.internals.KafkaTopicPartitionStateWithPunctuatedWatermarks
 
toString() - Method in class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
 
toString() - Method in class org.apache.flink.streaming.examples.socket.SocketWindowWordCount.WordWithCount
 
toString() - Method in class org.apache.flink.streaming.examples.wordcount.PojoExample.Word
 
toString() - Method in class org.apache.flink.streaming.runtime.io.BarrierBuffer
 
toString() - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractAlignedProcessingTimeWindowOperator
Deprecated.
 
toString() - Method in class org.apache.flink.streaming.runtime.operators.windowing.MergingWindowSet
 
toString() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
toString() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
 
toString() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
 
toString() - Method in class org.apache.flink.streaming.runtime.partitioner.BroadcastPartitioner
 
toString() - Method in class org.apache.flink.streaming.runtime.partitioner.CustomPartitionerWrapper
 
toString() - Method in class org.apache.flink.streaming.runtime.partitioner.ForwardPartitioner
 
toString() - Method in class org.apache.flink.streaming.runtime.partitioner.GlobalPartitioner
 
toString() - Method in class org.apache.flink.streaming.runtime.partitioner.KeyGroupStreamPartitioner
 
toString() - Method in class org.apache.flink.streaming.runtime.partitioner.RebalancePartitioner
 
toString() - Method in class org.apache.flink.streaming.runtime.partitioner.RescalePartitioner
 
toString() - Method in class org.apache.flink.streaming.runtime.partitioner.ShufflePartitioner
 
toString() - Method in class org.apache.flink.streaming.runtime.streamrecord.LatencyMarker
 
toString() - Method in class org.apache.flink.streaming.runtime.streamrecord.StreamRecord
 
toString() - Method in class org.apache.flink.streaming.runtime.streamstatus.StreamStatus
 
toString() - Method in exception org.apache.flink.streaming.runtime.tasks.AsynchronousException
 
toString() - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
toString() - Method in exception org.apache.flink.streaming.runtime.tasks.TimerException
 
toString() - Static method in exception org.apache.flink.table.api.AmbiguousTableSourceConverterException
 
toString() - Static method in exception org.apache.flink.table.api.CatalogAlreadyExistException
 
toString() - Static method in exception org.apache.flink.table.api.CatalogNotExistException
 
toString() - Method in class org.apache.flink.table.api.CurrentRange
 
toString() - Method in class org.apache.flink.table.api.CurrentRow
 
toString() - Static method in exception org.apache.flink.table.api.ExpressionParserException
 
toString() - Static method in exception org.apache.flink.table.api.ExternalCatalogAlreadyExistException
 
toString() - Static method in exception org.apache.flink.table.api.ExternalCatalogNotExistException
 
toString() - Static method in exception org.apache.flink.table.api.NoMatchedTableSourceConverterException
 
toString() - Static method in exception org.apache.flink.table.api.SqlParserException
 
toString() - Method in class org.apache.flink.table.api.Table
Registers an unique table name under the table environment and return the registered table name.
toString() - Static method in exception org.apache.flink.table.api.TableAlreadyExistException
 
toString() - Static method in exception org.apache.flink.table.api.TableException
 
toString() - Static method in exception org.apache.flink.table.api.TableNotExistException
 
toString() - Method in class org.apache.flink.table.api.TableSchema
 
toString() - Method in class org.apache.flink.table.api.UnboundedRange
 
toString() - Method in class org.apache.flink.table.api.UnboundedRow
 
toString() - Static method in exception org.apache.flink.table.api.UnresolvedException
 
toString() - Static method in exception org.apache.flink.table.api.ValidationException
 
toString() - Method in class org.apache.flink.table.examples.java.WordCountSQL.WC
 
toString() - Method in class org.apache.flink.table.examples.java.WordCountTable.WC
 
toString() - Method in class org.apache.flink.table.expressions.Abs
 
toString() - Method in class org.apache.flink.table.expressions.AbstractWindowProperty
 
toString() - Method in class org.apache.flink.table.expressions.Acos
 
toString() - Method in class org.apache.flink.table.expressions.AggFunctionCall
 
toString() - Method in class org.apache.flink.table.expressions.Aggregation
 
toString() - Method in class org.apache.flink.table.expressions.Alias
 
toString() - Method in class org.apache.flink.table.expressions.And
 
toString() - Method in class org.apache.flink.table.expressions.ArrayCardinality
 
toString() - Method in class org.apache.flink.table.expressions.ArrayConstructor
 
toString() - Method in class org.apache.flink.table.expressions.ArrayElement
 
toString() - Method in class org.apache.flink.table.expressions.ArrayElementAt
 
toString() - Method in class org.apache.flink.table.expressions.Asc
 
toString() - Method in class org.apache.flink.table.expressions.Asin
 
toString() - Method in class org.apache.flink.table.expressions.Atan
 
toString() - Method in class org.apache.flink.table.expressions.Avg
 
toString() - Method in class org.apache.flink.table.expressions.Call
 
toString() - Method in class org.apache.flink.table.expressions.Cast
 
toString() - Method in class org.apache.flink.table.expressions.Ceil
 
toString() - Method in class org.apache.flink.table.expressions.CharLength
 
toString() - Method in class org.apache.flink.table.expressions.Cos
 
toString() - Method in class org.apache.flink.table.expressions.Cot
 
toString() - Method in class org.apache.flink.table.expressions.Count
 
toString() - Static method in class org.apache.flink.table.expressions.CurrentDate
 
toString() - Static method in class org.apache.flink.table.expressions.CurrentTime
 
toString() - Method in class org.apache.flink.table.expressions.CurrentTimePoint
 
toString() - Static method in class org.apache.flink.table.expressions.CurrentTimestamp
 
toString() - Method in class org.apache.flink.table.expressions.Degrees
 
toString() - Method in class org.apache.flink.table.expressions.Desc
 
toString() - Method in class org.apache.flink.table.expressions.Div
 
toString() - Method in class org.apache.flink.table.expressions.EqualTo
 
toString() - Method in class org.apache.flink.table.expressions.Exp
 
toString() - Method in class org.apache.flink.table.expressions.Extract
 
toString() - Method in class org.apache.flink.table.expressions.Flattening
 
toString() - Method in class org.apache.flink.table.expressions.Floor
 
toString() - Method in class org.apache.flink.table.expressions.GetCompositeField
 
toString() - Method in class org.apache.flink.table.expressions.GreaterThan
 
toString() - Method in class org.apache.flink.table.expressions.GreaterThanOrEqual
 
toString() - Method in class org.apache.flink.table.expressions.If
 
toString() - Method in class org.apache.flink.table.expressions.InitCap
 
toString() - Method in class org.apache.flink.table.expressions.IsFalse
 
toString() - Method in class org.apache.flink.table.expressions.IsNotFalse
 
toString() - Method in class org.apache.flink.table.expressions.IsNotNull
 
toString() - Method in class org.apache.flink.table.expressions.IsNotTrue
 
toString() - Method in class org.apache.flink.table.expressions.IsNull
 
toString() - Method in class org.apache.flink.table.expressions.IsTrue
 
toString() - Method in class org.apache.flink.table.expressions.LessThan
 
toString() - Method in class org.apache.flink.table.expressions.LessThanOrEqual
 
toString() - Method in class org.apache.flink.table.expressions.Like
 
toString() - Method in class org.apache.flink.table.expressions.Literal
 
toString() - Method in class org.apache.flink.table.expressions.Ln
 
toString() - Static method in class org.apache.flink.table.expressions.LocalTime
 
toString() - Static method in class org.apache.flink.table.expressions.LocalTimestamp
 
toString() - Method in class org.apache.flink.table.expressions.Log10
 
toString() - Method in class org.apache.flink.table.expressions.Lower
 
toString() - Method in class org.apache.flink.table.expressions.Max
 
toString() - Method in class org.apache.flink.table.expressions.Min
 
toString() - Method in class org.apache.flink.table.expressions.Minus
 
toString() - Method in class org.apache.flink.table.expressions.Mod
 
toString() - Method in class org.apache.flink.table.expressions.Mul
 
toString() - Method in class org.apache.flink.table.expressions.Not
 
toString() - Method in class org.apache.flink.table.expressions.NotEqualTo
 
toString() - Method in class org.apache.flink.table.expressions.Null
 
toString() - Method in class org.apache.flink.table.expressions.Or
 
toString() - Method in class org.apache.flink.table.expressions.OverCall
 
toString() - Method in class org.apache.flink.table.expressions.Overlay
 
toString() - Method in class org.apache.flink.table.expressions.Pi
 
toString() - Method in class org.apache.flink.table.expressions.Plus
 
toString() - Method in class org.apache.flink.table.expressions.Position
 
toString() - Method in class org.apache.flink.table.expressions.Power
 
toString() - Method in class org.apache.flink.table.expressions.ProctimeAttribute
 
toString() - Method in class org.apache.flink.table.expressions.Quarter
 
toString() - Method in class org.apache.flink.table.expressions.Radians
 
toString() - Method in class org.apache.flink.table.expressions.ResolvedFieldReference
 
toString() - Method in class org.apache.flink.table.expressions.Round
 
toString() - Method in class org.apache.flink.table.expressions.RowtimeAttribute
 
toString() - Method in class org.apache.flink.table.expressions.ScalarFunctionCall
 
toString() - Method in class org.apache.flink.table.expressions.Sign
 
toString() - Method in class org.apache.flink.table.expressions.Similar
 
toString() - Method in class org.apache.flink.table.expressions.Sin
 
toString() - Method in class org.apache.flink.table.expressions.Sqrt
 
toString() - Method in class org.apache.flink.table.expressions.StddevPop
 
toString() - Method in class org.apache.flink.table.expressions.StddevSamp
 
toString() - Method in class org.apache.flink.table.expressions.Substring
 
toString() - Method in class org.apache.flink.table.expressions.Sum
 
toString() - Method in class org.apache.flink.table.expressions.Sum0
 
toString() - Method in class org.apache.flink.table.expressions.SymbolExpression
 
toString() - Method in class org.apache.flink.table.expressions.TableFunctionCall
 
toString() - Method in class org.apache.flink.table.expressions.Tan
 
toString() - Method in class org.apache.flink.table.expressions.TemporalCeil
 
toString() - Method in class org.apache.flink.table.expressions.TemporalFloor
 
toString() - Method in class org.apache.flink.table.expressions.TemporalOverlaps
 
toString() - Static method in class org.apache.flink.table.expressions.TimeIntervalUnit
 
toString() - Static method in class org.apache.flink.table.expressions.TimePointUnit
 
toString() - Method in class org.apache.flink.table.expressions.Trim
 
toString() - Static method in class org.apache.flink.table.expressions.TrimMode
 
toString() - Method in class org.apache.flink.table.expressions.UnaryMinus
 
toString() - Method in class org.apache.flink.table.expressions.UnresolvedFieldReference
 
toString() - Method in class org.apache.flink.table.expressions.Upper
 
toString() - Method in class org.apache.flink.table.expressions.VarPop
 
toString() - Method in class org.apache.flink.table.expressions.VarSamp
 
toString() - Method in class org.apache.flink.table.expressions.WindowEnd
 
toString() - Method in class org.apache.flink.table.expressions.WindowReference
 
toString() - Method in class org.apache.flink.table.expressions.WindowStart
 
toString() - Method in class org.apache.flink.table.functions.ScalarFunction
 
toString() - Method in class org.apache.flink.table.functions.TableFunction
 
toString() - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
toString() - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
toString() - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
toString() - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
toString() - Method in class org.apache.flink.table.plan.cost.DataSetCost
 
toString() - Method in class org.apache.flink.table.plan.logical.LogicalWindow
 
toString() - Static method in class org.apache.flink.table.plan.logical.rel.LogicalWindowAggregate
 
toString() - Method in class org.apache.flink.table.plan.logical.SessionGroupWindow
 
toString() - Method in class org.apache.flink.table.plan.logical.SlidingGroupWindow
 
toString() - Method in class org.apache.flink.table.plan.logical.TumblingGroupWindow
 
toString() - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetAggregate
 
toString() - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetCalc
 
toString() - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetCorrelate
 
toString() - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetDistinct
 
toString() - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetIntersect
 
toString() - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetJoin
 
toString() - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetMinus
 
toString() - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetSingleRowJoin
 
toString() - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetSort
 
toString() - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetUnion
 
toString() - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetValues
 
toString() - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetWindowAggregate
 
toString() - Static method in class org.apache.flink.table.plan.nodes.datastream.AccMode
 
toString() - Method in class org.apache.flink.table.plan.nodes.datastream.AccModeTrait
 
toString() - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamCalc
 
toString() - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamCorrelate
 
toString() - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupAggregate
 
toString() - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
toString() - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamOverAggregate
 
toString() - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamUnion
 
toString() - Method in class org.apache.flink.table.plan.nodes.datastream.UpdateAsRetractionTrait
 
toString() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalAggregate
 
toString() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCalc
 
toString() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalCorrelate
 
toString() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalIntersect
 
toString() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalJoin
 
toString() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalMinus
 
toString() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalNativeTableScan
 
toString() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalOverWindow
 
toString() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalSort
 
toString() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableFunctionScan
 
toString() - Method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalTableSourceScan
 
toString() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalUnion
 
toString() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalValues
 
toString() - Static method in class org.apache.flink.table.plan.nodes.logical.FlinkLogicalWindowAggregate
 
toString() - Method in class org.apache.flink.table.plan.nodes.PhysicalTableSourceScan
 
toString() - Static method in class org.apache.flink.table.plan.rules.dataSet.BatchTableSourceScanRule
 
toString() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateRule
 
toString() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetAggregateWithNullValuesRule
 
toString() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetCalcRule
 
toString() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetCorrelateRule
 
toString() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetDistinctRule
 
toString() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetIntersectRule
 
toString() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetJoinRule
 
toString() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetLogicalWindowAggregateRule
 
toString() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetMinusRule
 
toString() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetScanRule
 
toString() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetSingleRowJoinRule
 
toString() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetSortRule
 
toString() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetUnionRule
 
toString() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetValuesRule
 
toString() - Static method in class org.apache.flink.table.plan.rules.dataSet.DataSetWindowAggregateRule
 
toString() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamCalcRule
 
toString() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamCorrelateRule
 
toString() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupAggregateRule
 
toString() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamGroupWindowAggregateRule
 
toString() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamLogicalWindowAggregateRule
 
toString() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamOverAggregateRule
 
toString() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamScanRule
 
toString() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamUnionRule
 
toString() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamValuesRule
 
toString() - Static method in class org.apache.flink.table.plan.rules.datastream.StreamTableSourceScanRule
 
toString() - Static method in class org.apache.flink.table.plan.rules.logical.EnumerableToLogicalTableScan
 
toString() - Static method in class org.apache.flink.table.plan.rules.logical.LogicalUnnestRule
 
toString() - Static method in class org.apache.flink.table.plan.rules.logical.PushFilterIntoTableSourceScanRule
 
toString() - Static method in class org.apache.flink.table.plan.rules.logical.PushProjectIntoTableSourceScanRule
 
toString() - Method in class org.apache.flink.table.plan.schema.ArrayRelDataType
 
toString() - Method in class org.apache.flink.table.plan.schema.CompositeRelDataType
 
toString() - Method in class org.apache.flink.table.plan.schema.GenericRelDataType
 
toString() - Method in class org.apache.flink.table.plan.schema.MapRelDataType
 
toString() - Method in class org.apache.flink.table.plan.schema.TimeIndicatorRelDataType
 
toString() - Method in class org.apache.flink.table.plan.stats.ColumnStats
 
toString() - Method in class org.apache.flink.table.runtime.triggers.StateCleaningCountTrigger
 
toString() - Method in class org.apache.flink.table.runtime.types.CRow
 
toString() - Static method in class org.apache.flink.table.runtime.types.CRowTypeInfo
 
toString() - Method in class org.apache.flink.table.typeutils.InternalTypeInfo
 
toString() - Method in class org.apache.flink.table.typeutils.RowIntervalTypeInfo
 
toString() - Method in class org.apache.flink.table.typeutils.TimeIndicatorTypeInfo
 
toString() - Method in class org.apache.flink.table.typeutils.TimeIntervalTypeInfo
 
toString() - Method in class org.apache.flink.types.BooleanValue
 
toString() - Method in class org.apache.flink.types.ByteValue
 
toString() - Method in class org.apache.flink.types.CharValue
 
toString() - Method in class org.apache.flink.types.DoubleValue
 
toString() - Method in class org.apache.flink.types.Either.Left
 
toString() - Method in class org.apache.flink.types.Either.Right
 
toString() - Method in class org.apache.flink.types.FloatValue
 
toString() - Method in class org.apache.flink.types.IntValue
 
toString() - Method in class org.apache.flink.types.ListValue
 
toString() - Method in class org.apache.flink.types.LongValue
 
toString() - Method in class org.apache.flink.types.MapValue
 
toString() - Method in class org.apache.flink.types.NullValue
 
toString() - Method in class org.apache.flink.types.Row
 
toString() - Method in class org.apache.flink.types.ShortValue
 
toString() - Method in class org.apache.flink.types.StringValue
 
toString() - Method in class org.apache.flink.util.AbstractID
 
toString() - Method in class org.apache.flink.util.OutputTag
 
toString() - Method in class org.apache.flink.util.ReflectionUtil.FullTypeInfo
 
toString() - Method in class org.apache.flink.util.SerializedValue
 
toString() - Method in class org.apache.flink.util.StringBasedID
 
toString() - Method in class org.apache.flink.yarn.messages.ContainersAllocated
 
toString() - Method in class org.apache.flink.yarn.messages.ContainersComplete
 
toString() - Method in class org.apache.flink.yarn.RegisteredYarnWorkerNode
 
toString() - Method in class org.apache.flink.yarn.YarnContainerInLaunch
 
toTable(BatchTableEnvironment, Seq<Expression>) - Method in class org.apache.flink.table.api.scala.DataSetConversions
Converts the DataSet into a Table.
toTable(StreamTableEnvironment, Seq<Expression>) - Method in class org.apache.flink.table.api.scala.DataStreamConversions
Converts the DataStream into a Table.
total2pf(Function2<S, S, BoxedUnit>) - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
total2pf(Function2<S, S, BoxedUnit>) - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
total2pf(Function2<S, S, BoxedUnit>) - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
total2pf(Function2<S, S, BoxedUnit>) - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
totalAvailable - Variable in class org.apache.flink.core.fs.AbstractMultiFSDataInputStream
Total available bytes in the virtual global stream
totalNumberOfSlots() - Method in class org.apache.flink.runtime.clusterframework.messages.GetClusterStatusResponse
 
totalNumberOfSubTasks() - Method in class org.apache.flink.runtime.messages.ExecutionGraphMessages.ExecutionStateChanged
 
totalPos - Variable in class org.apache.flink.core.fs.AbstractMultiFSDataInputStream
Position in the virtual global stream
toTime() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Parses a time string in the form "hh:mm:ss" to a SQL Time.
toTime(Expression) - Method in class org.apache.flink.table.expressions.ExpressionUtils$
 
toTime(Expression) - Static method in class org.apache.flink.table.expressions.ExpressionUtils
 
toTimestamp() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Parses a timestamp string in the form "yy-mm-dd hh:mm:ss.fff" to a SQL Timestamp.
toTypeInfo(RelDataType) - Method in class org.apache.flink.table.calcite.FlinkTypeFactory$
 
toTypeInfo(RelDataType) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
toUri() - Method in class org.apache.flink.core.fs.Path
Converts the path object to a URI.
TPCHQuery10 - Class in org.apache.flink.examples.java.relational
This program implements a modified version of the TPC-H query 10.
TPCHQuery10() - Constructor for class org.apache.flink.examples.java.relational.TPCHQuery10
 
TPCHQuery10 - Class in org.apache.flink.examples.scala.relational
This program implements a modified version of the TPC-H query 10.
TPCHQuery10() - Constructor for class org.apache.flink.examples.scala.relational.TPCHQuery10
 
TPCHQuery10$ - Class in org.apache.flink.examples.scala.relational
This program implements a modified version of the TPC-H query 10.
TPCHQuery10$() - Constructor for class org.apache.flink.examples.scala.relational.TPCHQuery10$
 
TPCHQuery3 - Class in org.apache.flink.examples.java.relational
This program implements a modified version of the TPC-H query 3.
TPCHQuery3() - Constructor for class org.apache.flink.examples.java.relational.TPCHQuery3
 
TPCHQuery3 - Class in org.apache.flink.examples.scala.relational
This program implements a modified version of the TPC-H query 3.
TPCHQuery3() - Constructor for class org.apache.flink.examples.scala.relational.TPCHQuery3
 
TPCHQuery3$ - Class in org.apache.flink.examples.scala.relational
This program implements a modified version of the TPC-H query 3.
TPCHQuery3$() - Constructor for class org.apache.flink.examples.scala.relational.TPCHQuery3$
 
TPCHQuery3.Customer - Class in org.apache.flink.examples.java.relational
 
TPCHQuery3.Customer - Class in org.apache.flink.examples.scala.relational
 
TPCHQuery3.Customer$ - Class in org.apache.flink.examples.scala.relational
 
TPCHQuery3.Lineitem - Class in org.apache.flink.examples.java.relational
 
TPCHQuery3.Lineitem - Class in org.apache.flink.examples.scala.relational
 
TPCHQuery3.Lineitem$ - Class in org.apache.flink.examples.scala.relational
 
TPCHQuery3.Order - Class in org.apache.flink.examples.java.relational
 
TPCHQuery3.Order - Class in org.apache.flink.examples.scala.relational
 
TPCHQuery3.Order$ - Class in org.apache.flink.examples.scala.relational
 
TPCHQuery3.ShippedItem - Class in org.apache.flink.examples.scala.relational
 
TPCHQuery3.ShippedItem$ - Class in org.apache.flink.examples.scala.relational
 
TPCHQuery3.ShippingPriorityItem - Class in org.apache.flink.examples.java.relational
 
TPCHQuery3Table - Class in org.apache.flink.table.examples.scala
This program implements a modified version of the TPC-H query 3.
TPCHQuery3Table() - Constructor for class org.apache.flink.table.examples.scala.TPCHQuery3Table
 
TPCHQuery3Table$ - Class in org.apache.flink.table.examples.scala
This program implements a modified version of the TPC-H query 3.
TPCHQuery3Table$() - Constructor for class org.apache.flink.table.examples.scala.TPCHQuery3Table$
 
TPCHQuery3Table.Customer - Class in org.apache.flink.table.examples.scala
 
TPCHQuery3Table.Customer$ - Class in org.apache.flink.table.examples.scala
 
TPCHQuery3Table.Lineitem - Class in org.apache.flink.table.examples.scala
 
TPCHQuery3Table.Lineitem$ - Class in org.apache.flink.table.examples.scala
 
TPCHQuery3Table.Order - Class in org.apache.flink.table.examples.scala
 
TPCHQuery3Table.Order$ - Class in org.apache.flink.table.examples.scala
 
tpe() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.ArrayDescriptor
 
tpe() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.BoxedPrimitiveDescriptor
 
tpe() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.CaseClassDescriptor
 
tpe() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.EitherDescriptor
 
tpe() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.EnumValueDescriptor
 
tpe() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.FactoryTypeDescriptor
 
tpe() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.FieldDescriptor
 
tpe() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.GenericClassDescriptor
 
tpe() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.JavaTupleDescriptor
 
tpe() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.NothingDescriptor
 
tpe() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.OptionDescriptor
 
tpe() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.PojoDescriptor
 
tpe() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.PrimitiveDescriptor
 
tpe() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.RecursiveDescriptor
 
tpe() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.TraversableDescriptor
 
tpe() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.TryDescriptor
 
tpe() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.TypeParameterDescriptor
 
tpe() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.UDTDescriptor
 
tpe() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.UnitDescriptor
 
tpe() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.UnsupportedDescriptor
 
tpe() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.ValueDescriptor
 
tpe() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.WritableDescriptor
 
tpe() - Method in class org.apache.flink.table.expressions.WindowReference
 
TRAILING() - Method in class org.apache.flink.table.expressions.TrimMode$
 
TRAILING() - Static method in class org.apache.flink.table.expressions.TrimMode
 
training() - Method in class org.apache.flink.ml.preprocessing.Splitter.TrainTestDataSet
 
training() - Method in class org.apache.flink.ml.preprocessing.Splitter.TrainTestHoldoutDataSet
 
trainingSet() - Method in class org.apache.flink.ml.nn.KNN
 
TrainTestDataSet(DataSet<T>, DataSet<T>, TypeInformation<T>, ClassTag<T>) - Constructor for class org.apache.flink.ml.preprocessing.Splitter.TrainTestDataSet
 
TrainTestDataSet$() - Constructor for class org.apache.flink.ml.preprocessing.Splitter.TrainTestDataSet$
 
TrainTestHoldoutDataSet(DataSet<T>, DataSet<T>, DataSet<T>, TypeInformation<T>, ClassTag<T>) - Constructor for class org.apache.flink.ml.preprocessing.Splitter.TrainTestHoldoutDataSet
 
TrainTestHoldoutDataSet$() - Constructor for class org.apache.flink.ml.preprocessing.Splitter.TrainTestHoldoutDataSet$
 
trainTestHoldoutSplit(DataSet<T>, Tuple3<Object, Object, Object>, long, TypeInformation<T>, ClassTag<T>) - Method in class org.apache.flink.ml.preprocessing.Splitter$
A wrapper for multiRandomSplit that yields a TrainTestHoldoutDataSet
trainTestHoldoutSplit(DataSet<T>, Tuple3<Object, Object, Object>, long, TypeInformation<T>, ClassTag<T>) - Static method in class org.apache.flink.ml.preprocessing.Splitter
A wrapper for multiRandomSplit that yields a TrainTestHoldoutDataSet
trainTestSplit(DataSet<T>, double, boolean, long, TypeInformation<T>, ClassTag<T>) - Method in class org.apache.flink.ml.preprocessing.Splitter$
A wrapper for randomSplit that yields a TrainTestDataSet
trainTestSplit(DataSet<T>, double, boolean, long, TypeInformation<T>, ClassTag<T>) - Static method in class org.apache.flink.ml.preprocessing.Splitter
A wrapper for randomSplit that yields a TrainTestDataSet
traitDefs() - Method in class org.apache.flink.table.calcite.FlinkPlannerImpl
Holds the trait definitions to be registered with planner.
transform(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
transform(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
transform(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
transform(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
transform(DataSet<Input>, ParameterMap, TransformDataSetOperation<Self, Input, Output>) - Static method in class org.apache.flink.ml.outlier.StochasticOutlierSelection
 
transform(DataSet<Input>, ParameterMap, TransformDataSetOperation<Self, Input, Output>) - Static method in class org.apache.flink.ml.pipeline.ChainedTransformer
 
transform(DataSet<Input>, ParameterMap, TransformDataSetOperation<Self, Input, Output>) - Method in interface org.apache.flink.ml.pipeline.Transformer
Transform operation which transforms an input DataSet of type I into an ouptut DataSet of type O.
transform(Input, Model) - Method in interface org.apache.flink.ml.pipeline.TransformOperation
Transforms a single element with respect to the model associated with the respective Transformer
transform(DataSet<Input>, ParameterMap, TransformDataSetOperation<Self, Input, Output>) - Static method in class org.apache.flink.ml.preprocessing.MinMaxScaler
 
transform(DataSet<Input>, ParameterMap, TransformDataSetOperation<Self, Input, Output>) - Static method in class org.apache.flink.ml.preprocessing.PolynomialFeatures
 
transform(DataSet<Input>, ParameterMap, TransformDataSetOperation<Self, Input, Output>) - Static method in class org.apache.flink.ml.preprocessing.StandardScaler
 
transform(N, T, StateTransformationFunction<S, T>) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTable
 
transform(N, T, StateTransformationFunction<S, T>) - Method in class org.apache.flink.runtime.state.heap.NestedMapsStateTable
 
transform(N, T, StateTransformationFunction<S, T>) - Method in class org.apache.flink.runtime.state.heap.StateTable
Applies the given StateTransformationFunction to the state (1st input argument), using the given value as second input argument.
transform(String, TypeInformation<R>, TwoInputStreamOperator<IN1, IN2, R>) - Method in class org.apache.flink.streaming.api.datastream.ConnectedStreams
 
transform(String, TypeInformation<R>, OneInputStreamOperator<T, R>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Method for passing user defined operators along with the type information that will transform the DataStream.
transform(String, TypeInformation<R>, OneInputStreamOperator<T, R>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
 
transform(String, TwoInputStreamOperator<IN1, IN2, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.ConnectedStreams
 
transform(String, OneInputStreamOperator<T, R>, TypeInformation<R>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Transforms the DataStream by using a custom OneInputStreamOperator.
transform$default$2() - Static method in class org.apache.flink.ml.outlier.StochasticOutlierSelection
 
transform$default$2() - Static method in class org.apache.flink.ml.pipeline.ChainedTransformer
 
transform$default$2() - Static method in class org.apache.flink.ml.preprocessing.MinMaxScaler
 
transform$default$2() - Static method in class org.apache.flink.ml.preprocessing.PolynomialFeatures
 
transform$default$2() - Static method in class org.apache.flink.ml.preprocessing.StandardScaler
 
transformation - Variable in class org.apache.flink.streaming.api.datastream.DataStream
 
transformations - Variable in class org.apache.flink.streaming.api.environment.StreamExecutionEnvironment
 
transformDataSet(Instance, ParameterMap, DataSet<Input>) - Method in interface org.apache.flink.ml.pipeline.TransformDataSetOperation
 
TransformDataSetOperation<Instance,Input,Output> - Interface in org.apache.flink.ml.pipeline
Type class for a transform operation of Transformer.
transformer() - Method in class org.apache.flink.ml.pipeline.ChainedPredictor
 
Transformer<Self extends Transformer<Self>> - Interface in org.apache.flink.ml.pipeline
Transformer trait for Flink's pipeline operators.
Transformer$ - Class in org.apache.flink.ml.pipeline
 
Transformer$() - Constructor for class org.apache.flink.ml.pipeline.Transformer$
 
transformLabeledVector() - Method in class org.apache.flink.ml.preprocessing.StandardScaler$
TransformOperation to transform LabeledVector.
transformLabeledVector() - Static method in class org.apache.flink.ml.preprocessing.StandardScaler
TransformOperation to transform LabeledVector.
transformLabeledVectorIntoPolynomialBase() - Method in class org.apache.flink.ml.preprocessing.PolynomialFeatures$
TransformDataSetOperation to map a LabeledVector into the polynomial feature space
transformLabeledVectorIntoPolynomialBase() - Static method in class org.apache.flink.ml.preprocessing.PolynomialFeatures
TransformDataSetOperation to map a LabeledVector into the polynomial feature space
transformLabeledVectors() - Method in class org.apache.flink.ml.outlier.StochasticOutlierSelection$
 
transformLabeledVectors() - Static method in class org.apache.flink.ml.outlier.StochasticOutlierSelection
 
transformLabeledVectors() - Method in class org.apache.flink.ml.preprocessing.MinMaxScaler$
 
transformLabeledVectors() - Static method in class org.apache.flink.ml.preprocessing.MinMaxScaler
 
TransformOperation<Instance,Model,Input,Output> - Interface in org.apache.flink.ml.pipeline
Type class for a transform operation which works on a single element and the corresponding model of the Transformer.
transformTupleVectorDouble(BreezeVectorConverter<T>, TypeInformation<T>, ClassTag<T>) - Method in class org.apache.flink.ml.preprocessing.StandardScaler$
TransformOperation to transform tuples of type (Vector, Double).
transformTupleVectorDouble(BreezeVectorConverter<T>, TypeInformation<T>, ClassTag<T>) - Static method in class org.apache.flink.ml.preprocessing.StandardScaler
TransformOperation to transform tuples of type (Vector, Double).
transformVectorIntoPolynomialBase(VectorBuilder<T>, TypeInformation<T>, ClassTag<T>) - Method in class org.apache.flink.ml.preprocessing.PolynomialFeatures$
TransformDataSetOperation to map a Vector into the polynomial feature space.
transformVectorIntoPolynomialBase(VectorBuilder<T>, TypeInformation<T>, ClassTag<T>) - Static method in class org.apache.flink.ml.preprocessing.PolynomialFeatures
TransformDataSetOperation to map a Vector into the polynomial feature space.
transformVectors(BreezeVectorConverter<T>, TypeInformation<T>, ClassTag<T>) - Method in class org.apache.flink.ml.outlier.StochasticOutlierSelection$
TransformDataSetOperation applies the stochastic outlier selection algorithm on a Vector which will transform the high-dimensionaly input to a single Double output.
transformVectors(BreezeVectorConverter<T>, TypeInformation<T>, ClassTag<T>) - Static method in class org.apache.flink.ml.outlier.StochasticOutlierSelection
TransformDataSetOperation applies the stochastic outlier selection algorithm on a Vector which will transform the high-dimensionaly input to a single Double output.
transformVectors(BreezeVectorConverter<T>, TypeInformation<T>, ClassTag<T>) - Method in class org.apache.flink.ml.preprocessing.MinMaxScaler$
TransformDataSetOperation which scales input data of subtype of Vector with respect to the calculated minimum and maximum of the training data.
transformVectors(BreezeVectorConverter<T>, TypeInformation<T>, ClassTag<T>) - Static method in class org.apache.flink.ml.preprocessing.MinMaxScaler
TransformDataSetOperation which scales input data of subtype of Vector with respect to the calculated minimum and maximum of the training data.
transformVectors(BreezeVectorConverter<T>, TypeInformation<T>, ClassTag<T>) - Method in class org.apache.flink.ml.preprocessing.StandardScaler$
TransformOperation to transform Vector types
transformVectors(BreezeVectorConverter<T>, TypeInformation<T>, ClassTag<T>) - Static method in class org.apache.flink.ml.preprocessing.StandardScaler
TransformOperation to transform Vector types
TransitiveClosureData - Class in org.apache.flink.test.testdata
 
TransitiveClosureNaive - Class in org.apache.flink.examples.java.graph
 
TransitiveClosureNaive() - Constructor for class org.apache.flink.examples.java.graph.TransitiveClosureNaive
 
TransitiveClosureNaive - Class in org.apache.flink.examples.scala.graph
 
TransitiveClosureNaive() - Constructor for class org.apache.flink.examples.scala.graph.TransitiveClosureNaive
 
TransitiveClosureNaive$ - Class in org.apache.flink.examples.scala.graph
 
TransitiveClosureNaive$() - Constructor for class org.apache.flink.examples.scala.graph.TransitiveClosureNaive$
 
TRANSLATE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The TRANSLATE(char_value USING translation_name) function alters the character set of a string value from one base character set to another.
translate(IN, OUT) - Method in class org.apache.flink.graph.asm.translate.RichTranslateFunction
 
Translate - Class in org.apache.flink.graph.asm.translate
Methods for translation of the type or modification of the data of graph IDs, vertex values, and edge values.
Translate() - Constructor for class org.apache.flink.graph.asm.translate.Translate
 
translate(T, O) - Method in interface org.apache.flink.graph.asm.translate.TranslateFunction
The translating method.
translate(Long, LongValue) - Method in class org.apache.flink.graph.asm.translate.translators.LongToLongValue
 
translate(LongValue, LongValue) - Method in class org.apache.flink.graph.asm.translate.translators.LongValueAddOffset
 
translate(LongValue, IntValue) - Method in class org.apache.flink.graph.asm.translate.translators.LongValueToSignedIntValue
 
translate(LongValue, StringValue) - Method in class org.apache.flink.graph.asm.translate.translators.LongValueToStringValue
 
translate(LongValue, IntValue) - Method in class org.apache.flink.graph.asm.translate.translators.LongValueToUnsignedIntValue
 
translate(T, NullValue) - Method in class org.apache.flink.graph.asm.translate.translators.ToNullValue
 
translate(I, O) - Method in class org.apache.flink.graph.utils.GraphUtils.MapTo
 
translate(Table, TypeInformation<A>) - Method in class org.apache.flink.table.api.BatchTableEnvironment
Translates a Table into a DataSet.
translate(RelNode, RelDataType, TypeInformation<A>) - Method in class org.apache.flink.table.api.BatchTableEnvironment
Translates a logical RelNode into a DataSet.
translate(Table, StreamQueryConfig, boolean, boolean, TypeInformation<A>) - Method in class org.apache.flink.table.api.StreamTableEnvironment
Translates a Table into a DataStream.
translate(RelNode, RelDataType, StreamQueryConfig, boolean, TypeInformation<A>) - Method in class org.apache.flink.table.api.StreamTableEnvironment
Translates a logical RelNode into a DataStream.
translateEdgeIds(DataSet<Edge<OLD, EV>>, TranslateFunction<OLD, NEW>) - Static method in class org.apache.flink.graph.asm.translate.Translate
Translate Edge IDs using the given TranslateFunction.
translateEdgeIds(DataSet<Edge<OLD, EV>>, TranslateFunction<OLD, NEW>, int) - Static method in class org.apache.flink.graph.asm.translate.Translate
Translate Edge IDs using the given TranslateFunction.
translateEdgeValues(DataSet<Edge<K, OLD>>, TranslateFunction<OLD, NEW>) - Static method in class org.apache.flink.graph.asm.translate.Translate
Translate Edge values using the given TranslateFunction.
translateEdgeValues(DataSet<Edge<K, OLD>>, TranslateFunction<OLD, NEW>, int) - Static method in class org.apache.flink.graph.asm.translate.Translate
Translate Edge values using the given TranslateFunction.
TranslateEdgeValues<K,VV,OLD,NEW> - Class in org.apache.flink.graph.asm.translate
Translate Edge values using the given TranslateFunction.
TranslateEdgeValues(TranslateFunction<OLD, NEW>) - Constructor for class org.apache.flink.graph.asm.translate.TranslateEdgeValues
Translate Edge values using the given TranslateFunction.
translateEdgeValues(TranslateFunction<EV, NEW>) - Method in class org.apache.flink.graph.Graph
Translate Edge values using the given MapFunction.
translateEdgeValues(TranslateFunction<EV, NEW>, TypeInformation<NEW>, ClassTag<NEW>) - Method in class org.apache.flink.graph.scala.Graph
Translate edge values using the given MapFunction.
translateEdgeValues(Function2<EV, NEW, NEW>, TypeInformation<NEW>, ClassTag<NEW>) - Method in class org.apache.flink.graph.scala.Graph
Translate edge values using the given function.
TranslateFunction<T,O> - Interface in org.apache.flink.graph.asm.translate
Base interface for Translate functions.
TranslateGraphIds<OLD,NEW,VV,EV> - Class in org.apache.flink.graph.asm.translate
Translate Vertex and Edge IDs of a Graph using the given TranslateFunction
TranslateGraphIds(TranslateFunction<OLD, NEW>) - Constructor for class org.apache.flink.graph.asm.translate.TranslateGraphIds
Translate Vertex and Edge IDs of a Graph using the given TranslateFunction
translateGraphIds(TranslateFunction<K, NEW>) - Method in class org.apache.flink.graph.Graph
Translate Vertex and Edge IDs using the given MapFunction.
translateGraphIds(TranslateFunction<K, NEW>, TypeInformation<NEW>, ClassTag<NEW>) - Method in class org.apache.flink.graph.scala.Graph
Translate vertex and edge IDs using the given MapFunction.
translateGraphIds(Function2<K, NEW, NEW>, TypeInformation<NEW>, ClassTag<NEW>) - Method in class org.apache.flink.graph.scala.Graph
Translate vertex and edge IDs using the given function.
translateToCRow(RelNode, StreamQueryConfig) - Method in class org.apache.flink.table.api.StreamTableEnvironment
Translates a logical RelNode plan into a DataStream of type CRow.
translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.AggregateOperator
 
translateToDataFlow(Operator<I1>, Operator<I2>) - Method in class org.apache.flink.api.java.operators.CoGroupOperator
 
translateToDataFlow(Operator<I1>, Operator<I2>) - Method in class org.apache.flink.api.java.operators.CoGroupRawOperator
 
translateToDataFlow(Operator<I1>, Operator<I2>) - Method in class org.apache.flink.api.java.operators.CrossOperator
 
translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.operators.DataSink
 
translateToDataFlow() - Method in class org.apache.flink.api.java.operators.DataSource
 
translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.operators.DistinctOperator
 
translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.operators.FilterOperator
 
translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.FlatMapOperator
 
translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.GroupCombineOperator
 
translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.GroupReduceOperator
 
translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.operators.IterativeDataSet
 
translateToDataFlow(Operator<I1>, Operator<I2>) - Method in class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
 
translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.MapOperator
 
translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.MapPartitionOperator
 
translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.operators.PartitionOperator
 
translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.ProjectOperator
 
translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.ReduceOperator
 
translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.java.operators.SingleInputOperator
Translates this operation to a data flow operator of the common data flow API.
translateToDataFlow(Operator<T>) - Method in class org.apache.flink.api.java.operators.SortPartitionOperator
 
translateToDataFlow(Operator<IN1>, Operator<IN2>) - Method in class org.apache.flink.api.java.operators.TwoInputOperator
Translates this java API operator into a common API operator with two inputs.
translateToDataFlow(Operator<T>, Operator<T>) - Method in class org.apache.flink.api.java.operators.UnionOperator
Returns the BinaryNodeTranslation of the Union.
translateToDataFlow(Operator<IN>) - Method in class org.apache.flink.api.scala.operators.ScalaAggregateOperator
 
translateToPlan(List<DataSink<?>>, String) - Method in class org.apache.flink.api.java.operators.OperatorTranslation
 
translateToPlan(BatchTableEnvironment) - Method in class org.apache.flink.table.plan.nodes.dataset.BatchTableSourceScan
 
translateToPlan(BatchTableEnvironment) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetAggregate
 
translateToPlan(BatchTableEnvironment) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetCalc
 
translateToPlan(BatchTableEnvironment) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetCorrelate
 
translateToPlan(BatchTableEnvironment) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetDistinct
 
translateToPlan(BatchTableEnvironment) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetIntersect
 
translateToPlan(BatchTableEnvironment) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetJoin
 
translateToPlan(BatchTableEnvironment) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetMinus
 
translateToPlan(BatchTableEnvironment) - Method in interface org.apache.flink.table.plan.nodes.dataset.DataSetRel
Translates the DataSetRel node into a DataSet operator.
translateToPlan(BatchTableEnvironment) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetScan
 
translateToPlan(BatchTableEnvironment) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetSingleRowJoin
 
translateToPlan(BatchTableEnvironment) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetSort
 
translateToPlan(BatchTableEnvironment) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetUnion
 
translateToPlan(BatchTableEnvironment) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetValues
 
translateToPlan(BatchTableEnvironment) - Method in class org.apache.flink.table.plan.nodes.dataset.DataSetWindowAggregate
 
translateToPlan(StreamTableEnvironment, StreamQueryConfig) - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamCalc
 
translateToPlan(StreamTableEnvironment, StreamQueryConfig) - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamCorrelate
 
translateToPlan(StreamTableEnvironment, StreamQueryConfig) - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupAggregate
 
translateToPlan(StreamTableEnvironment, StreamQueryConfig) - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamGroupWindowAggregate
 
translateToPlan(StreamTableEnvironment, StreamQueryConfig) - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamOverAggregate
 
translateToPlan(StreamTableEnvironment, StreamQueryConfig) - Method in interface org.apache.flink.table.plan.nodes.datastream.DataStreamRel
Translates the FlinkRelNode into a Flink operator.
translateToPlan(StreamTableEnvironment, StreamQueryConfig) - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamScan
 
translateToPlan(StreamTableEnvironment, StreamQueryConfig) - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamUnion
 
translateToPlan(StreamTableEnvironment, StreamQueryConfig) - Method in class org.apache.flink.table.plan.nodes.datastream.DataStreamValues
 
translateToPlan(StreamTableEnvironment, StreamQueryConfig) - Method in class org.apache.flink.table.plan.nodes.datastream.StreamTableSourceScan
 
translateVertexIds(DataSet<Vertex<OLD, VV>>, TranslateFunction<OLD, NEW>) - Static method in class org.apache.flink.graph.asm.translate.Translate
Translate Vertex IDs using the given TranslateFunction.
translateVertexIds(DataSet<Vertex<OLD, VV>>, TranslateFunction<OLD, NEW>, int) - Static method in class org.apache.flink.graph.asm.translate.Translate
Translate Vertex IDs using the given TranslateFunction.
translateVertexValues(DataSet<Vertex<K, OLD>>, TranslateFunction<OLD, NEW>) - Static method in class org.apache.flink.graph.asm.translate.Translate
Translate Vertex values using the given TranslateFunction.
translateVertexValues(DataSet<Vertex<K, OLD>>, TranslateFunction<OLD, NEW>, int) - Static method in class org.apache.flink.graph.asm.translate.Translate
Translate Vertex values using the given TranslateFunction.
TranslateVertexValues<K,OLD,NEW,EV> - Class in org.apache.flink.graph.asm.translate
Translate Vertex values using the given TranslateFunction.
TranslateVertexValues(TranslateFunction<OLD, NEW>) - Constructor for class org.apache.flink.graph.asm.translate.TranslateVertexValues
Translate Vertex values using the given TranslateFunction.
translateVertexValues(TranslateFunction<VV, NEW>) - Method in class org.apache.flink.graph.Graph
Translate Vertex values using the given MapFunction.
translateVertexValues(TranslateFunction<VV, NEW>, TypeInformation<NEW>, ClassTag<NEW>) - Method in class org.apache.flink.graph.scala.Graph
Translate vertex values using the given MapFunction.
translateVertexValues(Function2<VV, NEW, NEW>, TypeInformation<NEW>, ClassTag<NEW>) - Method in class org.apache.flink.graph.scala.Graph
Translate vertex values using the given function.
translateWindowExpression(RexCall, RelDataType) - Method in class org.apache.flink.table.plan.rules.common.LogicalWindowAggregateRule
translate the group window expression in to a Flink Table window.
translateWindowExpression(RexCall, RelDataType) - Method in class org.apache.flink.table.plan.rules.dataSet.DataSetLogicalWindowAggregateRule
 
translateWindowExpression(RexCall, RelDataType) - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamLogicalWindowAggregateRule
 
TRANSPORT_TYPE - Static variable in class org.apache.flink.runtime.io.network.netty.NettyConfig
 
TransportException - Exception in org.apache.flink.runtime.io.network.netty.exception
 
TransportException(String, SocketAddress) - Constructor for exception org.apache.flink.runtime.io.network.netty.exception.TransportException
 
TransportException(String, SocketAddress, Throwable) - Constructor for exception org.apache.flink.runtime.io.network.netty.exception.TransportException
 
TraversableDescriptor(int, scala.reflect.macros.Context.universe, TypeDescriptors<C>.UDTDescriptor) - Constructor for class org.apache.flink.api.scala.codegen.TypeDescriptors.TraversableDescriptor
 
TraversableOnceException - Exception in org.apache.flink.util
An exception, indicating that an Iterable can only be traversed once, but has been attempted to traverse an additional time.
TraversableOnceException() - Constructor for exception org.apache.flink.util.TraversableOnceException
Creates a new exception with a default message.
TraversableSerializer<T extends scala.collection.TraversableOnce<E>,E> - Class in org.apache.flink.api.scala.typeutils
Serializer for Scala Collections.
TraversableSerializer(TypeSerializer<E>) - Constructor for class org.apache.flink.api.scala.typeutils.TraversableSerializer
 
TraversableSerializerConfigSnapshot<E> - Class in org.apache.flink.api.scala.typeutils
TraversableSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.scala.typeutils.TraversableSerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
TraversableSerializerConfigSnapshot(TypeSerializer<E>) - Constructor for class org.apache.flink.api.scala.typeutils.TraversableSerializerConfigSnapshot
 
TraversableTypeInfo<T extends scala.collection.TraversableOnce<E>,E> - Class in org.apache.flink.api.scala.typeutils
TypeInformation for Scala Collections.
TraversableTypeInfo(Class<T>, TypeInformation<E>) - Constructor for class org.apache.flink.api.scala.typeutils.TraversableTypeInfo
 
traverse(PlanNode, T, boolean) - Method in class org.apache.flink.optimizer.postpass.GenericFlatTypePostPass
 
traverse(PlanNode) - Method in class org.apache.flink.optimizer.postpass.JavaApiPostPass
 
traverseAllPanes(KeyMap.TraversalEvaluator<Key, Aggregate>, long) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
 
traverseMaps(KeyMap<K, V>[], KeyMap.TraversalEvaluator<K, V>, long) - Static method in class org.apache.flink.streaming.runtime.operators.windowing.KeyMap
Performs a traversal about logical the multi-map that results from the union of the given maps.
traverseStreamGraphAndGenerateHashes(StreamGraph) - Method in class org.apache.flink.migration.streaming.api.graph.StreamGraphHasherV1
 
traverseStreamGraphAndGenerateHashes(StreamGraph) - Method in interface org.apache.flink.streaming.api.graph.StreamGraphHasher
Returns a map with a hash for each StreamNode of the StreamGraph.
traverseStreamGraphAndGenerateHashes(StreamGraph) - Method in class org.apache.flink.streaming.api.graph.StreamGraphHasherV2
Returns a map with a hash for each StreamNode of the StreamGraph.
traverseStreamGraphAndGenerateHashes(StreamGraph) - Method in class org.apache.flink.streaming.api.graph.StreamGraphUserHashHasher
 
tree2Ops(T) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
TreeGen<C extends scala.reflect.macros.Context> - Interface in org.apache.flink.api.scala.codegen
 
TreeNode<A extends TreeNode<A>> - Class in org.apache.flink.table.plan
Generic base class for trees that can be transformed and traversed.
TreeNode() - Constructor for class org.apache.flink.table.plan.TreeNode
 
TRG_EDGE_TO_BE_REMOVED - Static variable in class org.apache.flink.graph.examples.data.IncrementalSSSPData
 
Triad() - Constructor for class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Triad
 
Triad(int, int, int) - Constructor for class org.apache.flink.examples.scala.graph.EnumTriangles.Triad
 
Triad() - Constructor for class org.apache.flink.graph.library.TriangleEnumerator.Triad
 
Triad$() - Constructor for class org.apache.flink.examples.scala.graph.EnumTriangles.Triad$
 
TriadBuilder() - Constructor for class org.apache.flink.examples.scala.graph.EnumTriangles.TriadBuilder
 
TriadicCensus<K extends Comparable<K> & CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.clustering.directed
A triad is formed by three connected or unconnected vertices in a graph.
TriadicCensus() - Constructor for class org.apache.flink.graph.library.clustering.directed.TriadicCensus
 
TriadicCensus<K extends Comparable<K> & CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.clustering.undirected
A triad is formed by three connected or unconnected vertices in a graph.
TriadicCensus() - Constructor for class org.apache.flink.graph.library.clustering.undirected.TriadicCensus
 
TriadicCensus.Result - Class in org.apache.flink.graph.library.clustering.directed
Wraps triadic census metrics.
TriadicCensus.Result - Class in org.apache.flink.graph.library.clustering.undirected
Wraps triadic census metrics.
TriangleCountData - Class in org.apache.flink.graph.examples.data
Provides the default data sets used for the Triangle Count test program.
TriangleEnumerator<K extends Comparable<K>,VV,EV> - Class in org.apache.flink.graph.library
This library method enumerates unique triangles present in the input graph.
TriangleEnumerator() - Constructor for class org.apache.flink.graph.library.TriangleEnumerator
 
TriangleEnumerator.EdgeWithDegrees<K> - Class in org.apache.flink.graph.library
 
TriangleEnumerator.Triad<K> - Class in org.apache.flink.graph.library
 
TriangleListing<K extends Comparable<K> & CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.drivers
Driver for directed and undirected triangle listing algorithm and analytic.
TriangleListing() - Constructor for class org.apache.flink.graph.drivers.TriangleListing
 
TriangleListing<K extends Comparable<K> & CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.clustering.directed
Generates a listing of distinct triangles from the input graph.
TriangleListing() - Constructor for class org.apache.flink.graph.library.clustering.directed.TriangleListing
 
TriangleListing<K extends Comparable<K> & CopyableValue<K>,VV,EV> - Class in org.apache.flink.graph.library.clustering.undirected
Generates a listing of distinct triangles from the input graph.
TriangleListing() - Constructor for class org.apache.flink.graph.library.clustering.undirected.TriangleListing
 
TriangleListing.Result<T> - Class in org.apache.flink.graph.library.clustering.directed
Wraps Tuple4 to encapsulate results from the directed Triangle Listing algorithm.
TriangleListing.Result<T> - Class in org.apache.flink.graph.library.clustering.undirected
Wraps Tuple3 to encapsulate results from the undirected Triangle Listing algorithm.
TRIANGLES_BY_DEGREE - Static variable in class org.apache.flink.test.testdata.EnumTriangleData
 
TRIANGLES_BY_ID - Static variable in class org.apache.flink.test.testdata.EnumTriangleData
 
trigger() - Method in class org.apache.flink.core.testutils.ManuallyTriggeredDirectExecutor
Triggers the next queued runnable and executes it synchronously.
trigger() - Method in class org.apache.flink.core.testutils.MultiShotLatch
Fires the latch.
trigger() - Method in class org.apache.flink.core.testutils.OneShotLatch
Fires the latch.
trigger(Trigger<? super T, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.AllWindowedStream
Sets the Trigger that should be used to trigger window emission.
trigger(Trigger<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
Sets the Trigger that should be used to trigger window emission.
trigger(Trigger<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
Sets the Trigger that should be used to trigger window emission.
trigger(Trigger<? super T, ? super W>) - Method in class org.apache.flink.streaming.api.datastream.WindowedStream
Sets the Trigger that should be used to trigger window emission.
trigger(Trigger<? super T, ? super W>) - Method in class org.apache.flink.streaming.api.scala.AllWindowedStream
Sets the Trigger that should be used to trigger window emission.
trigger(Trigger<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>) - Method in class org.apache.flink.streaming.api.scala.CoGroupedStreams.Where.EqualTo.WithWindow
Sets the Trigger that should be used to trigger window emission.
trigger(Trigger<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>) - Method in class org.apache.flink.streaming.api.scala.JoinedStreams.Where.EqualTo.WithWindow
Sets the Trigger that should be used to trigger window emission.
trigger(Trigger<? super T, ? super W>) - Method in class org.apache.flink.streaming.api.scala.WindowedStream
Sets the Trigger that should be used to trigger window emission.
Trigger<T,W extends Window> - Class in org.apache.flink.streaming.api.windowing.triggers
A Trigger determines when a pane of a window should be evaluated to emit the results for that part of the window.
Trigger() - Constructor for class org.apache.flink.streaming.api.windowing.triggers.Trigger
 
Trigger.OnMergeContext - Interface in org.apache.flink.streaming.api.windowing.triggers
Trigger.TriggerContext - Interface in org.apache.flink.streaming.api.windowing.triggers
A context object that is given to Trigger methods to allow them to register timer callbacks and deal with state.
TRIGGER_THREAD_GROUP - Static variable in class org.apache.flink.streaming.runtime.tasks.StreamTask
The thread group that holds all trigger timer threads.
Triggerable<K,N> - Interface in org.apache.flink.streaming.api.operators
Interface for things that can be called by InternalTimerService.
TriggerApplicationClientRegistration(String, FiniteDuration, Option<Deadline>) - Constructor for class org.apache.flink.yarn.YarnMessages.TriggerApplicationClientRegistration
 
TriggerApplicationClientRegistration$() - Constructor for class org.apache.flink.yarn.YarnMessages.TriggerApplicationClientRegistration$
 
triggerCheckpoint(long, boolean) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Triggers a new standard checkpoint and uses the given timestamp as the checkpoint timestamp.
triggerCheckpoint(long, CheckpointOptions) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Test method to trigger a checkpoint/savepoint.
triggerCheckpoint(long, long, Executor) - Method in interface org.apache.flink.runtime.checkpoint.MasterTriggerRestoreHook
This method is called by the checkpoint coordinator prior when triggering a checkpoint, prior to sending the "trigger checkpoint" messages to the source tasks.
triggerCheckpoint(long, long, CheckpointOptions) - Method in class org.apache.flink.runtime.executiongraph.Execution
Trigger a new checkpoint on the task of this execution.
triggerCheckpoint(CheckpointMetaData, CheckpointOptions) - Method in interface org.apache.flink.runtime.jobgraph.tasks.StatefulTask
This method is called to trigger a checkpoint, asynchronously by the checkpoint coordinator.
triggerCheckpoint(ExecutionAttemptID, JobID, long, long, CheckpointOptions) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
triggerCheckpoint(ExecutionAttemptID, JobID, long, long, CheckpointOptions) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Trigger for the given task a checkpoint.
triggerCheckpoint(ExecutionAttemptID, JobID, long, long, CheckpointOptions) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
TriggerCheckpoint - Class in org.apache.flink.runtime.messages.checkpoint
This message is sent from the JobManager to the TaskManager to tell a certain task to trigger its checkpoint.
TriggerCheckpoint(JobID, ExecutionAttemptID, long, long, CheckpointOptions) - Constructor for class org.apache.flink.runtime.messages.checkpoint.TriggerCheckpoint
 
triggerCheckpoint(ExecutionAttemptID, long, long, CheckpointOptions) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
triggerCheckpoint(ExecutionAttemptID, long, long, CheckpointOptions) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Trigger the checkpoint for the given task.
triggerCheckpoint(long) - Method in interface org.apache.flink.streaming.api.checkpoint.ExternallyInducedSource.CheckpointTrigger
Triggers a checkpoint.
triggerCheckpoint(CheckpointMetaData, CheckpointOptions) - Method in class org.apache.flink.streaming.runtime.tasks.SourceStreamTask
 
triggerCheckpoint(CheckpointMetaData, CheckpointOptions) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
triggerCheckpointBarrier(long, long, CheckpointOptions) - Method in class org.apache.flink.runtime.taskmanager.Task
Calls the invokable to trigger a checkpoint, if the invokable implements the interface StatefulTask.
triggerCheckpointOnBarrier(CheckpointMetaData, CheckpointOptions, CheckpointMetrics) - Method in interface org.apache.flink.runtime.jobgraph.tasks.StatefulTask
This method is called when a checkpoint is triggered as a result of receiving checkpoint barriers on all input streams.
triggerCheckpointOnBarrier(CheckpointMetaData, CheckpointOptions, CheckpointMetrics) - Method in class org.apache.flink.streaming.runtime.tasks.StreamTask
 
triggerCheckWorkers() - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
This method causes the resource framework master to asynchronouslyre-examine the set of available and pending workers containers, and release or allocate containers if needed.
triggerConnectingToJobManager(String) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Causes the resource manager to announce itself at the new leader JobManager and obtains its connection information and currently known TaskManagers.
triggerConnectingToJobManager(String) - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
 
triggerContext - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
triggerFullRecovery() - Method in class org.apache.flink.runtime.executiongraph.restart.ExecutionGraphRestartCallback
 
triggerFullRecovery() - Method in interface org.apache.flink.runtime.executiongraph.restart.RestartCallback
Triggers a full recovery in the target ExecutionGraph.
triggerMasterHooks(Collection<MasterTriggerRestoreHook<?>>, long, long, Executor, Time) - Static method in class org.apache.flink.runtime.checkpoint.hooks.MasterHooks
Triggers all given master hooks and returns state objects for each hook that produced a state.
triggerMeters() - Method in class org.apache.flink.streaming.scala.examples.windowing.TopSpeedWindowing$
 
triggerMeters() - Static method in class org.apache.flink.streaming.scala.examples.windowing.TopSpeedWindowing
 
triggerNextSuperstep() - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepKickoffLatch
 
triggerPartitionProducerStateCheck(JobID, IntermediateDataSetID, ResultPartitionID) - Method in class org.apache.flink.runtime.taskmanager.Task
 
triggerPartitionProducerStateCheck(JobID, IntermediateDataSetID, ResultPartitionID) - Method in interface org.apache.flink.runtime.taskmanager.TaskActions
Check the execution state of the execution producing a result partition.
TriggerRegistrationAtJobManager - Class in org.apache.flink.runtime.clusterframework.messages
Causes the resource manager to try and apply at the leader JobManager.
TriggerRegistrationAtJobManager(ActorRef) - Constructor for class org.apache.flink.runtime.clusterframework.messages.TriggerRegistrationAtJobManager
 
TriggerRegistrationAtJobManager(String) - Constructor for class org.apache.flink.runtime.clusterframework.messages.TriggerRegistrationAtJobManager
 
triggerResourceManagerReconnectInterval() - Method in class org.apache.flink.runtime.jobmanager.JobManager
 
TriggerResult - Enum in org.apache.flink.streaming.api.windowing.triggers
Result type for trigger methods.
triggerSavepoint(long, String) - Method in class org.apache.flink.runtime.checkpoint.CheckpointCoordinator
Triggers a savepoint with the given savepoint directory as a target.
TriggerSavepoint(JobID, Option<String>) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.TriggerSavepoint
 
TriggerSavepoint$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.TriggerSavepoint$
 
TriggerSavepointFailure(JobID, Throwable) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.TriggerSavepointFailure
 
TriggerSavepointFailure$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.TriggerSavepointFailure$
 
TriggerSavepointSuccess(JobID, long, String, long) - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.TriggerSavepointSuccess
 
TriggerSavepointSuccess$() - Constructor for class org.apache.flink.runtime.messages.JobManagerMessages.TriggerSavepointSuccess$
 
TriggerStackTraceSample(int, ExecutionAttemptID, int, Time, int) - Constructor for class org.apache.flink.runtime.messages.StackTraceSampleMessages.TriggerStackTraceSample
 
triggerStackTraceSample(ExecutionJobVertex) - Method in class org.apache.flink.runtime.webmonitor.BackPressureStatsTracker
Triggers a stack trace sample for a operator to gather the back pressure statistics.
triggerStackTraceSample(ExecutionVertex[], int, Time, int) - Method in class org.apache.flink.runtime.webmonitor.StackTraceSampleCoordinator
Triggers a stack trace sample to all tasks.
TriggerStackTraceSample$() - Constructor for class org.apache.flink.runtime.messages.StackTraceSampleMessages.TriggerStackTraceSample$
 
triggerTaskManagerRegistration() - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
TriggerTaskManagerRegistration(String, FiniteDuration, Option<Deadline>, int, UUID) - Constructor for class org.apache.flink.runtime.messages.RegistrationMessages.TriggerTaskManagerRegistration
 
triggerTaskManagerRegistration() - Method in class org.apache.flink.runtime.taskmanager.TaskManager
Starts the TaskManager's registration process to connect to the JobManager.
triggerTaskManagerRegistration() - Static method in class org.apache.flink.yarn.YarnTaskManager
 
TriggerTaskManagerRegistration$() - Constructor for class org.apache.flink.runtime.messages.RegistrationMessages.TriggerTaskManagerRegistration$
 
triggerTime() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.TriggerSavepointSuccess
 
TRIM - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The "TRIM" function.
trim(boolean, boolean, Expression) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Removes leading and/or trailing characters from the given string.
TRIM() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
TRIM() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
Trim - Class in org.apache.flink.table.expressions
Trim trimString from str according to trimMode.
Trim(Expression, Expression, Expression) - Constructor for class org.apache.flink.table.expressions.Trim
 
Trim$ - Class in org.apache.flink.table.expressions
 
Trim$() - Constructor for class org.apache.flink.table.expressions.Trim$
 
TRIM_DEFAULT_CHAR() - Method in class org.apache.flink.table.expressions.TrimConstants$
 
TRIM_DEFAULT_CHAR() - Static method in class org.apache.flink.table.expressions.TrimConstants
 
TrimCallGen - Class in org.apache.flink.table.codegen.calls
Generates a TRIM function call.
TrimCallGen() - Constructor for class org.apache.flink.table.codegen.calls.TrimCallGen
 
TrimConstants - Class in org.apache.flink.table.expressions
Enumeration of trim flags.
TrimConstants() - Constructor for class org.apache.flink.table.expressions.TrimConstants
 
TrimConstants$ - Class in org.apache.flink.table.expressions
Enumeration of trim flags.
TrimConstants$() - Constructor for class org.apache.flink.table.expressions.TrimConstants$
 
trimMode() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
trimMode() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
trimMode() - Method in class org.apache.flink.table.expressions.Trim
 
TrimMode - Class in org.apache.flink.table.expressions
Modes for trimming strings.
TrimMode() - Constructor for class org.apache.flink.table.expressions.TrimMode
 
TrimMode$ - Class in org.apache.flink.table.expressions
Modes for trimming strings.
TrimMode$() - Constructor for class org.apache.flink.table.expressions.TrimMode$
 
trimString() - Method in class org.apache.flink.table.expressions.Trim
 
trimUnusedFields(boolean, RelNode) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter
Walks over a tree of relational expressions, replacing each RelNode with a 'slimmed down' relational expression that projects only the fields required by its consumer.
Triplet<K,VV,EV> - Class in org.apache.flink.graph
A Triplet stores and retrieves the edges along with their corresponding source and target vertices.
Triplet() - Constructor for class org.apache.flink.graph.Triplet
 
Triplet(Vertex<K, VV>, Vertex<K, VV>, Edge<K, EV>) - Constructor for class org.apache.flink.graph.Triplet
Constructs a Triplet from a given source vertex, target vertex and edge
Triplet(K, K, VV, VV, EV) - Constructor for class org.apache.flink.graph.Triplet
Constructs a Triplet from its src vertex id, src target id, src vertex value, src target value and edge value respectively.
TRUE() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
TRUE() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
TRUE - Static variable in class org.apache.flink.types.BooleanValue
 
trueFunction() - Static method in class org.apache.flink.cep.pattern.conditions.BooleanConditions
 
TRUNCATE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
truncatePanes(int) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
 
tryCleanupOnError() - Method in interface org.apache.flink.api.common.io.CleanupWhenUnsuccessful
Hook that is called upon an unsuccessful execution.
tryCleanupOnError() - Method in class org.apache.flink.api.common.io.FileOutputFormat
 
TryDescriptor(int, scala.reflect.macros.Context.universe, TypeDescriptors<C>.UDTDescriptor) - Constructor for class org.apache.flink.api.scala.codegen.TypeDescriptors.TryDescriptor
 
tryPut(StreamElementQueueEntry<T>) - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
 
tryPut(StreamElementQueueEntry<T>) - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
Try to put the given element in the queue.
tryPut(StreamElementQueueEntry<T>) - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
 
tryReadSerializer(DataInputView, ClassLoader) - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
Reads from a data input view a TypeSerializer that was previously written using TypeSerializerSerializationUtil.writeSerializer(DataOutputView, TypeSerializer).
tryReadSerializer(DataInputView, ClassLoader, boolean) - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
Reads from a data input view a TypeSerializer that was previously written using TypeSerializerSerializationUtil.writeSerializer(DataOutputView, TypeSerializer).
tryRethrowIOException(Throwable) - Static method in class org.apache.flink.util.ExceptionUtils
Tries to throw the given Throwable in scenarios where the signatures allows only IOExceptions (and RuntimeException and Error).
TrySerializer<A> - Class in org.apache.flink.api.scala.typeutils
Serializer for Try.
TrySerializer(TypeSerializer<A>, ExecutionConfig) - Constructor for class org.apache.flink.api.scala.typeutils.TrySerializer
 
TrySerializer$ - Class in org.apache.flink.api.scala.typeutils
 
TrySerializer$() - Constructor for class org.apache.flink.api.scala.typeutils.TrySerializer$
 
TrySerializer.TrySerializerConfigSnapshot<A> - Class in org.apache.flink.api.scala.typeutils
We need to keep this to be compatible with snapshots taken in Flink 1.3.0.
TrySerializer.TrySerializerConfigSnapshot$ - Class in org.apache.flink.api.scala.typeutils
 
TrySerializerConfigSnapshot() - Constructor for class org.apache.flink.api.scala.typeutils.TrySerializer.TrySerializerConfigSnapshot
 
TrySerializerConfigSnapshot$() - Constructor for class org.apache.flink.api.scala.typeutils.TrySerializer.TrySerializerConfigSnapshot$
 
trySetCount(ZooKeeperVersionedValue<Integer>, int) - Method in class org.apache.flink.runtime.zookeeper.ZooKeeperSharedCount
 
TryTypeInfo<A,T extends scala.util.Try<A>> - Class in org.apache.flink.api.scala.typeutils
TypeInformation for Try.
TryTypeInfo(TypeInformation<A>) - Constructor for class org.apache.flink.api.scala.typeutils.TryTypeInfo
 
TUMBLE - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The TUMBLE group function.
Tumble - Class in org.apache.flink.table.api.java
Helper class for creating a tumbling window.
Tumble() - Constructor for class org.apache.flink.table.api.java.Tumble
 
Tumble - Class in org.apache.flink.table.api.scala
Helper object for creating a tumbling window.
Tumble() - Constructor for class org.apache.flink.table.api.scala.Tumble
 
Tumble$ - Class in org.apache.flink.table.api.java
Helper class for creating a tumbling window.
Tumble$() - Constructor for class org.apache.flink.table.api.java.Tumble$
 
Tumble$ - Class in org.apache.flink.table.api.scala
Helper object for creating a tumbling window.
Tumble$() - Constructor for class org.apache.flink.table.api.scala.Tumble$
 
TUMBLE_END - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The TUMBLE_END auxiliary function of the TUMBLE group function.
TUMBLE_START - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The TUMBLE_START auxiliary function of the TUMBLE group function.
TumbleWithSize - Class in org.apache.flink.table.api
Tumbling window.
TumbleWithSize(Expression) - Constructor for class org.apache.flink.table.api.TumbleWithSize
 
TumbleWithSize(String) - Constructor for class org.apache.flink.table.api.TumbleWithSize
Tumbling window.
TumbleWithSizeOnTime - Class in org.apache.flink.table.api
Tumbling window on time.
TumbleWithSizeOnTime(Expression, Expression) - Constructor for class org.apache.flink.table.api.TumbleWithSizeOnTime
 
TumbleWithSizeOnTimeWithAlias - Class in org.apache.flink.table.api
Tumbling window on time with alias.
TumbleWithSizeOnTimeWithAlias(Expression, Expression, Expression) - Constructor for class org.apache.flink.table.api.TumbleWithSizeOnTimeWithAlias
 
TumblingAlignedProcessingTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
This is a special window assigner used to tell the system to use the "Fast Aligned Processing Time Window Operator" for windowing.
TumblingAlignedProcessingTimeWindows(long) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.TumblingAlignedProcessingTimeWindows
 
TumblingEventTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
A WindowAssigner that windows elements into windows based on the timestamp of the elements.
TumblingEventTimeWindows(long, long) - Constructor for class org.apache.flink.streaming.api.windowing.assigners.TumblingEventTimeWindows
 
TumblingGroupWindow - Class in org.apache.flink.table.plan.logical
 
TumblingGroupWindow(Expression, Expression, Expression) - Constructor for class org.apache.flink.table.plan.logical.TumblingGroupWindow
 
TumblingGroupWindow$ - Class in org.apache.flink.table.plan.logical
 
TumblingGroupWindow$() - Constructor for class org.apache.flink.table.plan.logical.TumblingGroupWindow$
 
TumblingProcessingTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
A WindowAssigner that windows elements into windows based on the current system time of the machine the operation is running on.
TumblingTimeWindows - Class in org.apache.flink.streaming.api.windowing.assigners
Deprecated.
Tuple - Class in org.apache.flink.api.java.tuple
The base class of all tuples.
Tuple() - Constructor for class org.apache.flink.api.java.tuple.Tuple
 
Tuple0 - Class in org.apache.flink.api.java.tuple
A tuple with 0 fields.
Tuple0() - Constructor for class org.apache.flink.api.java.tuple.Tuple0
 
Tuple0Builder - Class in org.apache.flink.api.java.tuple.builder
 
Tuple0Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple0Builder
 
Tuple0Serializer - Class in org.apache.flink.api.java.typeutils.runtime
 
Tuple1<T0> - Class in org.apache.flink.api.java.tuple
A tuple with 1 fields.
Tuple1() - Constructor for class org.apache.flink.api.java.tuple.Tuple1
Creates a new tuple where all fields are null.
Tuple1(T0) - Constructor for class org.apache.flink.api.java.tuple.Tuple1
Creates a new tuple and assigns the given values to the tuple's fields.
Tuple10<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9> - Class in org.apache.flink.api.java.tuple
A tuple with 10 fields.
Tuple10() - Constructor for class org.apache.flink.api.java.tuple.Tuple10
Creates a new tuple where all fields are null.
Tuple10(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9) - Constructor for class org.apache.flink.api.java.tuple.Tuple10
Creates a new tuple and assigns the given values to the tuple's fields.
Tuple10Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9> - Class in org.apache.flink.api.java.tuple.builder
 
Tuple10Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple10Builder
 
Tuple11<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10> - Class in org.apache.flink.api.java.tuple
A tuple with 11 fields.
Tuple11() - Constructor for class org.apache.flink.api.java.tuple.Tuple11
Creates a new tuple where all fields are null.
Tuple11(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10) - Constructor for class org.apache.flink.api.java.tuple.Tuple11
Creates a new tuple and assigns the given values to the tuple's fields.
Tuple11Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10> - Class in org.apache.flink.api.java.tuple.builder
 
Tuple11Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple11Builder
 
Tuple12<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11> - Class in org.apache.flink.api.java.tuple
A tuple with 12 fields.
Tuple12() - Constructor for class org.apache.flink.api.java.tuple.Tuple12
Creates a new tuple where all fields are null.
Tuple12(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11) - Constructor for class org.apache.flink.api.java.tuple.Tuple12
Creates a new tuple and assigns the given values to the tuple's fields.
Tuple12Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11> - Class in org.apache.flink.api.java.tuple.builder
 
Tuple12Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple12Builder
 
Tuple13<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12> - Class in org.apache.flink.api.java.tuple
A tuple with 13 fields.
Tuple13() - Constructor for class org.apache.flink.api.java.tuple.Tuple13
Creates a new tuple where all fields are null.
Tuple13(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12) - Constructor for class org.apache.flink.api.java.tuple.Tuple13
Creates a new tuple and assigns the given values to the tuple's fields.
Tuple13Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12> - Class in org.apache.flink.api.java.tuple.builder
 
Tuple13Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple13Builder
 
Tuple14<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13> - Class in org.apache.flink.api.java.tuple
A tuple with 14 fields.
Tuple14() - Constructor for class org.apache.flink.api.java.tuple.Tuple14
Creates a new tuple where all fields are null.
Tuple14(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13) - Constructor for class org.apache.flink.api.java.tuple.Tuple14
Creates a new tuple and assigns the given values to the tuple's fields.
Tuple14Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13> - Class in org.apache.flink.api.java.tuple.builder
 
Tuple14Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple14Builder
 
Tuple15<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14> - Class in org.apache.flink.api.java.tuple
A tuple with 15 fields.
Tuple15() - Constructor for class org.apache.flink.api.java.tuple.Tuple15
Creates a new tuple where all fields are null.
Tuple15(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14) - Constructor for class org.apache.flink.api.java.tuple.Tuple15
Creates a new tuple and assigns the given values to the tuple's fields.
Tuple15Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14> - Class in org.apache.flink.api.java.tuple.builder
 
Tuple15Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple15Builder
 
Tuple16<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15> - Class in org.apache.flink.api.java.tuple
A tuple with 16 fields.
Tuple16() - Constructor for class org.apache.flink.api.java.tuple.Tuple16
Creates a new tuple where all fields are null.
Tuple16(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15) - Constructor for class org.apache.flink.api.java.tuple.Tuple16
Creates a new tuple and assigns the given values to the tuple's fields.
Tuple16Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15> - Class in org.apache.flink.api.java.tuple.builder
 
Tuple16Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple16Builder
 
Tuple17<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16> - Class in org.apache.flink.api.java.tuple
A tuple with 17 fields.
Tuple17() - Constructor for class org.apache.flink.api.java.tuple.Tuple17
Creates a new tuple where all fields are null.
Tuple17(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16) - Constructor for class org.apache.flink.api.java.tuple.Tuple17
Creates a new tuple and assigns the given values to the tuple's fields.
Tuple17Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16> - Class in org.apache.flink.api.java.tuple.builder
 
Tuple17Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple17Builder
 
Tuple18<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17> - Class in org.apache.flink.api.java.tuple
A tuple with 18 fields.
Tuple18() - Constructor for class org.apache.flink.api.java.tuple.Tuple18
Creates a new tuple where all fields are null.
Tuple18(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17) - Constructor for class org.apache.flink.api.java.tuple.Tuple18
Creates a new tuple and assigns the given values to the tuple's fields.
Tuple18Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17> - Class in org.apache.flink.api.java.tuple.builder
 
Tuple18Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple18Builder
 
Tuple19<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18> - Class in org.apache.flink.api.java.tuple
A tuple with 19 fields.
Tuple19() - Constructor for class org.apache.flink.api.java.tuple.Tuple19
Creates a new tuple where all fields are null.
Tuple19(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18) - Constructor for class org.apache.flink.api.java.tuple.Tuple19
Creates a new tuple and assigns the given values to the tuple's fields.
Tuple19Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18> - Class in org.apache.flink.api.java.tuple.builder
 
Tuple19Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple19Builder
 
Tuple1Builder<T0> - Class in org.apache.flink.api.java.tuple.builder
 
Tuple1Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple1Builder
 
Tuple2<T0,T1> - Class in org.apache.flink.api.java.tuple
A tuple with 2 fields.
Tuple2() - Constructor for class org.apache.flink.api.java.tuple.Tuple2
Creates a new tuple where all fields are null.
Tuple2(T0, T1) - Constructor for class org.apache.flink.api.java.tuple.Tuple2
Creates a new tuple and assigns the given values to the tuple's fields.
Tuple20<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19> - Class in org.apache.flink.api.java.tuple
A tuple with 20 fields.
Tuple20() - Constructor for class org.apache.flink.api.java.tuple.Tuple20
Creates a new tuple where all fields are null.
Tuple20(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19) - Constructor for class org.apache.flink.api.java.tuple.Tuple20
Creates a new tuple and assigns the given values to the tuple's fields.
Tuple20Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19> - Class in org.apache.flink.api.java.tuple.builder
 
Tuple20Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple20Builder
 
Tuple21<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20> - Class in org.apache.flink.api.java.tuple
A tuple with 21 fields.
Tuple21() - Constructor for class org.apache.flink.api.java.tuple.Tuple21
Creates a new tuple where all fields are null.
Tuple21(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20) - Constructor for class org.apache.flink.api.java.tuple.Tuple21
Creates a new tuple and assigns the given values to the tuple's fields.
Tuple21Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20> - Class in org.apache.flink.api.java.tuple.builder
 
Tuple21Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple21Builder
 
Tuple22<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21> - Class in org.apache.flink.api.java.tuple
A tuple with 22 fields.
Tuple22() - Constructor for class org.apache.flink.api.java.tuple.Tuple22
Creates a new tuple where all fields are null.
Tuple22(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21) - Constructor for class org.apache.flink.api.java.tuple.Tuple22
Creates a new tuple and assigns the given values to the tuple's fields.
Tuple22Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21> - Class in org.apache.flink.api.java.tuple.builder
 
Tuple22Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple22Builder
 
Tuple23<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22> - Class in org.apache.flink.api.java.tuple
A tuple with 23 fields.
Tuple23() - Constructor for class org.apache.flink.api.java.tuple.Tuple23
Creates a new tuple where all fields are null.
Tuple23(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22) - Constructor for class org.apache.flink.api.java.tuple.Tuple23
Creates a new tuple and assigns the given values to the tuple's fields.
Tuple23Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22> - Class in org.apache.flink.api.java.tuple.builder
 
Tuple23Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple23Builder
 
Tuple24<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23> - Class in org.apache.flink.api.java.tuple
A tuple with 24 fields.
Tuple24() - Constructor for class org.apache.flink.api.java.tuple.Tuple24
Creates a new tuple where all fields are null.
Tuple24(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22, T23) - Constructor for class org.apache.flink.api.java.tuple.Tuple24
Creates a new tuple and assigns the given values to the tuple's fields.
Tuple24Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23> - Class in org.apache.flink.api.java.tuple.builder
 
Tuple24Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple24Builder
 
Tuple25<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23,T24> - Class in org.apache.flink.api.java.tuple
A tuple with 25 fields.
Tuple25() - Constructor for class org.apache.flink.api.java.tuple.Tuple25
Creates a new tuple where all fields are null.
Tuple25(T0, T1, T2, T3, T4, T5, T6, T7, T8, T9, T10, T11, T12, T13, T14, T15, T16, T17, T18, T19, T20, T21, T22, T23, T24) - Constructor for class org.apache.flink.api.java.tuple.Tuple25
Creates a new tuple and assigns the given values to the tuple's fields.
Tuple25Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8,T9,T10,T11,T12,T13,T14,T15,T16,T17,T18,T19,T20,T21,T22,T23,T24> - Class in org.apache.flink.api.java.tuple.builder
 
Tuple25Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple25Builder
 
Tuple2Builder<T0,T1> - Class in org.apache.flink.api.java.tuple.builder
 
Tuple2Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple2Builder
 
Tuple2ToEdgeMap<K> - Class in org.apache.flink.graph.utils
Create an Edge from a Tuple2.
Tuple2ToEdgeMap() - Constructor for class org.apache.flink.graph.utils.Tuple2ToEdgeMap
 
Tuple2ToVertexMap<K,VV> - Class in org.apache.flink.graph.scala.utils
 
Tuple2ToVertexMap() - Constructor for class org.apache.flink.graph.scala.utils.Tuple2ToVertexMap
 
Tuple2ToVertexMap<K,VV> - Class in org.apache.flink.graph.utils
Create a Vertex DataSet from a Tuple2 DataSet
Tuple2ToVertexMap() - Constructor for class org.apache.flink.graph.utils.Tuple2ToVertexMap
 
Tuple3<T0,T1,T2> - Class in org.apache.flink.api.java.tuple
A tuple with 3 fields.
Tuple3() - Constructor for class org.apache.flink.api.java.tuple.Tuple3
Creates a new tuple where all fields are null.
Tuple3(T0, T1, T2) - Constructor for class org.apache.flink.api.java.tuple.Tuple3
Creates a new tuple and assigns the given values to the tuple's fields.
Tuple3Builder<T0,T1,T2> - Class in org.apache.flink.api.java.tuple.builder
 
Tuple3Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple3Builder
 
Tuple3ToEdgeMap<K,EV> - Class in org.apache.flink.graph.scala.utils
 
Tuple3ToEdgeMap() - Constructor for class org.apache.flink.graph.scala.utils.Tuple3ToEdgeMap
 
Tuple3ToEdgeMap<K,EV> - Class in org.apache.flink.graph.utils
Create an Edge DataSet from a Tuple3 DataSet
Tuple3ToEdgeMap() - Constructor for class org.apache.flink.graph.utils.Tuple3ToEdgeMap
 
Tuple3UnwrappingIterator<T,K1,K2> - Class in org.apache.flink.api.java.operators.translation
An iterator that reads 3-tuples (groupKey, sortKey, value) and returns only the values (third field).
Tuple3UnwrappingIterator() - Constructor for class org.apache.flink.api.java.operators.translation.Tuple3UnwrappingIterator
 
Tuple3WrappingCollector<IN,K1,K2> - Class in org.apache.flink.api.java.operators.translation
Needed to wrap tuples to Tuple3<groupKey, sortKey, value> for combine method of group reduce with key selector sorting
Tuple3WrappingCollector(Tuple3UnwrappingIterator<IN, K1, K2>) - Constructor for class org.apache.flink.api.java.operators.translation.Tuple3WrappingCollector
 
Tuple4<T0,T1,T2,T3> - Class in org.apache.flink.api.java.tuple
A tuple with 4 fields.
Tuple4() - Constructor for class org.apache.flink.api.java.tuple.Tuple4
Creates a new tuple where all fields are null.
Tuple4(T0, T1, T2, T3) - Constructor for class org.apache.flink.api.java.tuple.Tuple4
Creates a new tuple and assigns the given values to the tuple's fields.
Tuple4Builder<T0,T1,T2,T3> - Class in org.apache.flink.api.java.tuple.builder
 
Tuple4Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple4Builder
 
Tuple5<T0,T1,T2,T3,T4> - Class in org.apache.flink.api.java.tuple
A tuple with 5 fields.
Tuple5() - Constructor for class org.apache.flink.api.java.tuple.Tuple5
Creates a new tuple where all fields are null.
Tuple5(T0, T1, T2, T3, T4) - Constructor for class org.apache.flink.api.java.tuple.Tuple5
Creates a new tuple and assigns the given values to the tuple's fields.
Tuple5Builder<T0,T1,T2,T3,T4> - Class in org.apache.flink.api.java.tuple.builder
 
Tuple5Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple5Builder
 
Tuple6<T0,T1,T2,T3,T4,T5> - Class in org.apache.flink.api.java.tuple
A tuple with 6 fields.
Tuple6() - Constructor for class org.apache.flink.api.java.tuple.Tuple6
Creates a new tuple where all fields are null.
Tuple6(T0, T1, T2, T3, T4, T5) - Constructor for class org.apache.flink.api.java.tuple.Tuple6
Creates a new tuple and assigns the given values to the tuple's fields.
Tuple6Builder<T0,T1,T2,T3,T4,T5> - Class in org.apache.flink.api.java.tuple.builder
 
Tuple6Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple6Builder
 
Tuple7<T0,T1,T2,T3,T4,T5,T6> - Class in org.apache.flink.api.java.tuple
A tuple with 7 fields.
Tuple7() - Constructor for class org.apache.flink.api.java.tuple.Tuple7
Creates a new tuple where all fields are null.
Tuple7(T0, T1, T2, T3, T4, T5, T6) - Constructor for class org.apache.flink.api.java.tuple.Tuple7
Creates a new tuple and assigns the given values to the tuple's fields.
Tuple7Builder<T0,T1,T2,T3,T4,T5,T6> - Class in org.apache.flink.api.java.tuple.builder
 
Tuple7Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple7Builder
 
Tuple8<T0,T1,T2,T3,T4,T5,T6,T7> - Class in org.apache.flink.api.java.tuple
A tuple with 8 fields.
Tuple8() - Constructor for class org.apache.flink.api.java.tuple.Tuple8
Creates a new tuple where all fields are null.
Tuple8(T0, T1, T2, T3, T4, T5, T6, T7) - Constructor for class org.apache.flink.api.java.tuple.Tuple8
Creates a new tuple and assigns the given values to the tuple's fields.
Tuple8Builder<T0,T1,T2,T3,T4,T5,T6,T7> - Class in org.apache.flink.api.java.tuple.builder
 
Tuple8Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple8Builder
 
Tuple9<T0,T1,T2,T3,T4,T5,T6,T7,T8> - Class in org.apache.flink.api.java.tuple
A tuple with 9 fields.
Tuple9() - Constructor for class org.apache.flink.api.java.tuple.Tuple9
Creates a new tuple where all fields are null.
Tuple9(T0, T1, T2, T3, T4, T5, T6, T7, T8) - Constructor for class org.apache.flink.api.java.tuple.Tuple9
Creates a new tuple and assigns the given values to the tuple's fields.
Tuple9Builder<T0,T1,T2,T3,T4,T5,T6,T7,T8> - Class in org.apache.flink.api.java.tuple.builder
 
Tuple9Builder() - Constructor for class org.apache.flink.api.java.tuple.builder.Tuple9Builder
 
tupleClass - Variable in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
TupleComparator<T extends Tuple> - Class in org.apache.flink.api.java.typeutils.runtime
 
TupleComparator(int[], TypeComparator<?>[], TypeSerializer<?>[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.TupleComparator
 
TupleComparator() - Constructor for class org.apache.flink.test.util.JavaProgramTestBase.TupleComparator
 
TupleComparator() - Constructor for class org.apache.flink.test.util.TestBaseUtils.TupleComparator
 
TupleComparatorBase<T> - Class in org.apache.flink.api.java.typeutils.runtime
 
TupleComparatorBase(int[], TypeComparator<?>[], TypeSerializer<?>[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
TupleComparatorBase(TupleComparatorBase<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
TupleCsvInputFormat<OUT> - Class in org.apache.flink.api.java.io
 
TupleCsvInputFormat(Path, TupleTypeInfoBase<OUT>) - Constructor for class org.apache.flink.api.java.io.TupleCsvInputFormat
 
TupleCsvInputFormat(Path, String, String, TupleTypeInfoBase<OUT>) - Constructor for class org.apache.flink.api.java.io.TupleCsvInputFormat
 
TupleCsvInputFormat(Path, TupleTypeInfoBase<OUT>, int[]) - Constructor for class org.apache.flink.api.java.io.TupleCsvInputFormat
 
TupleCsvInputFormat(Path, String, String, TupleTypeInfoBase<OUT>, int[]) - Constructor for class org.apache.flink.api.java.io.TupleCsvInputFormat
 
TupleCsvInputFormat(Path, TupleTypeInfoBase<OUT>, boolean[]) - Constructor for class org.apache.flink.api.java.io.TupleCsvInputFormat
 
TupleCsvInputFormat(Path, String, String, TupleTypeInfoBase<OUT>, boolean[]) - Constructor for class org.apache.flink.api.java.io.TupleCsvInputFormat
 
TupleEdgeConverter() - Constructor for class org.apache.flink.examples.java.graph.EnumTriangles.TupleEdgeConverter
 
TupleLeftUnwrappingJoiner<I1,I2,OUT,K> - Class in org.apache.flink.api.java.operators.translation
 
TupleLeftUnwrappingJoiner(FlatJoinFunction<I1, I2, OUT>) - Constructor for class org.apache.flink.api.java.operators.translation.TupleLeftUnwrappingJoiner
 
tupleList - Variable in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
 
TupleOutputFormatter - Class in org.apache.flink.storm.util
 
TupleOutputFormatter() - Constructor for class org.apache.flink.storm.util.TupleOutputFormatter
 
TupleRightUnwrappingJoiner<I1,I2,OUT,K> - Class in org.apache.flink.api.java.operators.translation
 
TupleRightUnwrappingJoiner(FlatJoinFunction<I1, I2, OUT>) - Constructor for class org.apache.flink.api.java.operators.translation.TupleRightUnwrappingJoiner
 
TUPLES - Static variable in class org.apache.flink.storm.wordcount.operators.WordCountDataTuple
 
TupleSerializer<T extends Tuple> - Class in org.apache.flink.api.java.typeutils.runtime
 
TupleSerializer(Class<T>, TypeSerializer<?>[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.TupleSerializer
 
TupleSerializer(Tuple) - Constructor for class org.apache.flink.python.api.streaming.util.SerializationUtils.TupleSerializer
 
TupleSerializerBase<T> - Class in org.apache.flink.api.java.typeutils.runtime
 
TupleSerializerBase(Class<T>, TypeSerializer<?>[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.TupleSerializerBase
 
TupleSerializerConfigSnapshot<T> - Class in org.apache.flink.api.java.typeutils.runtime
Snapshot of a tuple serializer's configuration.
TupleSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.TupleSerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
TupleSerializerConfigSnapshot(Class<T>, TypeSerializer<?>[]) - Constructor for class org.apache.flink.api.java.typeutils.runtime.TupleSerializerConfigSnapshot
 
TupleSummaryAggregator<R extends Tuple> - Class in org.apache.flink.api.java.summarize.aggregation
Aggregate tuples using an array of aggregators, one for each "column" or position within the Tuple.
TupleSummaryAggregator(Aggregator[]) - Constructor for class org.apache.flink.api.java.summarize.aggregation.TupleSummaryAggregator
 
tupleType(Class<T>) - Method in class org.apache.flink.api.java.io.CsvReader
Configures the reader to read the CSV data and parse it to the given type.
TupleTypeInfo<T extends Tuple> - Class in org.apache.flink.api.java.typeutils
A TypeInformation for the tuple types of the Java API.
TupleTypeInfo(TypeInformation<?>...) - Constructor for class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
TupleTypeInfo(Class<T>, TypeInformation<?>...) - Constructor for class org.apache.flink.api.java.typeutils.TupleTypeInfo
 
TupleTypeInfoBase<T> - Class in org.apache.flink.api.java.typeutils
 
TupleTypeInfoBase(Class<T>, TypeInformation<?>...) - Constructor for class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
TupleUnwrappingIterator<T,K> - Class in org.apache.flink.api.java.operators.translation
An iterator that reads 2-tuples (key value pairs) and returns only the values (second field).
TupleUnwrappingIterator() - Constructor for class org.apache.flink.api.java.operators.translation.TupleUnwrappingIterator
 
TupleUnwrappingJoiner<I1,I2,OUT,K> - Class in org.apache.flink.api.java.operators.translation
 
TupleUnwrappingJoiner(FlatJoinFunction<I1, I2, OUT>) - Constructor for class org.apache.flink.api.java.operators.translation.TupleUnwrappingJoiner
 
TupleWrappingCollector<IN,K> - Class in org.apache.flink.api.java.operators.translation
Needed to wrap tuples to Tuple2<key, value> pairs for combine method of group reduce with key selector function
TupleWrappingCollector(TupleUnwrappingIterator<IN, K>) - Constructor for class org.apache.flink.api.java.operators.translation.TupleWrappingCollector
 
Tweet - Class in org.apache.flink.contrib.tweetinputformat.model.tweet
 
Tweet() - Constructor for class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
Tweet(int) - Constructor for class org.apache.flink.contrib.tweetinputformat.model.tweet.Tweet
 
TweetHandler - Class in org.apache.flink.contrib.tweetinputformat.io
 
TweetHandler() - Constructor for class org.apache.flink.contrib.tweetinputformat.io.TweetHandler
 
tweetObjectStatePrimitiveHandler(Object) - Method in class org.apache.flink.contrib.tweetinputformat.io.TweetHandler
 
TwitterExample - Class in org.apache.flink.streaming.examples.twitter
Implements the "TwitterStream" program that computes a most used word occurrence over JSON objects in a streaming fashion.
TwitterExample() - Constructor for class org.apache.flink.streaming.examples.twitter.TwitterExample
 
TwitterExample.SelectEnglishAndTokenizeFlatMap - Class in org.apache.flink.streaming.examples.twitter
Deserialize JSON from twitter source
TwitterExampleData - Class in org.apache.flink.streaming.examples.twitter.util
 
TwitterSource - Class in org.apache.flink.streaming.connectors.twitter
Implementation of SourceFunction specialized to emit tweets from Twitter.
TwitterSource(Properties) - Constructor for class org.apache.flink.streaming.connectors.twitter.TwitterSource
Create TwitterSource for streaming
TwitterSource.EndpointInitializer - Interface in org.apache.flink.streaming.connectors.twitter
Implementing this interface allows users of this source to set a custom endpoint.
two(T2) - Static method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.TaggedUnion
 
TwoInputNode - Class in org.apache.flink.optimizer.dag
A node in the optimizer plan that represents an operator with a two different inputs, such as Join, Cross, CoGroup, or Union.
TwoInputNode(DualInputOperator<?, ?, ?, ?>) - Constructor for class org.apache.flink.optimizer.dag.TwoInputNode
Creates a new two input node for the optimizer plan, representing the given operator.
TwoInputOperator<IN1,IN2,OUT,O extends TwoInputOperator<IN1,IN2,OUT,O>> - Class in org.apache.flink.api.java.operators
Base class for operations that operates on two input data sets.
TwoInputOperator(DataSet<IN1>, DataSet<IN2>, TypeInformation<OUT>) - Constructor for class org.apache.flink.api.java.operators.TwoInputOperator
 
TwoInputStreamOperator<IN1,IN2,OUT> - Interface in org.apache.flink.streaming.api.operators
Interface for stream operators with two inputs.
TwoInputStreamTask<IN1,IN2,OUT> - Class in org.apache.flink.streaming.runtime.tasks
TwoInputStreamTask() - Constructor for class org.apache.flink.streaming.runtime.tasks.TwoInputStreamTask
 
TwoInputTransformation<IN1,IN2,OUT> - Class in org.apache.flink.streaming.api.transformations
This Transformation represents the application of a TwoInputStreamOperator to two input StreamTransformations.
TwoInputTransformation(StreamTransformation<IN1>, StreamTransformation<IN2>, String, TwoInputStreamOperator<IN1, IN2, OUT>, TypeInformation<OUT>, int) - Constructor for class org.apache.flink.streaming.api.transformations.TwoInputTransformation
Creates a new TwoInputTransformation from the given inputs and operator.
TwoInputUdfOperator<IN1,IN2,OUT,O extends TwoInputUdfOperator<IN1,IN2,OUT,O>> - Class in org.apache.flink.api.java.operators
The TwoInputUdfOperator is the base class of all binary operators that execute user-defined functions (UDFs).
TwoInputUdfOperator(DataSet<IN1>, DataSet<IN2>, TypeInformation<OUT>) - Constructor for class org.apache.flink.api.java.operators.TwoInputUdfOperator
Creates a new operators with the two given data sets as inputs.
TwoKeyExtractingMapper<T,K1,K2> - Class in org.apache.flink.api.java.operators.translation
 
TwoKeyExtractingMapper(KeySelector<T, K1>, KeySelector<T, K2>) - Constructor for class org.apache.flink.api.java.operators.translation.TwoKeyExtractingMapper
 
type(OptionType) - Method in class org.apache.flink.api.java.utils.Option
Define the type of the Option.
TYPE - Static variable in class org.apache.flink.streaming.api.graph.JSONGenerator
 
TYPE_ARRAY - Static variable in class org.apache.flink.python.api.streaming.data.PythonSender
 
TYPE_BOOLEAN - Static variable in class org.apache.flink.python.api.streaming.util.SerializationUtils
 
TYPE_BYTE - Static variable in class org.apache.flink.python.api.streaming.util.SerializationUtils
 
TYPE_BYTES - Static variable in class org.apache.flink.python.api.streaming.util.SerializationUtils
 
TYPE_DOUBLE - Static variable in class org.apache.flink.python.api.streaming.util.SerializationUtils
 
TYPE_FLOAT - Static variable in class org.apache.flink.python.api.streaming.util.SerializationUtils
 
TYPE_INTEGER - Static variable in class org.apache.flink.python.api.streaming.util.SerializationUtils
 
TYPE_KEY_VALUE - Static variable in class org.apache.flink.python.api.streaming.data.PythonSender
 
TYPE_LONG - Static variable in class org.apache.flink.python.api.streaming.util.SerializationUtils
 
TYPE_NULL - Static variable in class org.apache.flink.python.api.streaming.util.SerializationUtils
 
TYPE_STRING - Static variable in class org.apache.flink.python.api.streaming.util.SerializationUtils
 
TYPE_VALUE_VALUE - Static variable in class org.apache.flink.python.api.streaming.data.PythonSender
 
TypeAnalyzer<C extends scala.reflect.macros.Context> - Interface in org.apache.flink.api.scala.codegen
 
TypeAnalyzer.UDTAnalyzerInstance - Class in org.apache.flink.api.scala.codegen
 
typeArgs(scala.reflect.macros.Context.universe) - Method in interface org.apache.flink.api.scala.codegen.TypeAnalyzer
 
typeCheck(scala.reflect.macros.Context.universe) - Method in interface org.apache.flink.api.scala.codegen.TreeGen
 
TypeCheckUtils - Class in org.apache.flink.table.typeutils
 
TypeCheckUtils() - Constructor for class org.apache.flink.table.typeutils.TypeCheckUtils
 
TypeCheckUtils$ - Class in org.apache.flink.table.typeutils
 
TypeCheckUtils$() - Constructor for class org.apache.flink.table.typeutils.TypeCheckUtils$
 
TypeCoercion - Class in org.apache.flink.table.typeutils
Utilities for type conversions.
TypeCoercion() - Constructor for class org.apache.flink.table.typeutils.TypeCoercion
 
TypeCoercion$ - Class in org.apache.flink.table.typeutils
Utilities for type conversions.
TypeCoercion$() - Constructor for class org.apache.flink.table.typeutils.TypeCoercion$
 
TypeComparable<T> - Class in org.apache.flink.api.common.operators.util
Wrapper that is used to store elements for which we have a TypeComparator in a Hash Map.
TypeComparable(T, TypeComparator<T>) - Constructor for class org.apache.flink.api.common.operators.util.TypeComparable
 
TypeComparator<T> - Class in org.apache.flink.api.common.typeutils
This interface describes the methods that are required for a data type to be handled by the pact runtime.
TypeComparator() - Constructor for class org.apache.flink.api.common.typeutils.TypeComparator
 
TypeComparatorFactory<T> - Interface in org.apache.flink.api.common.typeutils
 
TypeDescriptors<C extends scala.reflect.macros.Context> - Interface in org.apache.flink.api.scala.codegen
 
TypeDescriptors.ArrayDescriptor - Class in org.apache.flink.api.scala.codegen
 
TypeDescriptors.BoxedPrimitiveDescriptor - Class in org.apache.flink.api.scala.codegen
 
TypeDescriptors.CaseClassDescriptor - Class in org.apache.flink.api.scala.codegen
 
TypeDescriptors.EitherDescriptor - Class in org.apache.flink.api.scala.codegen
 
TypeDescriptors.EnumValueDescriptor - Class in org.apache.flink.api.scala.codegen
 
TypeDescriptors.FactoryTypeDescriptor - Class in org.apache.flink.api.scala.codegen
 
TypeDescriptors.FieldDescriptor - Class in org.apache.flink.api.scala.codegen
 
TypeDescriptors.GenericClassDescriptor - Class in org.apache.flink.api.scala.codegen
 
TypeDescriptors.JavaTupleDescriptor - Class in org.apache.flink.api.scala.codegen
 
TypeDescriptors.NothingDescriptor - Class in org.apache.flink.api.scala.codegen
 
TypeDescriptors.OptionDescriptor - Class in org.apache.flink.api.scala.codegen
 
TypeDescriptors.PojoDescriptor - Class in org.apache.flink.api.scala.codegen
 
TypeDescriptors.PrimitiveDescriptor - Class in org.apache.flink.api.scala.codegen
 
TypeDescriptors.RecursiveDescriptor - Class in org.apache.flink.api.scala.codegen
 
TypeDescriptors.TraversableDescriptor - Class in org.apache.flink.api.scala.codegen
 
TypeDescriptors.TryDescriptor - Class in org.apache.flink.api.scala.codegen
 
TypeDescriptors.TypeParameterDescriptor - Class in org.apache.flink.api.scala.codegen
 
TypeDescriptors.UDTDescriptor - Class in org.apache.flink.api.scala.codegen
 
TypeDescriptors.UnitDescriptor - Class in org.apache.flink.api.scala.codegen
 
TypeDescriptors.UnsupportedDescriptor - Class in org.apache.flink.api.scala.codegen
 
TypeDescriptors.ValueDescriptor - Class in org.apache.flink.api.scala.codegen
 
TypeDescriptors.WritableDescriptor - Class in org.apache.flink.api.scala.codegen
 
TypeDeserializer<T> - Interface in org.apache.flink.api.common.typeutils
This interface describes the methods that are required for a data type to be read by the Flink runtime.
TypeDeserializerAdapter<T> - Class in org.apache.flink.api.common.typeutils
A utility class that is used to bridge a TypeSerializer and TypeDeserializer.
TypeDeserializerAdapter(TypeDeserializer<T>) - Constructor for class org.apache.flink.api.common.typeutils.TypeDeserializerAdapter
TypeDeserializerAdapter(TypeSerializer<T>) - Constructor for class org.apache.flink.api.common.typeutils.TypeDeserializerAdapter
Creates a TypeDeserializerAdapter that wraps a TypeSerializer.
TypeExtractionException - Exception in org.apache.flink.api.java.typeutils
Type extraction always contains some uncertainty due to unpredictable JVM differences between vendors or versions.
TypeExtractionException() - Constructor for exception org.apache.flink.api.java.typeutils.TypeExtractionException
Creates a new exception with no message.
TypeExtractionException(String) - Constructor for exception org.apache.flink.api.java.typeutils.TypeExtractionException
Creates a new exception with the given message.
TypeExtractionException(String, Throwable) - Constructor for exception org.apache.flink.api.java.typeutils.TypeExtractionException
Creates a new exception with the given message and cause.
TypeExtractionUtils - Class in org.apache.flink.api.java.typeutils
 
TypeExtractionUtils.LambdaExecutable - Class in org.apache.flink.api.java.typeutils
Similar to a Java 8 Executable but with a return type.
TypeExtractor - Class in org.apache.flink.api.java.typeutils
A utility for reflection analysis on classes, to determine the return type of implementations of transformation functions.
TypeExtractor() - Constructor for class org.apache.flink.api.java.typeutils.TypeExtractor
 
typeFactory - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
 
TypeHint<T> - Class in org.apache.flink.api.common.typeinfo
A utility class for describing generic types.
TypeHint() - Constructor for class org.apache.flink.api.common.typeinfo.TypeHint
Creates a hint for the generic type in the class signature.
TypeHint(Class<?>, Object, int) - Constructor for class org.apache.flink.api.common.typeinfo.TypeHint
Creates a hint for the generic type in the class signature.
TypeInfo - Annotation Type in org.apache.flink.api.common.typeinfo
Annotation for specifying a corresponding TypeInfoFactory that can produce TypeInformation for the annotated type.
typeInfo - Variable in class org.apache.flink.streaming.connectors.cassandra.CassandraSink.CassandraSinkBuilder
 
typeInfo() - Method in class org.apache.flink.table.plan.schema.ArrayRelDataType
 
typeInfo() - Static method in class org.apache.flink.table.plan.schema.DataSetTable
 
typeInfo() - Static method in class org.apache.flink.table.plan.schema.DataStreamTable
 
typeInfo() - Method in class org.apache.flink.table.plan.schema.FlinkTable
 
typeInfo() - Method in class org.apache.flink.table.plan.schema.FlinkTableFunctionImpl
 
typeInfo() - Method in class org.apache.flink.table.plan.schema.GenericRelDataType
 
typeInfo() - Method in class org.apache.flink.table.plan.schema.MapRelDataType
 
typeInfo() - Static method in class org.apache.flink.table.plan.schema.StreamTableSourceTable
 
typeInfo() - Static method in class org.apache.flink.table.plan.schema.TableSourceTable
 
TypeInfoFactory<T> - Class in org.apache.flink.api.common.typeinfo
Base class for implementing a type information factory.
TypeInfoFactory() - Constructor for class org.apache.flink.api.common.typeinfo.TypeInfoFactory
 
TypeInfoParser - Class in org.apache.flink.api.java.typeutils
 
TypeInfoParser() - Constructor for class org.apache.flink.api.java.typeutils.TypeInfoParser
 
TypeInformation<T> - Class in org.apache.flink.api.common.typeinfo
TypeInformation is the core class of Flink's type system.
TypeInformation() - Constructor for class org.apache.flink.api.common.typeinfo.TypeInformation
 
TypeInformationGen<C extends scala.reflect.macros.Context> - Interface in org.apache.flink.api.scala.codegen
 
TypeInformationKeyValueSerializationSchema<K,V> - Class in org.apache.flink.streaming.util.serialization
A serialization and deserialization schema for Key Value Pairs that uses Flink's serialization stack to transform typed from and to byte arrays.
TypeInformationKeyValueSerializationSchema(TypeInformation<K>, TypeInformation<V>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.util.serialization.TypeInformationKeyValueSerializationSchema
Creates a new de-/serialization schema for the given types.
TypeInformationKeyValueSerializationSchema(Class<K>, Class<V>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.util.serialization.TypeInformationKeyValueSerializationSchema
Creates a new de-/serialization schema for the given types.
TypeInformationSerializationSchema<T> - Class in org.apache.flink.streaming.util.serialization
A serialization and deserialization schema that uses Flink's serialization stack to transform typed from and to byte arrays.
TypeInformationSerializationSchema(TypeInformation<T>, ExecutionConfig) - Constructor for class org.apache.flink.streaming.util.serialization.TypeInformationSerializationSchema
Creates a new de-/serialization schema for the given type.
typeInfoToClass(Seq<TypeInformation<?>>) - Method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils$
Extracts type classes of TypeInformation in a null-aware way.
typeInfoToClass(Seq<TypeInformation<?>>) - Static method in class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils
Extracts type classes of TypeInformation in a null-aware way.
TypePairComparator<T1,T2> - Class in org.apache.flink.api.common.typeutils
This interface defines the method required by the runtime to use data types in join-like operations.
TypePairComparator() - Constructor for class org.apache.flink.api.common.typeutils.TypePairComparator
 
TypePairComparatorFactory<T1,T2> - Interface in org.apache.flink.api.common.typeutils
 
TypeParameterDescriptor(int, scala.reflect.macros.Context.universe) - Constructor for class org.apache.flink.api.scala.codegen.TypeDescriptors.TypeParameterDescriptor
 
typeParamTypeInfos() - Method in class org.apache.flink.api.scala.typeutils.CaseClassTypeInfo
 
types - Variable in class org.apache.flink.api.common.operators.Ordering
 
Types - Class in org.apache.flink.api.common.typeinfo
This class gives access to the type information of the most most common types.
Types() - Constructor for class org.apache.flink.api.common.typeinfo.Types
 
types(Class<T0>) - Method in class org.apache.flink.api.java.io.CsvReader
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>) - Method in class org.apache.flink.api.java.io.CsvReader
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>, Class<T2>) - Method in class org.apache.flink.api.java.io.CsvReader
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>, Class<T2>, Class<T3>) - Method in class org.apache.flink.api.java.io.CsvReader
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>) - Method in class org.apache.flink.api.java.io.CsvReader
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>) - Method in class org.apache.flink.api.java.io.CsvReader
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>) - Method in class org.apache.flink.api.java.io.CsvReader
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>) - Method in class org.apache.flink.api.java.io.CsvReader
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>) - Method in class org.apache.flink.api.java.io.CsvReader
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>) - Method in class org.apache.flink.api.java.io.CsvReader
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>) - Method in class org.apache.flink.api.java.io.CsvReader
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>) - Method in class org.apache.flink.api.java.io.CsvReader
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>) - Method in class org.apache.flink.api.java.io.CsvReader
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>) - Method in class org.apache.flink.api.java.io.CsvReader
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>) - Method in class org.apache.flink.api.java.io.CsvReader
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>) - Method in class org.apache.flink.api.java.io.CsvReader
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>, Class<T16>) - Method in class org.apache.flink.api.java.io.CsvReader
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>, Class<T16>, Class<T17>) - Method in class org.apache.flink.api.java.io.CsvReader
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>, Class<T16>, Class<T17>, Class<T18>) - Method in class org.apache.flink.api.java.io.CsvReader
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>, Class<T16>, Class<T17>, Class<T18>, Class<T19>) - Method in class org.apache.flink.api.java.io.CsvReader
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>, Class<T16>, Class<T17>, Class<T18>, Class<T19>, Class<T20>) - Method in class org.apache.flink.api.java.io.CsvReader
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>, Class<T16>, Class<T17>, Class<T18>, Class<T19>, Class<T20>, Class<T21>) - Method in class org.apache.flink.api.java.io.CsvReader
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>, Class<T16>, Class<T17>, Class<T18>, Class<T19>, Class<T20>, Class<T21>, Class<T22>) - Method in class org.apache.flink.api.java.io.CsvReader
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>, Class<T16>, Class<T17>, Class<T18>, Class<T19>, Class<T20>, Class<T21>, Class<T22>, Class<T23>) - Method in class org.apache.flink.api.java.io.CsvReader
Specifies the types for the CSV fields.
types(Class<T0>, Class<T1>, Class<T2>, Class<T3>, Class<T4>, Class<T5>, Class<T6>, Class<T7>, Class<T8>, Class<T9>, Class<T10>, Class<T11>, Class<T12>, Class<T13>, Class<T14>, Class<T15>, Class<T16>, Class<T17>, Class<T18>, Class<T19>, Class<T20>, Class<T21>, Class<T22>, Class<T23>, Class<T24>) - Method in class org.apache.flink.api.java.io.CsvReader
Specifies the types for the CSV fields.
types(Class<?>...) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
Deprecated.
Deprecated method only kept for compatibility.
types(Class<?>...) - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
Deprecated.
Deprecated method only kept for compatibility.
types(Class<?>...) - Method in class org.apache.flink.api.java.operators.ProjectOperator
Deprecated.
Deprecated method only kept for compatibility.
types - Variable in class org.apache.flink.api.java.typeutils.TupleTypeInfoBase
 
types(Class<K>, Class<VV>, Class<EV>) - Method in class org.apache.flink.graph.GraphCsvReader
Creates a Graph from CSV input with vertex values and edge values.
types - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
Types - Class in org.apache.flink.table.api
 
Types() - Constructor for class org.apache.flink.table.api.Types
 
Types$ - Class in org.apache.flink.table.api
 
Types$() - Constructor for class org.apache.flink.table.api.Types$
 
TypeSerializer<T> - Class in org.apache.flink.api.common.typeutils
This interface describes the methods that are required for a data type to be handled by the Flink runtime.
TypeSerializer() - Constructor for class org.apache.flink.api.common.typeutils.TypeSerializer
 
TypeSerializerConfigSnapshot - Class in org.apache.flink.api.common.typeutils
A TypeSerializerConfigSnapshot is a point-in-time view of a TypeSerializer's configuration.
TypeSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.common.typeutils.TypeSerializerConfigSnapshot
 
TypeSerializerFactory<T> - Interface in org.apache.flink.api.common.typeutils
 
TypeSerializerInputFormat<T> - Class in org.apache.flink.api.java.io
Reads elements by deserializing them with a given type serializer.
TypeSerializerInputFormat(TypeInformation<T>) - Constructor for class org.apache.flink.api.java.io.TypeSerializerInputFormat
 
TypeSerializerOutputFormat<T> - Class in org.apache.flink.api.java.io
Stores elements by serializing them with their type serializer.
TypeSerializerOutputFormat() - Constructor for class org.apache.flink.api.java.io.TypeSerializerOutputFormat
 
TypeSerializerSerializationProxy(ClassLoader, boolean) - Constructor for class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil.TypeSerializerSerializationProxy
 
TypeSerializerSerializationProxy(ClassLoader) - Constructor for class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil.TypeSerializerSerializationProxy
 
TypeSerializerSerializationProxy(TypeSerializer<T>) - Constructor for class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil.TypeSerializerSerializationProxy
 
TypeSerializerSerializationUtil - Class in org.apache.flink.api.common.typeutils
Utility methods for serialization of TypeSerializer and TypeSerializerConfigSnapshot.
TypeSerializerSerializationUtil() - Constructor for class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
 
TypeSerializerSerializationUtil.SerialUIDMismatchTolerantInputStream - Class in org.apache.flink.api.common.typeutils
An ObjectInputStream that ignores serialVersionUID mismatches when deserializing objects of anonymous classes or our Scala serializer classes.
TypeSerializerSerializationUtil.TypeSerializerSerializationProxy<T> - Class in org.apache.flink.api.common.typeutils
Utility serialization proxy for a TypeSerializer.
TypeSerializerSingleton<T> - Class in org.apache.flink.api.common.typeutils.base
 
TypeSerializerSingleton() - Constructor for class org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton
 
typeToClass(Type) - Static method in class org.apache.flink.api.java.typeutils.TypeExtractionUtils
Convert ParameterizedType or Class to a Class.
typeUsed - Variable in class org.apache.flink.streaming.api.transformations.StreamTransformation
 
TypeUtils - Class in org.apache.flink.api.scala.typeutils
 
TypeUtils() - Constructor for class org.apache.flink.api.scala.typeutils.TypeUtils
 
TypeUtils$ - Class in org.apache.flink.api.scala.typeutils
 
TypeUtils$() - Constructor for class org.apache.flink.api.scala.typeutils.TypeUtils$
 

U

UDAGGExpression<T,ACC> - Class in org.apache.flink.table.expressions
A class which creates a call to an aggregateFunction
UDAGGExpression(AggregateFunction<T, ACC>, TypeInformation<T>) - Constructor for class org.apache.flink.table.expressions.UDAGGExpression
 
UDAGGExpression$ - Class in org.apache.flink.table.expressions
 
UDAGGExpression$() - Constructor for class org.apache.flink.table.expressions.UDAGGExpression$
 
UdfAnalyzer - Class in org.apache.flink.api.java.sca
Implements a Static Code Analyzer (SCA) that uses the ASM framework for interpreting Java bytecode of Flink UDFs.
UdfAnalyzer(Class<?>, Class<?>, String, TypeInformation<?>, TypeInformation<?>, TypeInformation<?>, Keys<?>, Keys<?>, boolean) - Constructor for class org.apache.flink.api.java.sca.UdfAnalyzer
 
UdfAnalyzerUtils - Class in org.apache.flink.api.java.sca
Utility class to work with UdfAnalyzer
UdfOperator<O extends UdfOperator<O>> - Interface in org.apache.flink.api.java.operators
This interface marks operators as operators that execute user-defined functions (UDFs), such as RichMapFunction, RichReduceFunction, or RichCoGroupFunction.
UdfOperatorUtils - Class in org.apache.flink.api.java.operators
Utility class that contains helper methods to work with UDF operators.
udfWithForwardedFieldsAnnotation(Class<?>) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
 
udfWithForwardedFieldsFirstAnnotation(Class<?>) - Method in class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
 
udfWithForwardedFieldsFirstAnnotation(Class<?>) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
 
udfWithForwardedFieldsSecondAnnotation(Class<?>) - Method in class org.apache.flink.api.java.operators.JoinOperator.EquiJoin
 
udfWithForwardedFieldsSecondAnnotation(Class<?>) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
 
UDTAnalyzerInstance() - Constructor for class org.apache.flink.api.scala.codegen.TypeAnalyzer.UDTAnalyzerInstance
 
UDTDescriptor() - Constructor for class org.apache.flink.api.scala.codegen.TypeDescriptors.UDTDescriptor
 
uid(String) - Method in class org.apache.flink.streaming.api.datastream.DataStreamSink
Sets an ID for this operator.
uid(String) - Method in class org.apache.flink.streaming.api.datastream.SingleOutputStreamOperator
Sets an ID for this operator.
uid(String) - Method in class org.apache.flink.streaming.api.scala.DataStream
Sets an ID for this operator.
uid(String) - Method in class org.apache.flink.streaming.connectors.cassandra.CassandraSink
Sets an ID for this operator.
uid(String) - Method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010.FlinkKafkaProducer010Configuration
 
unary() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
unary() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
UNARY_MINUS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Prefix arithmetic minus operator, '-'.
UNARY_PLUS - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
Prefix arithmetic plus operator, '+'.
UnaryExpression - Class in org.apache.flink.table.expressions
 
UnaryExpression() - Constructor for class org.apache.flink.table.expressions.UnaryExpression
 
unaryMinus() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
unaryMinus() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
UnaryMinus - Class in org.apache.flink.table.expressions
 
UnaryMinus(Expression) - Constructor for class org.apache.flink.table.expressions.UnaryMinus
 
UnaryMinus$ - Class in org.apache.flink.table.expressions
 
UnaryMinus$() - Constructor for class org.apache.flink.table.expressions.UnaryMinus$
 
UnaryNode - Class in org.apache.flink.table.plan.logical
 
UnaryNode() - Constructor for class org.apache.flink.table.plan.logical.UnaryNode
 
unaryNot() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
unaryNot() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
unaryOperation(AbstractInsnNode, BasicValue) - Method in class org.apache.flink.api.java.sca.NestedMethodAnalyzer
 
UnaryOperatorInformation<IN,OUT> - Class in org.apache.flink.api.common.operators
A class for holding information about a single input operator, such as input/output TypeInformation.
UnaryOperatorInformation(TypeInformation<IN>, TypeInformation<OUT>) - Constructor for class org.apache.flink.api.common.operators.UnaryOperatorInformation
 
UnaryOperatorNode - Class in org.apache.flink.optimizer.dag
 
UnaryOperatorNode(String, SingleInputOperator<?, ?, ?>, boolean) - Constructor for class org.apache.flink.optimizer.dag.UnaryOperatorNode
 
UnaryOperatorNode(String, FieldSet, OperatorDescriptorSingle...) - Constructor for class org.apache.flink.optimizer.dag.UnaryOperatorNode
 
UnaryOperatorNode(String, FieldSet, List<OperatorDescriptorSingle>) - Constructor for class org.apache.flink.optimizer.dag.UnaryOperatorNode
 
unaryPlus() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
unaryPlus() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
UnaryResult<T> - Interface in org.apache.flink.graph.asm.result
A GraphAlgorithm result for a single vertex.
Unassign(Protos.TaskID, String) - Constructor for class org.apache.flink.mesos.scheduler.LaunchCoordinator.Unassign
 
Unassign$() - Constructor for class org.apache.flink.mesos.scheduler.LaunchCoordinator.Unassign$
 
unblock(DataSet<Tuple2<Object, double[][]>>, DataSet<Tuple2<Object, ALS.OutBlockInformation>>, ALS.BlockIDPartitioner) - Method in class org.apache.flink.ml.recommendation.ALS$
Unblocks the blocked user and item matrix representation so that it is at DataSet of column vectors.
unblock(DataSet<Tuple2<Object, double[][]>>, DataSet<Tuple2<Object, ALS.OutBlockInformation>>, ALS.BlockIDPartitioner) - Static method in class org.apache.flink.ml.recommendation.ALS
Unblocks the blocked user and item matrix representation so that it is at DataSet of column vectors.
UNBOUNDED_RANGE() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionConversions
 
UNBOUNDED_RANGE() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
UNBOUNDED_RANGE() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
UNBOUNDED_ROW() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionConversions
 
UNBOUNDED_ROW() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
UNBOUNDED_ROW() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
UnboundedRange - Class in org.apache.flink.table.api
 
UnboundedRange() - Constructor for class org.apache.flink.table.api.UnboundedRange
 
unboundedRange() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
unboundedRange() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
UnboundedRange$ - Class in org.apache.flink.table.api
 
UnboundedRange$() - Constructor for class org.apache.flink.table.api.UnboundedRange$
 
UnboundedRow - Class in org.apache.flink.table.api
 
UnboundedRow() - Constructor for class org.apache.flink.table.api.UnboundedRow
 
unboundedRow() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
unboundedRow() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
UnboundedRow$ - Class in org.apache.flink.table.api
 
UnboundedRow$() - Constructor for class org.apache.flink.table.api.UnboundedRow$
 
unbox() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.BoxedPrimitiveDescriptor
 
uncaughtException(Thread, Throwable) - Method in class org.apache.flink.runtime.io.disk.iomanager.IOManagerAsync
 
uncaughtException(Thread, Throwable) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.ThreadBase
 
uncaughtException(Thread, Throwable) - Method in class org.apache.flink.runtime.util.FatalExitExceptionHandler
 
UnclosedBranchDescriptor(OptimizerNode, long) - Constructor for class org.apache.flink.optimizer.dag.OptimizerNode.UnclosedBranchDescriptor
Creates a new branching descriptor.
UNDEFINED() - Method in class org.apache.flink.api.scala.FlinkShell.ExecutionMode$
 
UndirectEdge() - Constructor for class org.apache.flink.examples.java.graph.ConnectedComponents.UndirectEdge
 
UnfinishedCoGroupOperation<L,R> - Class in org.apache.flink.api.scala
An unfinished coGroup operation that results from DataSet.coGroup The keys for the left and right side must be specified using first where and then equalTo.
UnfinishedCoGroupOperation(DataSet<L>, DataSet<R>, ClassTag<L>, ClassTag<R>) - Constructor for class org.apache.flink.api.scala.UnfinishedCoGroupOperation
 
UnfinishedJoinOperation<L,R> - Class in org.apache.flink.api.scala
An unfinished inner join operation that results from calling DataSet.join().
UnfinishedJoinOperation(DataSet<L>, DataSet<R>, JoinOperatorBase.JoinHint) - Constructor for class org.apache.flink.api.scala.UnfinishedJoinOperation
 
UnfinishedJoinOperationBase<L,R,O extends JoinFunctionAssigner<L,R>> - Class in org.apache.flink.api.scala
 
UnfinishedJoinOperationBase(DataSet<L>, DataSet<R>, JoinOperatorBase.JoinHint, JoinType) - Constructor for class org.apache.flink.api.scala.UnfinishedJoinOperationBase
 
UnfinishedKeyPairOperation<L,R,O> - Class in org.apache.flink.api.scala
This is for dealing with operations that require keys and use a fluent interface (join, and coGroup for now).
UnfinishedKeyPairOperation(DataSet<L>, DataSet<R>) - Constructor for class org.apache.flink.api.scala.UnfinishedKeyPairOperation
 
UnfinishedOuterJoinOperation<L,R> - Class in org.apache.flink.api.scala
An unfinished outer join operation that results from calling, e.g.
UnfinishedOuterJoinOperation(DataSet<L>, DataSet<R>, JoinOperatorBase.JoinHint, JoinType) - Constructor for class org.apache.flink.api.scala.UnfinishedOuterJoinOperation
 
unhandled(Object) - Static method in class org.apache.flink.mesos.runtime.clusterframework.MesosTaskManager
 
unhandled(Object) - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
unhandled(Object) - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
unhandled(Object) - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
unhandled(Object) - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
unhandled(Object) - Static method in class org.apache.flink.mesos.scheduler.Tasks
 
unhandled(Object) - Method in class org.apache.flink.runtime.jobmanager.JobManager
Handle unmatched messages with an exception.
unhandled(Object) - Method in class org.apache.flink.runtime.jobmanager.MemoryArchivist
Handle unmatched messages with an exception.
unhandled(Object) - Method in class org.apache.flink.runtime.taskmanager.TaskManager
Handle unmatched messages with an exception.
unhandled(Object) - Method in class org.apache.flink.yarn.ApplicationClient
Handle unmatched messages with an exception.
unhandled(Object) - Static method in class org.apache.flink.yarn.YarnTaskManager
 
UnilateralSortMerger<E> - Class in org.apache.flink.runtime.operators.sort
The UnilateralSortMerger is a full fledged sorter.
UnilateralSortMerger(MemoryManager, IOManager, MutableObjectIterator<E>, AbstractInvokable, TypeSerializerFactory<E>, TypeComparator<E>, double, int, float, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
 
UnilateralSortMerger(MemoryManager, IOManager, MutableObjectIterator<E>, AbstractInvokable, TypeSerializerFactory<E>, TypeComparator<E>, double, int, int, float, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
 
UnilateralSortMerger(MemoryManager, List<MemorySegment>, IOManager, MutableObjectIterator<E>, AbstractInvokable, TypeSerializerFactory<E>, TypeComparator<E>, int, int, float, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
 
UnilateralSortMerger(MemoryManager, IOManager, MutableObjectIterator<E>, AbstractInvokable, TypeSerializerFactory<E>, TypeComparator<E>, double, int, int, float, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
 
UnilateralSortMerger(MemoryManager, List<MemorySegment>, IOManager, MutableObjectIterator<E>, AbstractInvokable, TypeSerializerFactory<E>, TypeComparator<E>, int, int, float, boolean, boolean, boolean) - Constructor for class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
 
UnilateralSortMerger.ChannelWithBlockCount - Class in org.apache.flink.runtime.operators.sort
 
UnilateralSortMerger.CircularElement<E> - Class in org.apache.flink.runtime.operators.sort
Class representing buffers that circulate between the reading, sorting and spilling thread.
UnilateralSortMerger.CircularQueues<E> - Class in org.apache.flink.runtime.operators.sort
Collection of queues that are used for the communication between the threads.
UnilateralSortMerger.ReadingThread<E> - Class in org.apache.flink.runtime.operators.sort
The thread that consumes the input data and puts it into a buffer that will be sorted.
UnilateralSortMerger.SortingThread<E> - Class in org.apache.flink.runtime.operators.sort
The thread that sorts filled buffers.
UnilateralSortMerger.SpillingThread - Class in org.apache.flink.runtime.operators.sort
The thread that handles the spilling of intermediate results and sets up the merging.
UnilateralSortMerger.ThreadBase<E> - Class in org.apache.flink.runtime.operators.sort
Base class for all working threads in this sort-merger.
uninstall() - Method in class org.apache.flink.runtime.security.modules.HadoopModule
 
uninstall() - Method in class org.apache.flink.runtime.security.modules.JaasModule
 
uninstall() - Method in interface org.apache.flink.runtime.security.modules.SecurityModule
Uninstall the security module.
uninstall() - Method in class org.apache.flink.runtime.security.modules.ZooKeeperModule
 
UNION - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
Union<T> - Class in org.apache.flink.api.common.operators
This operator represents a Union between two inputs.
Union(BinaryOperatorInformation<T, T, T>, String) - Constructor for class org.apache.flink.api.common.operators.Union
Creates a new Union operator.
Union(Operator<T>, Operator<T>, String) - Constructor for class org.apache.flink.api.common.operators.Union
 
union(DataSet<T>) - Method in class org.apache.flink.api.java.DataSet
Creates a union of this DataSet with an other DataSet.
union(DataSet<T>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
union(DataSet<T>) - Method in class org.apache.flink.api.scala.DataSet
Creates a new DataSet containing the elements from both this DataSet and the other DataSet.
union(Seq<DataSet<T>>) - Method in class org.apache.flink.api.scala.ExecutionEnvironment
 
union(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.Graph
Performs union on the vertices and edges sets of the input graphs removing duplicate vertices but maintaining duplicate edges.
union(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.scala.Graph
Performs union on the vertices and edges sets of the input graphs removing duplicate vertices but maintaining duplicate edges.
union(DataStream<T>...) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Creates a new DataStream by merging DataStream outputs of the same type with each other.
union(Seq<DataStream<T>>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Creates a new DataStream by merging DataStream outputs of the same type with each other.
union(Table) - Method in class org.apache.flink.table.api.Table
Unions two Tables with duplicate records removed.
union(boolean) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
union(boolean, int) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
Union - Class in org.apache.flink.table.plan.logical
 
Union(LogicalNode, LogicalNode, boolean) - Constructor for class org.apache.flink.table.plan.logical.Union
 
Union$ - Class in org.apache.flink.table.plan.logical
 
Union$() - Constructor for class org.apache.flink.table.plan.logical.Union$
 
UNION_ALL - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
unionAll(Table) - Method in class org.apache.flink.table.api.Table
Unions two Tables.
unionFields(Record) - Method in class org.apache.flink.types.Record
Unions the other record's fields with this records fields.
UnionInputGate - Class in org.apache.flink.runtime.io.network.partition.consumer
Input gate wrapper to union the input from multiple input gates.
UnionInputGate(InputGate...) - Constructor for class org.apache.flink.runtime.io.network.partition.consumer.UnionInputGate
 
UnionIterator<T> - Class in org.apache.flink.util
 
UnionIterator() - Constructor for class org.apache.flink.util.UnionIterator
 
UnionOperator<T> - Class in org.apache.flink.api.java.operators
Java API operator for union of two data sets
UnionOperator(DataSet<T>, DataSet<T>, String) - Constructor for class org.apache.flink.api.java.operators.UnionOperator
Create an operator that produces the union of the two given data sets.
UnionParallelismAndForwardEnforcer - Class in org.apache.flink.optimizer.traversals
Enforces that all union nodes have the same parallelism as their successor (there must be only one!) and that the union node and its successor are connected by a forward ship strategy.
UnionParallelismAndForwardEnforcer() - Constructor for class org.apache.flink.optimizer.traversals.UnionParallelismAndForwardEnforcer
 
UnionSemanticProperties() - Constructor for class org.apache.flink.optimizer.dag.BinaryUnionNode.UnionSemanticProperties
 
UnionSerializerConfigSnapshot() - Constructor for class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
UnionSerializerConfigSnapshot(TypeSerializer<T1>, TypeSerializer<T2>) - Constructor for class org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializerConfigSnapshot
 
unionsStaticAndDynamicPath() - Method in class org.apache.flink.optimizer.plan.BinaryUnionPlanNode
 
UnionTransformation<T> - Class in org.apache.flink.streaming.api.transformations
This transformation represents a union of several input StreamTransformations.
UnionTransformation(List<StreamTransformation<T>>) - Constructor for class org.apache.flink.streaming.api.transformations.UnionTransformation
Creates a new UnionTransformation from the given input StreamTransformations.
UnionWithTempOperator<T> - Class in org.apache.flink.runtime.operators
 
UnionWithTempOperator() - Constructor for class org.apache.flink.runtime.operators.UnionWithTempOperator
 
uniqueFields - Variable in class org.apache.flink.optimizer.dag.OptimizerNode
 
UnitDescriptor(int, scala.reflect.macros.Context.universe) - Constructor for class org.apache.flink.api.scala.codegen.TypeDescriptors.UnitDescriptor
 
UnitSerializer - Class in org.apache.flink.api.scala.typeutils
 
UnitSerializer() - Constructor for class org.apache.flink.api.scala.typeutils.UnitSerializer
 
UnitTypeInfo - Class in org.apache.flink.api.scala.typeutils
 
UnitTypeInfo() - Constructor for class org.apache.flink.api.scala.typeutils.UnitTypeInfo
 
unjar(InputStream, File) - Method in class org.apache.flink.api.java.JarHelper
Given an InputStream on a jar file, unjars the contents into the given directory.
unjarDir(File, File) - Method in class org.apache.flink.api.java.JarHelper
Unjars a given jar file into a given directory.
UNKNOWN - Static variable in class org.apache.flink.optimizer.costs.Costs
 
UNKNOWN - Static variable in class org.apache.flink.runtime.clusterframework.types.ResourceProfile
 
UNKNOWN - Static variable in class org.apache.flink.runtime.util.EnvironmentInformation
 
UNKNOWN() - Method in class org.apache.flink.table.plan.stats.FlinkStatistic$
Represents a FlinkStatistic that knows nothing about a table
UNKNOWN() - Static method in class org.apache.flink.table.plan.stats.FlinkStatistic
Represents a FlinkStatistic that knows nothing about a table
UnknownFileHandler() - Constructor for class org.apache.flink.mesos.util.MesosArtifactServer.UnknownFileHandler
 
UnknownKeyOrNamespace - Exception in org.apache.flink.runtime.query.netty
Thrown if the KvState does not hold any state for the given key or namespace.
UnknownKvStateID - Exception in org.apache.flink.runtime.query.netty
Thrown if no KvState with the given ID cannot found by the server handler.
UnknownKvStateID(KvStateID) - Constructor for exception org.apache.flink.runtime.query.netty.UnknownKvStateID
 
UnknownKvStateLocation - Exception in org.apache.flink.runtime.query
Thrown if there is no KvStateLocation found for the requested registration name.
UnknownKvStateLocation(String) - Constructor for exception org.apache.flink.runtime.query.UnknownKvStateLocation
 
UnloadableDummyTypeSerializer<T> - Class in org.apache.flink.api.common.typeutils
Dummy TypeSerializer to avoid that data is lost when checkpointing again a serializer for which we encountered a ClassNotFoundException or InvalidClassException.
UnloadableDummyTypeSerializer(byte[]) - Constructor for class org.apache.flink.api.common.typeutils.UnloadableDummyTypeSerializer
 
UnmodifiableConfiguration - Class in org.apache.flink.configuration
Unmodifiable version of the Configuration class.
UnmodifiableConfiguration(Configuration) - Constructor for class org.apache.flink.configuration.UnmodifiableConfiguration
Creates a new UnmodifiableConfiguration, which holds a copy of the given configuration that cannot be altered.
unmonitorTarget(ResourceID) - Method in interface org.apache.flink.runtime.heartbeat.HeartbeatManager
Stops monitoring the heartbeat target with the associated resource ID.
unmonitorTarget(ResourceID) - Method in class org.apache.flink.runtime.heartbeat.HeartbeatManagerImpl
 
UNNEST - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The UNNEST operator.
UNNEST_WITH_ORDINALITY - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The UNNEST WITH ORDINALITY operator.
UnorderedStreamElementQueue - Class in org.apache.flink.streaming.api.operators.async.queue
Unordered implementation of the StreamElementQueue.
UnorderedStreamElementQueue(int, Executor, OperatorActions) - Constructor for class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
 
unorderedWait(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit, int) - Static method in class org.apache.flink.streaming.api.datastream.AsyncDataStream
Add an AsyncWaitOperator.
unorderedWait(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit) - Static method in class org.apache.flink.streaming.api.datastream.AsyncDataStream
Add an AsyncWaitOperator.
unorderedWait(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit, int, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.scala.AsyncDataStream$
Apply an asynchronous function on the input data stream.
unorderedWait(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.scala.AsyncDataStream$
Apply an asynchronous function on the input data stream.
unorderedWait(DataStream<IN>, long, TimeUnit, int, Function2<IN, AsyncCollector<OUT>, BoxedUnit>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.scala.AsyncDataStream$
Apply an asynchronous function on the input data stream.
unorderedWait(DataStream<IN>, long, TimeUnit, Function2<IN, AsyncCollector<OUT>, BoxedUnit>, TypeInformation<OUT>) - Method in class org.apache.flink.streaming.api.scala.AsyncDataStream$
Apply an asynchronous function on the input data stream.
unorderedWait(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit, int, TypeInformation<OUT>) - Static method in class org.apache.flink.streaming.api.scala.AsyncDataStream
Apply an asynchronous function on the input data stream.
unorderedWait(DataStream<IN>, AsyncFunction<IN, OUT>, long, TimeUnit, TypeInformation<OUT>) - Static method in class org.apache.flink.streaming.api.scala.AsyncDataStream
Apply an asynchronous function on the input data stream.
unorderedWait(DataStream<IN>, long, TimeUnit, int, Function2<IN, AsyncCollector<OUT>, BoxedUnit>, TypeInformation<OUT>) - Static method in class org.apache.flink.streaming.api.scala.AsyncDataStream
Apply an asynchronous function on the input data stream.
unorderedWait(DataStream<IN>, long, TimeUnit, Function2<IN, AsyncCollector<OUT>, BoxedUnit>, TypeInformation<OUT>) - Static method in class org.apache.flink.streaming.api.scala.AsyncDataStream
Apply an asynchronous function on the input data stream.
unparse(SqlWriter, SqlCall, int, int) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
unparse(SqlWriter, SqlCall, int, int) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
unparse(SqlWriter, SqlCall, int, int) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
unparse(SqlWriter, SqlCall, int, int) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
unparseListClause(SqlWriter, SqlNode) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
unparseListClause(SqlWriter, SqlNode, SqlKind) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
unparseListClause(SqlWriter, SqlNode) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
unparseListClause(SqlWriter, SqlNode, SqlKind) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
unparseListClause(SqlWriter, SqlNode) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
unparseListClause(SqlWriter, SqlNode, SqlKind) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
unparseListClause(SqlWriter, SqlNode) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
unparseListClause(SqlWriter, SqlNode, SqlKind) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
unregister(Metric, String, AbstractMetricGroup) - Method in class org.apache.flink.runtime.metrics.MetricRegistry
Un-registers the given Metric with this registry.
unregisterAll() - Method in class org.apache.flink.runtime.query.TaskKvStateRegistry
Unregisters all registered KvState instances from the KvStateRegistry.
unregisterAllTaskManagers() - Method in class org.apache.flink.runtime.instance.InstanceManager
Unregisters all currently registered TaskManagers from the InstanceManager.
unregisterAllTimeouts() - Method in class org.apache.flink.runtime.taskexecutor.slot.TimerService
Unregister all timeouts.
unregisterChannelToBeRemovedAtShudown(FileIOChannel.ID) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Removes a channel from the list of channels that are to be removed at shutdown.
unregisterClosable(C) - Method in class org.apache.flink.util.AbstractCloseableRegistry
Removes a Closeable from the registry.
UnregisteredMetricsGroup - Class in org.apache.flink.metrics.groups
A special MetricGroup that does not register any metrics at the metrics registry and any reporters.
UnregisteredMetricsGroup() - Constructor for class org.apache.flink.metrics.groups.UnregisteredMetricsGroup
 
UnRegisterInfoMessageListener - Class in org.apache.flink.runtime.clusterframework.messages
This message signals to the resource master to register the sender as an info message listener.
unRegisterInfoMessageListener(String) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
Unregisters an info message listener
unRegisterInfoMessageListener(String) - Method in interface org.apache.flink.runtime.resourcemanager.ResourceManagerGateway
Unregisters an infoMessage listener
unregisterJob(JobID) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
 
unregisterJob(JobID) - Method in class org.apache.flink.runtime.execution.librarycache.FallbackLibraryCacheManager
 
unregisterJob(JobID) - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
Unregisters a job from the library cache manager.
unregisterKvState(JobID, JobVertexID, KeyGroupRange, String, KvStateID) - Method in class org.apache.flink.runtime.query.KvStateRegistry
Unregisters the KvState instance identified by the given KvStateID.
unregisterListener() - Method in class org.apache.flink.runtime.query.KvStateRegistry
Unregisters the listener with the registry
unregisterOpenChannelToBeRemovedAtShudown(FileIOChannel) - Method in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
Removes a channel reader/writer from the list of channels that are to be removed at shutdown.
unregisterReference(SharedStateRegistryKey) - Method in class org.apache.flink.runtime.state.SharedStateRegistry
Releases one reference to the given shared state in the registry.
unregisterSlotRequest(AllocationID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Cancels and removes a pending slot request with the given allocation id.
unregisterTask(JobID, ExecutionAttemptID) - Method in class org.apache.flink.runtime.execution.librarycache.BlobLibraryCacheManager
 
unregisterTask(JobID, ExecutionAttemptID) - Method in class org.apache.flink.runtime.execution.librarycache.FallbackLibraryCacheManager
 
unregisterTask(JobID, ExecutionAttemptID) - Method in interface org.apache.flink.runtime.execution.librarycache.LibraryCacheManager
Unregisters a job from the library cache manager.
unregisterTask(Task) - Method in class org.apache.flink.runtime.io.network.NetworkEnvironment
 
unregisterTaskManager(InstanceID, boolean) - Method in class org.apache.flink.runtime.instance.InstanceManager
Unregisters the TaskManager with the given instance id.
unregisterTaskManager(InstanceID) - Method in class org.apache.flink.runtime.resourcemanager.slotmanager.SlotManager
Unregisters the task manager identified by the given instance id and its associated slots from the slot manager.
unregisterTimeout(K) - Method in class org.apache.flink.runtime.taskexecutor.slot.TimerService
Unregister the timeout for the given key.
unregisterWriter(ResultPartitionWriter) - Method in class org.apache.flink.runtime.io.network.TaskEventDispatcher
 
UnresolvedAlias - Class in org.apache.flink.table.expressions
 
UnresolvedAlias(Expression) - Constructor for class org.apache.flink.table.expressions.UnresolvedAlias
 
UnresolvedAlias$ - Class in org.apache.flink.table.expressions
 
UnresolvedAlias$() - Constructor for class org.apache.flink.table.expressions.UnresolvedAlias$
 
UnresolvedException - Exception in org.apache.flink.table.api
Exception for unwanted method calling on unresolved expression.
UnresolvedException(String) - Constructor for exception org.apache.flink.table.api.UnresolvedException
 
UnresolvedException$ - Class in org.apache.flink.table.api
 
UnresolvedException$() - Constructor for class org.apache.flink.table.api.UnresolvedException$
 
UnresolvedFieldExpression(Symbol) - Constructor for class org.apache.flink.table.api.scala.ImplicitExpressionConversions.UnresolvedFieldExpression
 
UnresolvedFieldReference - Class in org.apache.flink.table.expressions
 
UnresolvedFieldReference(String) - Constructor for class org.apache.flink.table.expressions.UnresolvedFieldReference
 
UnresolvedFieldReference$ - Class in org.apache.flink.table.expressions
 
UnresolvedFieldReference$() - Constructor for class org.apache.flink.table.expressions.UnresolvedFieldReference$
 
unresolvedHostAndPortToNormalizedString(String, int) - Static method in class org.apache.flink.util.NetUtils
Returns a valid address for Akka.
unresolvedHostToNormalizedString(String) - Static method in class org.apache.flink.util.NetUtils
Returns an address in a normalized format for Akka.
UnresolvedOverCall - Class in org.apache.flink.table.expressions
Over call with unresolved alias for over window.
UnresolvedOverCall(Expression, Expression) - Constructor for class org.apache.flink.table.expressions.UnresolvedOverCall
 
UnresolvedOverCall$ - Class in org.apache.flink.table.expressions
 
UnresolvedOverCall$() - Constructor for class org.apache.flink.table.expressions.UnresolvedOverCall$
 
UNSAFE - Static variable in class org.apache.flink.core.memory.MemorySegment
The unsafe handle for transparent memory copied (heap / off-heap)
UNSAFE - Static variable in class org.apache.flink.core.memory.MemoryUtils
The "unsafe", which can be used to perform native memory accesses.
unset() - Method in class org.apache.flink.graph.utils.proxy.OptionalBoolean
Reset to the unset state.
unsetAsContext() - Method in class org.apache.flink.client.program.PreviewPlanEnvironment
 
unsetAsContext() - Static method in class org.apache.flink.streaming.util.TestStreamEnvironment
Resets the streaming context environment to null.
unsetAsContext() - Static method in class org.apache.flink.test.util.CollectionTestEnvironment
 
unsetAsContext() - Static method in class org.apache.flink.test.util.TestEnvironment
 
UnsortedGrouping<T> - Class in org.apache.flink.api.java.operators
 
UnsortedGrouping(DataSet<T>, Keys<T>) - Constructor for class org.apache.flink.api.java.operators.UnsortedGrouping
 
unsplittable - Variable in class org.apache.flink.api.common.io.FileInputFormat
Some file input formats are not splittable on a block level (avro, deflate) Therefore, the FileInputFormat can only read whole files.
unsubscribe(EventListener<TaskEvent>, Class<? extends TaskEvent>) - Method in class org.apache.flink.runtime.io.network.api.TaskEventHandler
 
UnsupportedAggregationTypeException - Exception in org.apache.flink.api.java.aggregation
 
UnsupportedAggregationTypeException(String) - Constructor for exception org.apache.flink.api.java.aggregation.UnsupportedAggregationTypeException
 
UnsupportedDescriptor(int, scala.reflect.macros.Context.universe, Seq<String>) - Constructor for class org.apache.flink.api.scala.codegen.TypeDescriptors.UnsupportedDescriptor
 
unsynchronizedGetNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.consumer.RemoteInputChannel
 
unsynchronizedGetNumberOfQueuedBuffers() - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
Makes a best effort to get the current size of the queue.
unwrap(Class<T>) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
unwrap() - Method in exception org.apache.flink.util.WrappingRuntimeException
Recursively unwraps this WrappingRuntimeException and its causes, getting the first non wrapping exception.
update(T) - Method in interface org.apache.flink.api.common.state.ValueState
Updates the operator state accessible by ValueState.value() to the given value.
update(V) - Method in class org.apache.flink.contrib.streaming.state.RocksDBValueState
 
update(long) - Method in class org.apache.flink.dropwizard.metrics.DropwizardHistogramWrapper
 
update(long) - Method in class org.apache.flink.dropwizard.metrics.FlinkHistogramWrapper
 
Update() - Constructor for class org.apache.flink.examples.java.ml.LinearRegression.Update
 
update(long) - Method in interface org.apache.flink.metrics.Histogram
Update the histogram with the given value.
update() - Method in class org.apache.flink.metrics.MeterView
 
update() - Method in interface org.apache.flink.metrics.View
This method will be called regularly to update the metric.
update(int, int, double) - Method in class org.apache.flink.ml.math.DenseMatrix
Element wise update function
update(int, double) - Method in class org.apache.flink.ml.math.DenseVector
Updates the element at the given index with the provided value
update(int, int, double) - Method in interface org.apache.flink.ml.math.Matrix
Element wise update function
update(int, int, double) - Method in class org.apache.flink.ml.math.SparseMatrix
Element wise update function
update(int, double) - Method in class org.apache.flink.ml.math.SparseVector
Updates the element at the given index with the provided value
update(int, double) - Method in interface org.apache.flink.ml.math.Vector
Updates the element at the given index with the provided value
update(V) - Method in class org.apache.flink.runtime.state.heap.HeapValueState
 
update() - Method in class org.apache.flink.runtime.webmonitor.metrics.MetricFetcher
This method can be used to signal this MetricFetcher that the metrics are still in use and should be updated.
UPDATE_INTERVAL_SECONDS - Static variable in interface org.apache.flink.metrics.View
The interval in which metrics are updated
UpdateAccumulator() - Constructor for class org.apache.flink.examples.java.ml.LinearRegression.UpdateAccumulator
 
updateAccumulators(AccumulatorSnapshot) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Updates the accumulators during the runtime of a job.
UpdateAsRetractionTrait - Class in org.apache.flink.table.plan.nodes.datastream
Tracks if a RelNode needs to send update and delete changes as retraction messages.
UpdateAsRetractionTrait() - Constructor for class org.apache.flink.table.plan.nodes.datastream.UpdateAsRetractionTrait
 
UpdateAsRetractionTrait(boolean) - Constructor for class org.apache.flink.table.plan.nodes.datastream.UpdateAsRetractionTrait
 
UpdateAsRetractionTrait$ - Class in org.apache.flink.table.plan.nodes.datastream
 
UpdateAsRetractionTrait$() - Constructor for class org.apache.flink.table.plan.nodes.datastream.UpdateAsRetractionTrait$
 
UpdateAsRetractionTraitDef - Class in org.apache.flink.table.plan.nodes.datastream
Definition of the UpdateAsRetractionTrait.
UpdateAsRetractionTraitDef() - Constructor for class org.apache.flink.table.plan.nodes.datastream.UpdateAsRetractionTraitDef
 
UpdateAsRetractionTraitDef$ - Class in org.apache.flink.table.plan.nodes.datastream
 
UpdateAsRetractionTraitDef$() - Constructor for class org.apache.flink.table.plan.nodes.datastream.UpdateAsRetractionTraitDef$
 
updateBinaryRepresenation() - Method in class org.apache.flink.types.Record
Updates the binary representation of the data, such that it reflects the state of the currently stored fields.
updateCoLocationGroup(CoLocationGroup) - Method in class org.apache.flink.runtime.jobgraph.JobVertex
 
updateCondition() - Method in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
Condition for writing the contents of tupleList and clearing it.
updateCondition() - Method in class org.apache.flink.streaming.api.functions.sink.WriteSinkFunctionByMillis
 
updateFactors(int, DataSet<Tuple2<Object, double[][]>>, DataSet<Tuple2<Object, ALS.OutBlockInformation>>, DataSet<Tuple2<Object, ALS.InBlockInformation>>, int, double, Partitioner<Object>) - Method in class org.apache.flink.ml.recommendation.ALS$
Calculates a single half step of the ALS optimization.
updateFactors(int, DataSet<Tuple2<Object, double[][]>>, DataSet<Tuple2<Object, ALS.OutBlockInformation>>, DataSet<Tuple2<Object, ALS.InBlockInformation>>, int, double, Partitioner<Object>) - Static method in class org.apache.flink.ml.recommendation.ALS
Calculates a single half step of the ALS optimization.
updateGlobalAggregatesAndReset(String[], Value[]) - Method in class org.apache.flink.runtime.iterative.task.RuntimeAggregatorRegistry
 
updateInputChannel(InputChannelDeploymentDescriptor) - Method in class org.apache.flink.runtime.io.network.partition.consumer.SingleInputGate
 
updateMatch(BT) - Method in class org.apache.flink.runtime.operators.hash.AbstractHashTableProber
 
updateMatch(T) - Method in class org.apache.flink.runtime.operators.hash.CompactingHashTable.HashTableProber
 
updateMatch(T) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.HashTableProber
This method can be called after getMatchFor returned a match.
UpdatePartitionInfo() - Constructor for class org.apache.flink.runtime.messages.TaskMessages.UpdatePartitionInfo
 
updatePartitions(ExecutionAttemptID, Iterable<PartitionInfo>, Time) - Method in class org.apache.flink.runtime.jobmanager.slots.ActorTaskManagerGateway
 
updatePartitions(ExecutionAttemptID, Iterable<PartitionInfo>, Time) - Method in interface org.apache.flink.runtime.jobmanager.slots.TaskManagerGateway
Update the task where the given partitions can be found.
updatePartitions(ExecutionAttemptID, Iterable<PartitionInfo>, Time) - Method in class org.apache.flink.runtime.jobmaster.RpcTaskManagerGateway
 
updatePartitions(ExecutionAttemptID, Iterable<PartitionInfo>) - Method in class org.apache.flink.runtime.taskexecutor.TaskExecutor
 
updatePartitions(ExecutionAttemptID, Iterable<PartitionInfo>, Time) - Method in interface org.apache.flink.runtime.taskexecutor.TaskExecutorGateway
Update the task where the given partitions can be found.
updatePropertiesWithUniqueSets(Set<FieldSet>) - Method in class org.apache.flink.optimizer.plan.PlanNode
 
UPDATES_AS_RETRACTION_INSTANCE() - Method in class org.apache.flink.table.plan.rules.datastream.DataStreamRetractionRules$
Rule instance that checks if DataStreamRel nodes need to ship updates as retractions.
UPDATES_AS_RETRACTION_INSTANCE() - Static method in class org.apache.flink.table.plan.rules.datastream.DataStreamRetractionRules
Rule instance that checks if DataStreamRel nodes need to ship updates as retractions.
updateState(TaskExecutionState) - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
Updates the state of one of the ExecutionVertex's Execution attempts.
updateStatistics(Buffer) - Method in class org.apache.flink.runtime.io.network.partition.ResultSubpartition
 
updateTableEntryWithReduce(T) - Method in class org.apache.flink.runtime.operators.hash.InPlaceMutableHashTable.ReduceFacade
Looks up the table entry that has the same key as the given record, and updates it by performing a reduce step.
updateTaskExecutionState(UUID, TaskExecutionState) - Method in class org.apache.flink.runtime.jobmaster.JobMaster
Updates the task execution state for a given task.
updateTaskExecutionState(UUID, TaskExecutionState) - Method in interface org.apache.flink.runtime.jobmaster.JobMasterGateway
Updates the task execution state for a given task.
UpdateTaskExecutionState(TaskExecutionState) - Constructor for class org.apache.flink.runtime.messages.TaskMessages.UpdateTaskExecutionState
 
updateTaskExecutionState(TaskExecutionState) - Method in class org.apache.flink.runtime.taskmanager.ActorGatewayTaskManagerActions
 
updateTaskExecutionState(TaskExecutionState) - Method in interface org.apache.flink.runtime.taskmanager.TaskManagerActions
Notifies the task manager about the task execution state update.
UpdateTaskExecutionState$() - Constructor for class org.apache.flink.runtime.messages.TaskMessages.UpdateTaskExecutionState$
 
UpdateTaskMultiplePartitionInfos(ExecutionAttemptID, Iterable<PartitionInfo>) - Constructor for class org.apache.flink.runtime.messages.TaskMessages.UpdateTaskMultiplePartitionInfos
 
UpdateTaskMultiplePartitionInfos$() - Constructor for class org.apache.flink.runtime.messages.TaskMessages.UpdateTaskMultiplePartitionInfos$
 
UpdateTaskSinglePartitionInfo(ExecutionAttemptID, IntermediateDataSetID, InputChannelDeploymentDescriptor) - Constructor for class org.apache.flink.runtime.messages.TaskMessages.UpdateTaskSinglePartitionInfo
 
UpdateTaskSinglePartitionInfo$() - Constructor for class org.apache.flink.runtime.messages.TaskMessages.UpdateTaskSinglePartitionInfo$
 
updateVertex(Vertex<Long, Double>, MessageIterator<Double>) - Method in class org.apache.flink.graph.examples.IncrementalSSSP.VertexDistanceUpdater
 
updateVertex(Vertex<K, Double>, MessageIterator<Double>) - Method in class org.apache.flink.graph.examples.PageRank.VertexRankUpdater
 
updateVertex(Vertex<K, Tuple2<Long, Double>>, MessageIterator<Tuple2<Long, Double>>) - Method in class org.apache.flink.graph.library.CommunityDetection.VertexLabelUpdater
 
updateVertex(Vertex<K, VV>, MessageIterator<VV>) - Method in class org.apache.flink.graph.library.ConnectedComponents.CCUpdater
 
updateVertex(Vertex<K, VV>, MessageIterator<VV>) - Method in class org.apache.flink.graph.library.LabelPropagation.UpdateVertexLabel
 
updateVertex(Vertex<K, Double>, MessageIterator<Double>) - Method in class org.apache.flink.graph.library.SingleSourceShortestPaths.VertexDistanceUpdater
 
updateVertex(Vertex<K, VV>, MessageIterator<Message>) - Method in class org.apache.flink.graph.spargel.GatherFunction
This method is invoked once per vertex per superstep.
UpdateVertexLabel() - Constructor for class org.apache.flink.graph.library.LabelPropagation.UpdateVertexLabel
 
uploadJarFiles(ActorGateway, FiniteDuration, Configuration, List<Path>) - Static method in class org.apache.flink.runtime.blob.BlobClient
Retrieves the BlobServer address from the JobManager and uploads the JAR files to it.
uploadJarFiles(InetSocketAddress, Configuration, List<Path>) - Static method in class org.apache.flink.runtime.blob.BlobClient
Uploads the JAR files to a BlobServer at the given address.
uploadRequiredJarFiles(InetSocketAddress, Configuration) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Uploads the previously added user jar file to the job manager through the job manager's BLOB server.
uploadUserJars(ActorGateway, FiniteDuration, Configuration) - Method in class org.apache.flink.runtime.jobgraph.JobGraph
Uploads the previously added user JAR files to the job manager through the job manager's BLOB server.
UPPER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
Upper - Class in org.apache.flink.table.expressions
Returns str with all characters changed to uppercase.
Upper(Expression) - Constructor for class org.apache.flink.table.expressions.Upper
 
Upper$ - Class in org.apache.flink.table.expressions
 
Upper$() - Constructor for class org.apache.flink.table.expressions.Upper$
 
UPPER_BOUND_MAX_PARALLELISM - Static variable in class org.apache.flink.runtime.state.KeyGroupRangeAssignment
The (inclusive) upper bound for max parallelism
UPPER_BOUND_MAX_PARALLELISM - Static variable in class org.apache.flink.streaming.api.graph.StreamGraphGenerator
 
upperCase() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Returns all of the characters in a string in upper case using the rules of the default locale.
upperPart - Variable in class org.apache.flink.util.AbstractID
The upper part of the actual ID
UpsertStreamTableSink<T> - Interface in org.apache.flink.table.sinks
Defines an external TableSink to emit a streaming Table with insert, update, and delete changes.
UpTimeGauge - Class in org.apache.flink.runtime.executiongraph.metrics
A gauge that returns (in milliseconds) how long a job has been running.
UpTimeGauge(ExecutionGraph) - Constructor for class org.apache.flink.runtime.executiongraph.metrics.UpTimeGauge
 
uri(URL, boolean) - Static method in class org.apache.flink.mesos.Utils
Construct a Mesos URI.
uri(MesosArtifactResolver, ContainerSpecification.Artifact) - Static method in class org.apache.flink.mesos.Utils
Construct a Mesos URI.
URL - Class in org.apache.flink.contrib.tweetinputformat.model.tweet.entities
Represents URLs included in the text of a Tweet or within textual fields of a UserMention object.
URL() - Constructor for class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.URL
 
USE_LARGE_RECORD_HANDLER_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Whether to use the LargeRecordHandler when spilling.
useDoubleMultiplication(RelDataType, RelDataType) - Static method in class org.apache.flink.table.calcite.FlinkTypeFactory
 
useKeySelector() - Method in class org.apache.flink.api.java.operators.SortPartitionOperator
Returns whether using key selector or not.
useMetrics - Variable in class org.apache.flink.streaming.connectors.kafka.internals.AbstractFetcher
Flag whether to register metrics for the fetcher
UseQuadTree$() - Constructor for class org.apache.flink.ml.nn.KNN.UseQuadTree$
 
USER - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The USER function.
User() - Constructor for class org.apache.flink.examples.java.misc.CollectionExecutionExample.User
 
User(int, String) - Constructor for class org.apache.flink.examples.java.misc.CollectionExecutionExample.User
 
user() - Method in class org.apache.flink.ml.recommendation.ALS.Rating
 
user() - Method in class org.apache.flink.table.examples.scala.StreamSQLExample.Order
 
user() - Method in class org.apache.flink.table.examples.scala.StreamTableExample.Order
 
USER_FACTORS_FILE() - Method in class org.apache.flink.ml.recommendation.ALS$
 
USER_FACTORS_FILE() - Static method in class org.apache.flink.ml.recommendation.ALS
 
USER_SONG_TRIPLETS - Static variable in class org.apache.flink.graph.examples.data.MusicProfilesData
 
userCodeClassLoader - Variable in class org.apache.flink.client.program.ContextEnvironment
 
userCodeClassLoader - Variable in class org.apache.flink.runtime.operators.chaining.ChainedDriver
 
userCodeClassLoader - Variable in class org.apache.flink.runtime.state.AbstractKeyedStateBackend
 
userCodeClassLoader - Variable in class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.AbstractOperatorBackendStateMetaInfoReader
 
UserCodeClassWrapper<T> - Class in org.apache.flink.api.common.operators.util
This holds a class containing user defined code.
UserCodeClassWrapper(Class<? extends T>) - Constructor for class org.apache.flink.api.common.operators.util.UserCodeClassWrapper
 
UserCodeObjectWrapper<T> - Class in org.apache.flink.api.common.operators.util
This holds an actual object containing user defined code.
UserCodeObjectWrapper(T) - Constructor for class org.apache.flink.api.common.operators.util.UserCodeObjectWrapper
 
UserCodeWrapper<T> - Interface in org.apache.flink.api.common.operators.util
UDf operators can have either a class or an object containing the user code, this is the common interface to access them.
userConfiguration() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
userDefinedAggFunctionConstructor(AggregateFunction<T, ACC>, TypeInformation<T>) - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionConversions
 
UserDefinedFunction - Class in org.apache.flink.table.functions
Base class for all user-defined functions such as scalar functions, table functions, or aggregation functions.
UserDefinedFunction() - Constructor for class org.apache.flink.table.functions.UserDefinedFunction
 
UserDefinedFunctionUtils - Class in org.apache.flink.table.functions.utils
 
UserDefinedFunctionUtils() - Constructor for class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils
 
UserDefinedFunctionUtils$ - Class in org.apache.flink.table.functions.utils
 
UserDefinedFunctionUtils$() - Constructor for class org.apache.flink.table.functions.utils.UserDefinedFunctionUtils$
 
userFactors() - Method in class org.apache.flink.ml.recommendation.ALS.BlockedFactorization
 
userFactors() - Method in class org.apache.flink.ml.recommendation.ALS.Factorization
 
userFunction - Variable in class org.apache.flink.api.common.operators.AbstractUdfOperator
The object or class containing the user function.
userFunction - Variable in class org.apache.flink.streaming.api.operators.AbstractUdfStreamOperator
The user function.
userId - Variable in class org.apache.flink.examples.java.misc.CollectionExecutionExample.EMail
 
userIdentifier - Variable in class org.apache.flink.examples.java.misc.CollectionExecutionExample.User
 
UserMention - Class in org.apache.flink.contrib.tweetinputformat.model.tweet.entities
Represents other Twitter users mentioned in the text of the Tweet.
UserMention() - Constructor for class org.apache.flink.contrib.tweetinputformat.model.tweet.entities.UserMention
 
userObjectStatePrimitiveHandler(Object) - Method in class org.apache.flink.contrib.tweetinputformat.io.TweetHandler
 
Users - Class in org.apache.flink.contrib.tweetinputformat.model.User
Users can be anyone or anything.
Users() - Constructor for class org.apache.flink.contrib.tweetinputformat.model.User.Users
 
usesConvergenceCriterion() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
usesImplicitConvergenceCriterion() - Method in class org.apache.flink.runtime.operators.util.TaskConfig
 
useSingleActorSystem() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
usesUDF - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
useTicketCache() - Method in class org.apache.flink.runtime.security.SecurityUtils.SecurityConfiguration
 
Util - Class in org.apache.flink.graph.drivers.parameter
Utility methods for parsing command-line arguments.
Utils - Class in org.apache.flink.api.java
Utility class that contains helper methods to work with Java APIs.
Utils - Class in org.apache.flink.mesos
 
Utils() - Constructor for class org.apache.flink.mesos.Utils
 
Utils - Class in org.apache.flink.optimizer.util
Utility class that contains helper methods for optimizer.
Utils - Class in org.apache.flink.yarn
Utility class that provides helper methods to work with Apache Hadoop YARN.
Utils.ChecksumHashCode - Class in org.apache.flink.api.java
 
Utils.ChecksumHashCodeHelper<T> - Class in org.apache.flink.api.java
 
Utils.CollectHelper<T> - Class in org.apache.flink.api.java
Utility sink function that collects elements into an accumulator, from which it they can be retrieved by the client.
Utils.CountHelper<T> - Class in org.apache.flink.api.java
Utility sink function that counts elements and writes the count into an accumulator, from which it can be retrieved by the client.
UtilSinkJoinOpDescriptor - Class in org.apache.flink.optimizer.operators
 
UtilSinkJoinOpDescriptor() - Constructor for class org.apache.flink.optimizer.operators.UtilSinkJoinOpDescriptor
 

V

V1 - Static variable in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Edge
 
V1 - Static variable in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.EdgeWithDegrees
 
V1 - Static variable in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Triad
 
v1() - Method in class org.apache.flink.examples.scala.graph.EnumTriangles.Edge
 
v1() - Method in class org.apache.flink.examples.scala.graph.EnumTriangles.Triad
 
V1 - Static variable in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
 
V1 - Static variable in class org.apache.flink.graph.library.TriangleEnumerator.Triad
 
V2 - Static variable in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Edge
 
V2 - Static variable in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.EdgeWithDegrees
 
V2 - Static variable in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Triad
 
v2() - Method in class org.apache.flink.examples.scala.graph.EnumTriangles.Edge
 
v2() - Method in class org.apache.flink.examples.scala.graph.EnumTriangles.Triad
 
V2 - Static variable in class org.apache.flink.graph.library.TriangleEnumerator.EdgeWithDegrees
 
V2 - Static variable in class org.apache.flink.graph.library.TriangleEnumerator.Triad
 
V3 - Static variable in class org.apache.flink.examples.java.graph.util.EnumTrianglesDataTypes.Triad
 
v3() - Method in class org.apache.flink.examples.scala.graph.EnumTriangles.Triad
 
V3 - Static variable in class org.apache.flink.graph.library.TriangleEnumerator.Triad
 
VAL_EDGE_TO_BE_REMOVED - Static variable in class org.apache.flink.graph.examples.data.IncrementalSSSPData
 
valid() - Static method in class org.apache.flink.table.api.CurrentRange
 
valid() - Static method in class org.apache.flink.table.api.CurrentRow
 
valid() - Static method in class org.apache.flink.table.api.UnboundedRange
 
valid() - Static method in class org.apache.flink.table.api.UnboundedRow
 
valid() - Static method in class org.apache.flink.table.expressions.Abs
 
valid() - Static method in class org.apache.flink.table.expressions.Acos
 
valid() - Static method in class org.apache.flink.table.expressions.AggFunctionCall
 
valid() - Static method in class org.apache.flink.table.expressions.Alias
 
valid() - Static method in class org.apache.flink.table.expressions.And
 
valid() - Static method in class org.apache.flink.table.expressions.ArrayCardinality
 
valid() - Static method in class org.apache.flink.table.expressions.ArrayConstructor
 
valid() - Static method in class org.apache.flink.table.expressions.ArrayElement
 
valid() - Static method in class org.apache.flink.table.expressions.ArrayElementAt
 
valid() - Static method in class org.apache.flink.table.expressions.Asc
 
valid() - Static method in class org.apache.flink.table.expressions.Asin
 
valid() - Static method in class org.apache.flink.table.expressions.Atan
 
valid() - Static method in class org.apache.flink.table.expressions.Avg
 
valid() - Static method in class org.apache.flink.table.expressions.Call
 
valid() - Static method in class org.apache.flink.table.expressions.Cast
 
valid() - Static method in class org.apache.flink.table.expressions.Ceil
 
valid() - Static method in class org.apache.flink.table.expressions.CharLength
 
valid() - Static method in class org.apache.flink.table.expressions.Cos
 
valid() - Static method in class org.apache.flink.table.expressions.Cot
 
valid() - Static method in class org.apache.flink.table.expressions.Count
 
valid() - Static method in class org.apache.flink.table.expressions.CurrentDate
 
valid() - Static method in class org.apache.flink.table.expressions.CurrentTime
 
valid() - Static method in class org.apache.flink.table.expressions.CurrentTimestamp
 
valid() - Static method in class org.apache.flink.table.expressions.Degrees
 
valid() - Static method in class org.apache.flink.table.expressions.Desc
 
valid() - Static method in class org.apache.flink.table.expressions.Div
 
valid() - Static method in class org.apache.flink.table.expressions.EqualTo
 
valid() - Static method in class org.apache.flink.table.expressions.Exp
 
valid() - Method in class org.apache.flink.table.expressions.Expression
One pass validation of the expression tree in post order.
valid() - Static method in class org.apache.flink.table.expressions.Extract
 
valid() - Static method in class org.apache.flink.table.expressions.Flattening
 
valid() - Static method in class org.apache.flink.table.expressions.Floor
 
valid() - Static method in class org.apache.flink.table.expressions.GetCompositeField
 
valid() - Static method in class org.apache.flink.table.expressions.GreaterThan
 
valid() - Static method in class org.apache.flink.table.expressions.GreaterThanOrEqual
 
valid() - Static method in class org.apache.flink.table.expressions.If
 
valid() - Static method in class org.apache.flink.table.expressions.InitCap
 
valid() - Static method in class org.apache.flink.table.expressions.IsFalse
 
valid() - Static method in class org.apache.flink.table.expressions.IsNotFalse
 
valid() - Static method in class org.apache.flink.table.expressions.IsNotNull
 
valid() - Static method in class org.apache.flink.table.expressions.IsNotTrue
 
valid() - Static method in class org.apache.flink.table.expressions.IsNull
 
valid() - Static method in class org.apache.flink.table.expressions.IsTrue
 
valid() - Static method in class org.apache.flink.table.expressions.LessThan
 
valid() - Static method in class org.apache.flink.table.expressions.LessThanOrEqual
 
valid() - Static method in class org.apache.flink.table.expressions.Like
 
valid() - Static method in class org.apache.flink.table.expressions.Literal
 
valid() - Static method in class org.apache.flink.table.expressions.Ln
 
valid() - Static method in class org.apache.flink.table.expressions.LocalTime
 
valid() - Static method in class org.apache.flink.table.expressions.LocalTimestamp
 
valid() - Static method in class org.apache.flink.table.expressions.Log10
 
valid() - Static method in class org.apache.flink.table.expressions.Lower
 
valid() - Static method in class org.apache.flink.table.expressions.Max
 
valid() - Static method in class org.apache.flink.table.expressions.Min
 
valid() - Static method in class org.apache.flink.table.expressions.Minus
 
valid() - Static method in class org.apache.flink.table.expressions.Mod
 
valid() - Static method in class org.apache.flink.table.expressions.Mul
 
valid() - Static method in class org.apache.flink.table.expressions.Not
 
valid() - Static method in class org.apache.flink.table.expressions.NotEqualTo
 
valid() - Static method in class org.apache.flink.table.expressions.Null
 
valid() - Static method in class org.apache.flink.table.expressions.Or
 
valid() - Static method in class org.apache.flink.table.expressions.OverCall
 
valid() - Static method in class org.apache.flink.table.expressions.Overlay
 
valid() - Static method in class org.apache.flink.table.expressions.Pi
 
valid() - Static method in class org.apache.flink.table.expressions.Plus
 
valid() - Static method in class org.apache.flink.table.expressions.Position
 
valid() - Static method in class org.apache.flink.table.expressions.Power
 
valid() - Static method in class org.apache.flink.table.expressions.ProctimeAttribute
 
valid() - Static method in class org.apache.flink.table.expressions.Quarter
 
valid() - Static method in class org.apache.flink.table.expressions.Radians
 
valid() - Static method in class org.apache.flink.table.expressions.ResolvedFieldReference
 
valid() - Static method in class org.apache.flink.table.expressions.Round
 
valid() - Static method in class org.apache.flink.table.expressions.RowtimeAttribute
 
valid() - Static method in class org.apache.flink.table.expressions.ScalarFunctionCall
 
valid() - Static method in class org.apache.flink.table.expressions.Sign
 
valid() - Static method in class org.apache.flink.table.expressions.Similar
 
valid() - Static method in class org.apache.flink.table.expressions.Sin
 
valid() - Static method in class org.apache.flink.table.expressions.Sqrt
 
valid() - Static method in class org.apache.flink.table.expressions.StddevPop
 
valid() - Static method in class org.apache.flink.table.expressions.StddevSamp
 
valid() - Static method in class org.apache.flink.table.expressions.Substring
 
valid() - Static method in class org.apache.flink.table.expressions.Sum
 
valid() - Static method in class org.apache.flink.table.expressions.Sum0
 
valid() - Static method in class org.apache.flink.table.expressions.SymbolExpression
 
valid() - Static method in class org.apache.flink.table.expressions.TableFunctionCall
 
valid() - Static method in class org.apache.flink.table.expressions.Tan
 
valid() - Static method in class org.apache.flink.table.expressions.TemporalCeil
 
valid() - Static method in class org.apache.flink.table.expressions.TemporalFloor
 
valid() - Static method in class org.apache.flink.table.expressions.TemporalOverlaps
 
valid() - Static method in class org.apache.flink.table.expressions.Trim
 
valid() - Static method in class org.apache.flink.table.expressions.UnaryMinus
 
valid() - Method in class org.apache.flink.table.expressions.UnresolvedAlias
 
valid() - Static method in class org.apache.flink.table.expressions.UnresolvedFieldReference
 
valid() - Static method in class org.apache.flink.table.expressions.UnresolvedOverCall
 
valid() - Static method in class org.apache.flink.table.expressions.Upper
 
valid() - Static method in class org.apache.flink.table.expressions.VarPop
 
valid() - Static method in class org.apache.flink.table.expressions.VarSamp
 
valid() - Static method in class org.apache.flink.table.expressions.WindowEnd
 
valid() - Static method in class org.apache.flink.table.expressions.WindowReference
 
valid() - Static method in class org.apache.flink.table.expressions.WindowStart
 
validate() - Method in class org.apache.flink.api.common.operators.base.BulkIterationBase
 
validate(GraphValidator<K, VV, EV>) - Method in class org.apache.flink.graph.Graph
Function that checks whether a Graph is a valid Graph, as defined by the given GraphValidator.
validate(GraphValidator<K, VV, EV>) - Method in class org.apache.flink.graph.scala.Graph
 
validate(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.validation.GraphValidator
 
validate(Graph<K, VV, EV>) - Method in class org.apache.flink.graph.validation.InvalidVertexIdsValidator
Checks that the edge set input contains valid vertex Ids, i.e.
validate(SqlNode) - Method in class org.apache.flink.table.calcite.FlinkPlannerImpl
 
validate(TableEnvironment) - Method in class org.apache.flink.table.plan.logical.Aggregate
 
validate(TableEnvironment) - Static method in class org.apache.flink.table.plan.logical.AliasNode
 
validate(TableEnvironment) - Method in class org.apache.flink.table.plan.logical.CatalogNode
 
validate(TableEnvironment) - Method in class org.apache.flink.table.plan.logical.Distinct
 
validate(TableEnvironment) - Method in class org.apache.flink.table.plan.logical.Filter
 
validate(TableEnvironment) - Method in class org.apache.flink.table.plan.logical.Intersect
 
validate(TableEnvironment) - Method in class org.apache.flink.table.plan.logical.Join
 
validate(TableEnvironment) - Method in class org.apache.flink.table.plan.logical.Limit
 
validate(TableEnvironment) - Method in class org.apache.flink.table.plan.logical.LogicalNode
 
validate(TableEnvironment) - Method in class org.apache.flink.table.plan.logical.LogicalRelNode
 
validate(TableEnvironment) - Method in class org.apache.flink.table.plan.logical.LogicalTableFunctionCall
 
validate(TableEnvironment) - Method in class org.apache.flink.table.plan.logical.LogicalWindow
 
validate(TableEnvironment) - Method in class org.apache.flink.table.plan.logical.Minus
 
validate(TableEnvironment) - Method in class org.apache.flink.table.plan.logical.Project
 
validate(TableEnvironment) - Method in class org.apache.flink.table.plan.logical.SessionGroupWindow
 
validate(TableEnvironment) - Method in class org.apache.flink.table.plan.logical.SlidingGroupWindow
 
validate(TableEnvironment) - Method in class org.apache.flink.table.plan.logical.Sort
 
validate(TableEnvironment) - Method in class org.apache.flink.table.plan.logical.TumblingGroupWindow
 
validate(TableEnvironment) - Method in class org.apache.flink.table.plan.logical.Union
 
validate(TableEnvironment) - Method in class org.apache.flink.table.plan.logical.WindowAggregate
 
validateAndNormalizeUri(URI) - Static method in class org.apache.flink.runtime.state.filesystem.FsStateBackend
Checks and normalizes the checkpoint data URI.
validateAndNormalizeUri(URI) - Static method in class org.apache.flink.runtime.webmonitor.WebMonitorUtils
Checks and normalizes the given URI.
validateCall(SqlCall, SqlValidator, SqlValidatorScope, SqlValidatorScope) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
validateCall(SqlCall, SqlValidator, SqlValidatorScope, SqlValidatorScope) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
validateCall(SqlCall, SqlValidator, SqlValidatorScope, SqlValidatorScope) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
validateCall(SqlCall, SqlValidator, SqlValidatorScope, SqlValidatorScope) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
validateClassLoadable(ClassNotFoundException, ClassLoader) - Static method in class org.apache.flink.runtime.util.ClassLoaderUtil
Checks, whether the class that was not found in the given exception, can be resolved through the given class loader.
validateCustomPartitioner(Partitioner<E>, TypeInformation<E>) - Method in class org.apache.flink.api.common.operators.Keys.ExpressionKeys
 
validateCustomPartitioner(Partitioner<E>, TypeInformation<E>) - Method in class org.apache.flink.api.common.operators.Keys.SelectorFunctionKeys
 
validateCustomPartitioner(Partitioner<E>, TypeInformation<E>) - Method in class org.apache.flink.api.common.operators.Keys
 
validatedSqlNode() - Method in class org.apache.flink.table.calcite.FlinkPlannerImpl
 
validateInput() - Static method in class org.apache.flink.table.api.CurrentRange
 
validateInput() - Static method in class org.apache.flink.table.api.CurrentRow
 
validateInput() - Static method in class org.apache.flink.table.api.UnboundedRange
 
validateInput() - Static method in class org.apache.flink.table.api.UnboundedRow
 
validateInput() - Method in class org.apache.flink.table.expressions.Abs
 
validateInput() - Method in class org.apache.flink.table.expressions.AbstractWindowProperty
 
validateInput() - Method in class org.apache.flink.table.expressions.Acos
 
validateInput() - Method in class org.apache.flink.table.expressions.AggFunctionCall
 
validateInput() - Method in class org.apache.flink.table.expressions.Alias
 
validateInput() - Static method in class org.apache.flink.table.expressions.And
 
validateInput() - Method in class org.apache.flink.table.expressions.ArrayCardinality
 
validateInput() - Method in class org.apache.flink.table.expressions.ArrayConstructor
 
validateInput() - Method in class org.apache.flink.table.expressions.ArrayElement
 
validateInput() - Method in class org.apache.flink.table.expressions.ArrayElementAt
 
validateInput() - Static method in class org.apache.flink.table.expressions.Asc
 
validateInput() - Method in class org.apache.flink.table.expressions.Asin
 
validateInput() - Method in class org.apache.flink.table.expressions.Atan
 
validateInput() - Method in class org.apache.flink.table.expressions.Avg
 
validateInput() - Method in class org.apache.flink.table.expressions.BinaryArithmetic
 
validateInput() - Method in class org.apache.flink.table.expressions.BinaryComparison
 
validateInput() - Method in class org.apache.flink.table.expressions.BinaryPredicate
 
validateInput() - Method in class org.apache.flink.table.expressions.Call
 
validateInput() - Method in class org.apache.flink.table.expressions.Cast
 
validateInput() - Method in class org.apache.flink.table.expressions.Ceil
 
validateInput() - Method in class org.apache.flink.table.expressions.CharLength
 
validateInput() - Method in class org.apache.flink.table.expressions.Cos
 
validateInput() - Method in class org.apache.flink.table.expressions.Cot
 
validateInput() - Static method in class org.apache.flink.table.expressions.Count
 
validateInput() - Static method in class org.apache.flink.table.expressions.CurrentDate
 
validateInput() - Static method in class org.apache.flink.table.expressions.CurrentTime
 
validateInput() - Method in class org.apache.flink.table.expressions.CurrentTimePoint
 
validateInput() - Static method in class org.apache.flink.table.expressions.CurrentTimestamp
 
validateInput() - Method in class org.apache.flink.table.expressions.Degrees
 
validateInput() - Static method in class org.apache.flink.table.expressions.Desc
 
validateInput() - Static method in class org.apache.flink.table.expressions.Div
 
validateInput() - Method in class org.apache.flink.table.expressions.EqualTo
 
validateInput() - Static method in class org.apache.flink.table.expressions.Exp
 
validateInput() - Method in class org.apache.flink.table.expressions.Expression
Check input data types, inputs number or other properties specified by this expression.
validateInput() - Method in class org.apache.flink.table.expressions.Extract
 
validateInput() - Method in class org.apache.flink.table.expressions.Flattening
 
validateInput() - Method in class org.apache.flink.table.expressions.Floor
 
validateInput() - Method in class org.apache.flink.table.expressions.GetCompositeField
 
validateInput() - Static method in class org.apache.flink.table.expressions.GreaterThan
 
validateInput() - Static method in class org.apache.flink.table.expressions.GreaterThanOrEqual
 
validateInput() - Method in class org.apache.flink.table.expressions.If
 
validateInput() - Method in class org.apache.flink.table.expressions.InitCap
 
validateInput() - Method in interface org.apache.flink.table.expressions.InputTypeSpec
 
validateInput() - Static method in class org.apache.flink.table.expressions.IsFalse
 
validateInput() - Static method in class org.apache.flink.table.expressions.IsNotFalse
 
validateInput() - Static method in class org.apache.flink.table.expressions.IsNotNull
 
validateInput() - Static method in class org.apache.flink.table.expressions.IsNotTrue
 
validateInput() - Static method in class org.apache.flink.table.expressions.IsNull
 
validateInput() - Static method in class org.apache.flink.table.expressions.IsTrue
 
validateInput() - Static method in class org.apache.flink.table.expressions.LessThan
 
validateInput() - Static method in class org.apache.flink.table.expressions.LessThanOrEqual
 
validateInput() - Method in class org.apache.flink.table.expressions.Like
 
validateInput() - Static method in class org.apache.flink.table.expressions.Literal
 
validateInput() - Static method in class org.apache.flink.table.expressions.Ln
 
validateInput() - Static method in class org.apache.flink.table.expressions.LocalTime
 
validateInput() - Static method in class org.apache.flink.table.expressions.LocalTimestamp
 
validateInput() - Static method in class org.apache.flink.table.expressions.Log10
 
validateInput() - Method in class org.apache.flink.table.expressions.Lower
 
validateInput() - Method in class org.apache.flink.table.expressions.Max
 
validateInput() - Method in class org.apache.flink.table.expressions.Min
 
validateInput() - Method in class org.apache.flink.table.expressions.Minus
 
validateInput() - Static method in class org.apache.flink.table.expressions.Mod
 
validateInput() - Static method in class org.apache.flink.table.expressions.Mul
 
validateInput() - Method in class org.apache.flink.table.expressions.Not
 
validateInput() - Method in class org.apache.flink.table.expressions.NotEqualTo
 
validateInput() - Static method in class org.apache.flink.table.expressions.Null
 
validateInput() - Static method in class org.apache.flink.table.expressions.Or
 
validateInput() - Method in class org.apache.flink.table.expressions.Ordering
 
validateInput() - Method in class org.apache.flink.table.expressions.OverCall
 
validateInput() - Static method in class org.apache.flink.table.expressions.Overlay
 
validateInput() - Static method in class org.apache.flink.table.expressions.Pi
 
validateInput() - Method in class org.apache.flink.table.expressions.Plus
 
validateInput() - Static method in class org.apache.flink.table.expressions.Position
 
validateInput() - Static method in class org.apache.flink.table.expressions.Power
 
validateInput() - Method in class org.apache.flink.table.expressions.ProctimeAttribute
 
validateInput() - Static method in class org.apache.flink.table.expressions.Quarter
 
validateInput() - Method in class org.apache.flink.table.expressions.Radians
 
validateInput() - Static method in class org.apache.flink.table.expressions.ResolvedFieldReference
 
validateInput() - Method in class org.apache.flink.table.expressions.Round
 
validateInput() - Method in class org.apache.flink.table.expressions.RowtimeAttribute
 
validateInput() - Method in class org.apache.flink.table.expressions.ScalarFunctionCall
 
validateInput() - Method in class org.apache.flink.table.expressions.Sign
 
validateInput() - Method in class org.apache.flink.table.expressions.Similar
 
validateInput() - Method in class org.apache.flink.table.expressions.Sin
 
validateInput() - Static method in class org.apache.flink.table.expressions.Sqrt
 
validateInput() - Method in class org.apache.flink.table.expressions.StddevPop
 
validateInput() - Method in class org.apache.flink.table.expressions.StddevSamp
 
validateInput() - Static method in class org.apache.flink.table.expressions.Substring
 
validateInput() - Method in class org.apache.flink.table.expressions.Sum
 
validateInput() - Method in class org.apache.flink.table.expressions.Sum0
 
validateInput() - Static method in class org.apache.flink.table.expressions.SymbolExpression
 
validateInput() - Static method in class org.apache.flink.table.expressions.TableFunctionCall
 
validateInput() - Method in class org.apache.flink.table.expressions.Tan
 
validateInput() - Static method in class org.apache.flink.table.expressions.TemporalCeil
 
validateInput() - Method in class org.apache.flink.table.expressions.TemporalCeilFloor
 
validateInput() - Static method in class org.apache.flink.table.expressions.TemporalFloor
 
validateInput() - Method in class org.apache.flink.table.expressions.TemporalOverlaps
 
validateInput() - Method in class org.apache.flink.table.expressions.Trim
 
validateInput() - Method in class org.apache.flink.table.expressions.UnaryMinus
 
validateInput() - Static method in class org.apache.flink.table.expressions.UnresolvedAlias
 
validateInput() - Method in class org.apache.flink.table.expressions.UnresolvedFieldReference
 
validateInput() - Method in class org.apache.flink.table.expressions.UnresolvedOverCall
 
validateInput() - Static method in class org.apache.flink.table.expressions.Upper
 
validateInput() - Method in class org.apache.flink.table.expressions.VarPop
 
validateInput() - Method in class org.apache.flink.table.expressions.VarSamp
 
validateInput() - Static method in class org.apache.flink.table.expressions.WindowEnd
 
validateInput() - Static method in class org.apache.flink.table.expressions.WindowReference
 
validateInput() - Static method in class org.apache.flink.table.expressions.WindowStart
 
validateJoin(SqlJoin, SqlValidatorScope) - Method in class org.apache.flink.table.calcite.FlinkCalciteSqlValidator
 
validateOperands(SqlValidator, SqlValidatorScope, SqlCall) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
validateOperands(SqlValidator, SqlValidatorScope, SqlCall) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
validateOperands(SqlValidator, SqlValidatorScope, SqlCall) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
validateOperands(SqlValidator, SqlValidatorScope, SqlCall) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
validateQuantifier(SqlValidator, SqlCall) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
validateQuantifier(SqlValidator, SqlCall) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
validateQuantifier(SqlValidator, SqlCall) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
validateQuantifier(SqlValidator, SqlCall) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
validateRunsInMainThread() - Method in class org.apache.flink.runtime.rpc.RpcEndpoint
Validates that the method call happens in the RPC endpoint's main thread.
validateType(TypeInformation<?>) - Method in class org.apache.flink.table.api.TableEnvironment$
Validate if class represented by the typeInfo is static and globally accessible
validateType(TypeInformation<?>) - Static method in class org.apache.flink.table.api.TableEnvironment
Validate if class represented by the typeInfo is static and globally accessible
validateZooKeeperConfig(Properties) - Static method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaConsumer08
Validate the ZK configuration, checking for required parameters
ValidationException - Exception in org.apache.flink.table.api
Exception for all errors occurring during validation phase.
ValidationException(String, Throwable) - Constructor for exception org.apache.flink.table.api.ValidationException
 
ValidationException(String) - Constructor for exception org.apache.flink.table.api.ValidationException
 
ValidationException$ - Class in org.apache.flink.table.api
 
ValidationException$() - Constructor for class org.apache.flink.table.api.ValidationException$
 
ValidationFailure - Class in org.apache.flink.table.validate
Represents the failing result of a validation, with a error message to show the reason of failure.
ValidationFailure(String) - Constructor for class org.apache.flink.table.validate.ValidationFailure
 
ValidationFailure$ - Class in org.apache.flink.table.validate
 
ValidationFailure$() - Constructor for class org.apache.flink.table.validate.ValidationFailure$
 
ValidationResult - Interface in org.apache.flink.table.validate
Represents the result of a validation.
ValidationSuccess - Class in org.apache.flink.table.validate
Represents the successful result of a validation.
ValidationSuccess() - Constructor for class org.apache.flink.table.validate.ValidationSuccess
 
ValidationSuccess$ - Class in org.apache.flink.table.validate
Represents the successful result of a validation.
ValidationSuccess$() - Constructor for class org.apache.flink.table.validate.ValidationSuccess$
 
validator - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
 
validator() - Method in class org.apache.flink.table.calcite.FlinkPlannerImpl
 
validRexOperands(int, Litmus) - Static method in class org.apache.flink.table.functions.TimeMaterializationSqlFunction
 
validRexOperands(int, Litmus) - Static method in class org.apache.flink.table.functions.utils.AggSqlFunction
 
validRexOperands(int, Litmus) - Static method in class org.apache.flink.table.functions.utils.ScalarSqlFunction
 
validRexOperands(int, Litmus) - Static method in class org.apache.flink.table.functions.utils.TableSqlFunction
 
vals() - Method in class org.apache.flink.hcatalog.scala.HCatInputFormat
 
value() - Method in interface org.apache.flink.api.common.state.ValueState
Returns the current value for the state.
value - Variable in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
value() - Method in class org.apache.flink.api.java.summarize.aggregation.CompensatedSum
The value of the sum
value() - Method in class org.apache.flink.contrib.streaming.state.RocksDBValueState
 
Value() - Constructor for class org.apache.flink.graph.drivers.parameter.IterationConvergence.Value
 
value - Variable in class org.apache.flink.graph.drivers.parameter.SimpleParameter
 
value - Variable in class org.apache.flink.runtime.metrics.dump.MetricDump.GaugeDump
 
value() - Method in class org.apache.flink.runtime.state.heap.HeapValueState
 
value - Variable in class org.apache.flink.storm.util.SplitStreamType
The actual data value.
value() - Method in class org.apache.flink.table.expressions.Literal
 
Value(Enum<?>) - Method in class org.apache.flink.table.expressions.TableSymbols
 
Value() - Static method in class org.apache.flink.table.expressions.TimeIntervalUnit
 
Value(int) - Static method in class org.apache.flink.table.expressions.TimeIntervalUnit
 
Value(String) - Static method in class org.apache.flink.table.expressions.TimeIntervalUnit
 
Value(int, String) - Static method in class org.apache.flink.table.expressions.TimeIntervalUnit
 
Value(Enum<?>) - Static method in class org.apache.flink.table.expressions.TimeIntervalUnit
 
Value() - Static method in class org.apache.flink.table.expressions.TimePointUnit
 
Value(int) - Static method in class org.apache.flink.table.expressions.TimePointUnit
 
Value(String) - Static method in class org.apache.flink.table.expressions.TimePointUnit
 
Value(int, String) - Static method in class org.apache.flink.table.expressions.TimePointUnit
 
Value(Enum<?>) - Static method in class org.apache.flink.table.expressions.TimePointUnit
 
Value() - Static method in class org.apache.flink.table.expressions.TrimMode
 
Value(int) - Static method in class org.apache.flink.table.expressions.TrimMode
 
Value(String) - Static method in class org.apache.flink.table.expressions.TrimMode
 
Value(int, String) - Static method in class org.apache.flink.table.expressions.TrimMode
 
Value(Enum<?>) - Static method in class org.apache.flink.table.expressions.TrimMode
 
Value() - Static method in class org.apache.flink.table.plan.nodes.datastream.AccMode
 
Value(int) - Static method in class org.apache.flink.table.plan.nodes.datastream.AccMode
 
Value(String) - Static method in class org.apache.flink.table.plan.nodes.datastream.AccMode
 
Value(int, String) - Static method in class org.apache.flink.table.plan.nodes.datastream.AccMode
 
Value - Interface in org.apache.flink.types
Basic value interface for types that act as serializable values.
VALUE_FIELD - Static variable in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter.AvroKeyValue
The name of the generic record field containing the value.
VALUE_NOT_SET - Static variable in class org.apache.flink.runtime.executiongraph.ExecutionJobVertex
 
ValueArray<T> - Interface in org.apache.flink.graph.types.valuearray
Basic interface for array types which reuse objects during serialization.
ValueArrayFactory - Class in org.apache.flink.graph.types.valuearray
A factory generator for ValueArray types is necessary because the contained Value types do not currently implement a common interface for creating a ValueArray.
ValueArrayFactory() - Constructor for class org.apache.flink.graph.types.valuearray.ValueArrayFactory
 
ValueArrayTypeInfo<T> - Class in org.apache.flink.graph.types.valuearray
A TypeInformation for the ValueArray type.
ValueArrayTypeInfo(TypeInformation<T>) - Constructor for class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfo
 
ValueArrayTypeInfoFactory<T> - Class in org.apache.flink.graph.types.valuearray
Used by TypeExtractor to create a TypeInformation for implementations of ValueArray.
ValueArrayTypeInfoFactory() - Constructor for class org.apache.flink.graph.types.valuearray.ValueArrayTypeInfoFactory
 
valueClass - Variable in class org.apache.flink.api.java.hadoop.mapred.HadoopInputFormatBase
 
valueClass - Variable in class org.apache.flink.api.java.hadoop.mapreduce.HadoopInputFormatBase
 
ValueComparator<T extends Value & Comparable<T>> - Class in org.apache.flink.api.java.typeutils.runtime
Comparator for all Value types that extend Key
ValueComparator(boolean, Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
ValueDescriptor(int, scala.reflect.macros.Context.universe) - Constructor for class org.apache.flink.api.scala.codegen.TypeDescriptors.ValueDescriptor
 
valueOf(String) - Static method in enum org.apache.flink.api.common.CodeAnalysisMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.common.ExecutionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.common.io.FileOutputFormat.OutputDirectoryMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.common.operators.base.CrossOperatorBase.CrossHint
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.common.operators.base.OuterJoinOperatorBase.OuterJoinType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.common.operators.base.PartitionOperatorBase.PartitionMethod
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.common.operators.base.ReduceOperatorBase.CombineHint
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.common.operators.Order
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.common.state.StateDescriptor.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.java.aggregation.Aggregations
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.java.io.AvroOutputFormat.Codec
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.java.operators.join.JoinType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.java.sca.TaggedValue.Input
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.java.sca.TaggedValue.Tag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.java.typeutils.runtime.KryoRegistration.SerializerDefinitionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.api.java.utils.OptionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.cep.nfa.State.StateType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.cep.nfa.StateTransitionAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.cep.pattern.Quantifier.ConsumingStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.cep.pattern.Quantifier.QuantifierProperty
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.contrib.streaming.state.PredefinedOptions
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.core.fs.FileSystem.WriteMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.core.fs.FileSystemKind
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.core.memory.MemoryType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.graph.drivers.parameter.Simplify.Ordering
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.graph.EdgeDirection
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.graph.EdgeOrder
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.graph.utils.proxy.OptionalBoolean.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters.ContainerType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore.WorkerState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.metrics.datadog.MetricType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.optimizer.dag.TempMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.optimizer.dataproperties.PartitioningProperty
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.optimizer.plan.PlanNode.FeedbackPropertiesMeetRequirementsReport
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.optimizer.plan.PlanNode.SourceAndDamReport
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.python.api.PythonOperationInfo.DatasizeHint
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.python.api.PythonPlanBinder.Operation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.akka.ListeningBehaviour
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointDeclineReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointOptions.CheckpointType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.checkpoint.PendingCheckpoint.TaskAcknowledgeResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.clusterframework.ApplicationStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.execution.ExecutionState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils.AddressResolution
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.highavailability.RunningJobsRegistry.JobSchedulingStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.io.disk.iomanager.IOManager.IOMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer.DeserializationResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.io.network.api.serialization.RecordSerializer.SerializationResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.io.network.DataExchangeMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.jobgraph.DistributionPattern
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.jobgraph.JobStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.jobgraph.ScheduleMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.jobmanager.HighAvailabilityMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.jobmanager.JobManagerMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.jobmanager.scheduler.Locality
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.operators.DamBehavior
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.operators.DriverStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.operators.shipping.ShipStrategyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.operators.util.LocalStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.query.netty.message.KvStateRequestType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils.AkkaProtocol
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.rpc.akka.messages.Processing
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.state.OperatorStateHandle.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.util.ZooKeeperUtils.ZkClientACLMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.runtime.webmonitor.handlers.TaskManagerLogHandler.FileMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.streaming.api.CheckpointingMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.streaming.api.datastream.AsyncDataStream.OutputMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.streaming.api.datastream.LegacyWindowOperatorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.streaming.api.environment.CheckpointConfig.ExternalizedCheckpointCleanup
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.streaming.api.functions.aggregation.AggregationFunction.AggregationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.streaming.api.functions.source.FileMonitoringFunction.WatchType
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.streaming.api.functions.source.FileProcessingMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.streaming.api.operators.ChainingStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.streaming.api.TimeCharacteristic
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.streaming.api.TimeDomain
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.streaming.api.windowing.triggers.TriggerResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase.FlushBackoffType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.streaming.connectors.kafka.config.OffsetCommitMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.streaming.connectors.kafka.config.StartupMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.test.util.MultipleProgramsTestBase.TestExecutionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.types.parser.FieldParser.ParseErrorState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.util.OperatingSystem
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.flink.yarn.configuration.YarnConfigOptions.UserJarInclusion
Returns the enum constant of this type with the specified name.
valueOrNull(Object) - Static method in class org.apache.flink.runtime.metrics.scope.ScopeFormat
 
VALUES - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
 
values() - Static method in enum org.apache.flink.api.common.CodeAnalysisMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.api.common.ExecutionMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.api.common.io.FileOutputFormat.OutputDirectoryMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.api.common.operators.base.CrossOperatorBase.CrossHint
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.api.common.operators.base.JoinOperatorBase.JoinHint
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.api.common.operators.base.OuterJoinOperatorBase.OuterJoinType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.api.common.operators.base.PartitionOperatorBase.PartitionMethod
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.api.common.operators.base.ReduceOperatorBase.CombineHint
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.api.common.operators.Order
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in interface org.apache.flink.api.common.state.MapState
Returns all the values in the state.
values() - Static method in enum org.apache.flink.api.common.state.StateDescriptor.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.api.java.aggregation.Aggregations
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.api.java.io.AvroOutputFormat.Codec
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.api.java.operators.join.JoinType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.api.java.sca.TaggedValue.Input
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.api.java.sca.TaggedValue.Tag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.api.java.typeutils.runtime.KryoRegistration.SerializerDefinitionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.api.java.utils.OptionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.cep.nfa.State.StateType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.cep.nfa.StateTransitionAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.cep.pattern.Quantifier.ConsumingStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.cep.pattern.Quantifier.QuantifierProperty
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.contrib.streaming.state.PredefinedOptions
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.flink.contrib.streaming.state.RocksDBMapState
 
values() - Static method in enum org.apache.flink.core.fs.FileSystem.WriteMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.core.fs.FileSystemKind
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.core.memory.MemoryType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.graph.drivers.parameter.Simplify.Ordering
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.graph.EdgeDirection
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.graph.EdgeOrder
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.graph.utils.proxy.OptionalBoolean.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.mesos.runtime.clusterframework.MesosTaskManagerParameters.ContainerType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.mesos.runtime.clusterframework.store.MesosWorkerStore.WorkerState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.metrics.datadog.MetricType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.flink.ml.common.Block
 
values() - Method in class org.apache.flink.ml.math.distributed.IndexedRow
 
values() - Static method in enum org.apache.flink.optimizer.dag.TempMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.optimizer.dataproperties.PartitioningProperty
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.optimizer.plan.PlanNode.FeedbackPropertiesMeetRequirementsReport
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.optimizer.plan.PlanNode.SourceAndDamReport
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.python.api.PythonOperationInfo.DatasizeHint
Returns an array containing the constants of this enum type, in the order they are declared.
values - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
values() - Static method in enum org.apache.flink.python.api.PythonPlanBinder.Operation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.akka.ListeningBehaviour
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointDeclineReason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointOptions.CheckpointType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.checkpoint.CheckpointStatsStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.checkpoint.PendingCheckpoint.TaskAcknowledgeResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.clusterframework.ApplicationStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.execution.ExecutionState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.highavailability.HighAvailabilityServicesUtils.AddressResolution
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.highavailability.RunningJobsRegistry.JobSchedulingStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.io.disk.iomanager.IOManager.IOMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.io.network.api.serialization.RecordDeserializer.DeserializationResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.io.network.api.serialization.RecordSerializer.SerializationResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.io.network.DataExchangeMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.io.network.partition.ResultPartitionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.jobgraph.DistributionPattern
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.jobgraph.JobStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.jobgraph.ScheduleMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.jobmanager.HighAvailabilityMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.jobmanager.JobManagerMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.jobmanager.scheduler.Locality
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.operators.DamBehavior
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.operators.DriverStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.operators.shipping.ShipStrategyType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.operators.util.LocalStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.query.netty.message.KvStateRequestType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.rpc.akka.AkkaRpcServiceUtils.AkkaProtocol
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.rpc.akka.messages.Processing
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.flink.runtime.state.heap.HeapMapState
 
values() - Static method in enum org.apache.flink.runtime.state.OperatorStateHandle.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.util.ZooKeeperUtils.ZkClientACLMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.runtime.webmonitor.handlers.TaskManagerLogHandler.FileMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.flink.storm.util.StormConfig
 
values() - Static method in enum org.apache.flink.streaming.api.CheckpointingMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.streaming.api.datastream.AsyncDataStream.OutputMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.streaming.api.datastream.LegacyWindowOperatorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.streaming.api.environment.CheckpointConfig.ExternalizedCheckpointCleanup
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.streaming.api.functions.aggregation.AggregationFunction.AggregationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.streaming.api.functions.source.FileMonitoringFunction.WatchType
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.streaming.api.functions.source.FileProcessingMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.flink.streaming.api.operators.async.queue.OrderedStreamElementQueue
 
values() - Method in interface org.apache.flink.streaming.api.operators.async.queue.StreamElementQueue
Return the collection of StreamElementQueueEntry currently contained in this queue.
values() - Method in class org.apache.flink.streaming.api.operators.async.queue.UnorderedStreamElementQueue
 
values() - Static method in enum org.apache.flink.streaming.api.operators.ChainingStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.streaming.api.TimeCharacteristic
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.streaming.api.TimeDomain
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.streaming.api.windowing.triggers.TriggerResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.streaming.connectors.elasticsearch.ElasticsearchSinkBase.FlushBackoffType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.streaming.connectors.kafka.config.OffsetCommitMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.streaming.connectors.kafka.config.StartupMode
Returns an array containing the constants of this enum type, in the order they are declared.
values(String[], Object[]) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
values(RelDataType, Object[]) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
values(Iterable<? extends List<RexLiteral>>, RelDataType) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
values(RelDataType) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
values() - Static method in class org.apache.flink.table.expressions.TimeIntervalUnit
 
values() - Static method in class org.apache.flink.table.expressions.TimePointUnit
 
values() - Static method in class org.apache.flink.table.expressions.TrimMode
 
values() - Static method in class org.apache.flink.table.plan.nodes.datastream.AccMode
 
values() - Static method in enum org.apache.flink.test.util.MultipleProgramsTestBase.TestExecutionMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.flink.types.MapValue
 
values() - Static method in enum org.apache.flink.types.parser.FieldParser.ParseErrorState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.util.OperatingSystem
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.flink.yarn.configuration.YarnConfigOptions.UserJarInclusion
Returns an array containing the constants of this enum type, in the order they are declared.
ValueSerializer<T extends Value> - Class in org.apache.flink.api.java.typeutils.runtime
Serializer for Value types.
ValueSerializer(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.ValueSerializer
 
ValueSerializer.ValueSerializerConfigSnapshot<T extends Value> - Class in org.apache.flink.api.java.typeutils.runtime
 
ValueSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.ValueSerializer.ValueSerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
ValueSerializerConfigSnapshot(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.ValueSerializer.ValueSerializerConfigSnapshot
 
ValuesInputFormat - Class in org.apache.flink.table.runtime.io
 
ValuesInputFormat(String, String, TypeInformation<Row>) - Constructor for class org.apache.flink.table.runtime.io.ValuesInputFormat
 
ValueState<T> - Interface in org.apache.flink.api.common.state
State interface for partitioned single-value state.
ValueStateDescriptor<T> - Class in org.apache.flink.api.common.state
ValueStateDescriptor(String, Class<T>, T) - Constructor for class org.apache.flink.api.common.state.ValueStateDescriptor
Deprecated.
Use ValueStateDescriptor.ValueStateDescriptor(String, Class) instead and manually manage the default value by checking whether the contents of the state is null.
ValueStateDescriptor(String, TypeInformation<T>, T) - Constructor for class org.apache.flink.api.common.state.ValueStateDescriptor
Deprecated.
Use ValueStateDescriptor.ValueStateDescriptor(String, TypeInformation) instead and manually manage the default value by checking whether the contents of the state is null.
ValueStateDescriptor(String, TypeSerializer<T>, T) - Constructor for class org.apache.flink.api.common.state.ValueStateDescriptor
Deprecated.
Use ValueStateDescriptor.ValueStateDescriptor(String, TypeSerializer) instead and manually manage the default value by checking whether the contents of the state is null.
ValueStateDescriptor(String, Class<T>) - Constructor for class org.apache.flink.api.common.state.ValueStateDescriptor
Creates a new ValueStateDescriptor with the given name and type
ValueStateDescriptor(String, TypeInformation<T>) - Constructor for class org.apache.flink.api.common.state.ValueStateDescriptor
Creates a new ValueStateDescriptor with the given name and type.
ValueStateDescriptor(String, TypeSerializer<T>) - Constructor for class org.apache.flink.api.common.state.ValueStateDescriptor
Creates a new ValueStateDescriptor with the given name and the specific serializer.
ValueSummaryAggregator<VT extends Value,PT,R,A extends Aggregator<PT,R>> - Class in org.apache.flink.api.java.summarize.aggregation
This is a generic Aggregator for Value types like StringValue, DoubleValue, etc.
ValueSummaryAggregator() - Constructor for class org.apache.flink.api.java.summarize.aggregation.ValueSummaryAggregator
 
ValueSummaryAggregator.BooleanValueSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
 
ValueSummaryAggregator.DoubleValueSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
 
ValueSummaryAggregator.FloatValueSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
 
ValueSummaryAggregator.IntegerValueSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
 
ValueSummaryAggregator.LongValueSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
 
ValueSummaryAggregator.ShortValueSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
 
ValueSummaryAggregator.StringValueSummaryAggregator - Class in org.apache.flink.api.java.summarize.aggregation
 
valueType() - Method in class org.apache.flink.table.plan.schema.MapRelDataType
 
ValueTypeInfo<T extends Value> - Class in org.apache.flink.api.java.typeutils
Type information for data types that extend the Value interface.
ValueTypeInfo(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.ValueTypeInfo
 
VAR_POP - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
VAR_POP aggregate function.
VAR_SAMP - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
VAR_SAMP aggregate function.
variable(String, String) - Static method in class org.apache.flink.mesos.Utils
Construct a Mesos environment variable.
variable(Holder<RexCorrelVariable>) - Static method in class org.apache.flink.table.calcite.FlinkRelBuilder
 
variables - Variable in class org.apache.flink.runtime.metrics.groups.AbstractMetricGroup
The map containing all variables and their associated values, lazily computed.
varPop() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Returns the population standard variance of an expression.
VarPop - Class in org.apache.flink.table.expressions
 
VarPop(Expression) - Constructor for class org.apache.flink.table.expressions.VarPop
 
VarPop$ - Class in org.apache.flink.table.expressions
 
VarPop$() - Constructor for class org.apache.flink.table.expressions.VarPop$
 
varSamp() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Returns the sample variance of a given expression.
VarSamp - Class in org.apache.flink.table.expressions
 
VarSamp(Expression) - Constructor for class org.apache.flink.table.expressions.VarSamp
 
VarSamp$ - Class in org.apache.flink.table.expressions
 
VarSamp$() - Constructor for class org.apache.flink.table.expressions.VarSamp$
 
vector() - Method in class org.apache.flink.ml.common.LabeledVector
 
Vector - Interface in org.apache.flink.ml.math
Base trait for Vectors
Vector$ - Class in org.apache.flink.ml.math
 
Vector$() - Constructor for class org.apache.flink.ml.math.Vector$
 
Vector2BreezeConverter(Vector) - Constructor for class org.apache.flink.ml.math.Breeze.Vector2BreezeConverter
 
VectorAccumulator() - Constructor for class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator.VectorAccumulator
 
VectorAccumulator(ArrayList<Integer>) - Constructor for class org.apache.flink.examples.java.relational.EmptyFieldsCountAccumulator.VectorAccumulator
 
VectorBuilder<T extends Vector> - Interface in org.apache.flink.ml.math
Type class to allow the vector construction from different data types
vectorBuilder() - Method in class org.apache.flink.ml.math.VectorBuilder$
Type class implementation for Vector
VectorBuilder$ - Class in org.apache.flink.ml.math
 
VectorBuilder$() - Constructor for class org.apache.flink.ml.math.VectorBuilder$
 
vectorConverter() - Method in class org.apache.flink.ml.math.Vector$
BreezeVectorConverter implementation for Vector
VerifyAndEnrichBolt - Class in org.apache.flink.storm.split.operators
 
VerifyAndEnrichBolt(boolean) - Constructor for class org.apache.flink.storm.split.operators.VerifyAndEnrichBolt
 
verifyEmpty() - Method in class org.apache.flink.runtime.memory.MemoryManager
Checks if the memory manager all memory available.
verifyEndOfSuperstepState() - Method in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
VERSION() - Method in class org.apache.flink.api.scala.typeutils.EnumValueSerializer.ScalaEnumSerializerConfigSnapshot$
 
VERSION() - Method in class org.apache.flink.api.scala.typeutils.OptionSerializer.OptionSerializerConfigSnapshot$
 
VERSION() - Method in class org.apache.flink.api.scala.typeutils.TrySerializer.TrySerializerConfigSnapshot$
 
VERSION - Static variable in class org.apache.flink.migration.runtime.checkpoint.savepoint.SavepointV0
The savepoint version.
version() - Method in class org.apache.flink.runtime.checkpoint.MasterState
 
VERSION - Static variable in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV1
The savepoint version.
VERSION - Static variable in class org.apache.flink.runtime.checkpoint.savepoint.SavepointV2
The savepoint version.
VERSION - Static variable in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
 
VERSION - Static variable in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
 
VERSION() - Method in class org.apache.flink.table.runtime.types.CRowSerializer.CRowSerializerConfigSnapshot$
 
Versioned - Interface in org.apache.flink.core.io
This interface is implemented by classes that provide a version number.
VersionedIOReadableWritable - Class in org.apache.flink.core.io
This is the abstract base class for IOReadableWritable which allows to differentiate between serialization versions.
VersionedIOReadableWritable() - Constructor for class org.apache.flink.core.io.VersionedIOReadableWritable
 
VersionMismatchException - Exception in org.apache.flink.core.io
This exception signals that incompatible versions have been found during serialization.
VersionMismatchException() - Constructor for exception org.apache.flink.core.io.VersionMismatchException
 
VersionMismatchException(String) - Constructor for exception org.apache.flink.core.io.VersionMismatchException
 
VersionMismatchException(String, Throwable) - Constructor for exception org.apache.flink.core.io.VersionMismatchException
 
VersionMismatchException(Throwable) - Constructor for exception org.apache.flink.core.io.VersionMismatchException
 
Vertex<K,V> - Class in org.apache.flink.graph
Represents the graph's nodes.
Vertex() - Constructor for class org.apache.flink.graph.Vertex
 
Vertex(K, V) - Constructor for class org.apache.flink.graph.Vertex
 
VertexCentricConfiguration - Class in org.apache.flink.graph.pregel
A VertexCentricConfiguration object can be used to set the iteration name and degree of parallelism, to register aggregators and use broadcast sets in the ComputeFunction.
VertexCentricConfiguration() - Constructor for class org.apache.flink.graph.pregel.VertexCentricConfiguration
 
VertexCentricIteration<K,VV,EV,Message> - Class in org.apache.flink.graph.pregel
This class represents iterative graph computations, programmed in a vertex-centric perspective.
VertexCentricIteration.MessageCombinerUdf<K,Message> - Class in org.apache.flink.graph.pregel
 
vertexCount() - Method in class org.apache.flink.graph.drivers.input.CirculantGraph
 
vertexCount() - Method in class org.apache.flink.graph.drivers.input.CompleteGraph
 
vertexCount() - Method in class org.apache.flink.graph.drivers.input.CycleGraph
 
vertexCount() - Method in class org.apache.flink.graph.drivers.input.EchoGraph
 
vertexCount() - Method in class org.apache.flink.graph.drivers.input.EmptyGraph
 
vertexCount() - Method in class org.apache.flink.graph.drivers.input.GeneratedGraph
The vertex count is verified to be no greater than the capacity of the selected data type.
vertexCount() - Method in class org.apache.flink.graph.drivers.input.GridGraph
 
vertexCount() - Method in class org.apache.flink.graph.drivers.input.HypercubeGraph
 
vertexCount() - Method in class org.apache.flink.graph.drivers.input.PathGraph
 
vertexCount() - Method in class org.apache.flink.graph.drivers.input.RMatGraph
 
vertexCount() - Method in class org.apache.flink.graph.drivers.input.SingletonEdgeGraph
 
vertexCount() - Method in class org.apache.flink.graph.drivers.input.StarGraph
 
VertexDegree<K,VV,EV> - Class in org.apache.flink.graph.asm.degree.annotate.undirected
Annotates vertices of an undirected graph with the degree.
VertexDegree() - Constructor for class org.apache.flink.graph.asm.degree.annotate.undirected.VertexDegree
 
VertexDegrees<K,VV,EV> - Class in org.apache.flink.graph.asm.degree.annotate.directed
Annotates vertices of a directed graph with the degree, out-, and in-degree.
VertexDegrees() - Constructor for class org.apache.flink.graph.asm.degree.annotate.directed.VertexDegrees
 
VertexDegrees.Degrees - Class in org.apache.flink.graph.asm.degree.annotate.directed
Wraps the vertex degree, out-degree, and in-degree.
VertexDistanceUpdater() - Constructor for class org.apache.flink.graph.examples.IncrementalSSSP.VertexDistanceUpdater
 
VertexDistanceUpdater() - Constructor for class org.apache.flink.graph.library.SingleSourceShortestPaths.VertexDistanceUpdater
 
VertexGroupItem() - Constructor for class org.apache.flink.graph.library.Summarization.VertexGroupItem
 
vertexID() - Method in class org.apache.flink.runtime.messages.ExecutionGraphMessages.ExecutionStateChanged
 
vertexID() - Method in class org.apache.flink.runtime.messages.JobManagerMessages.RequestNextInputSplit
 
vertexID - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.OperatorQueryScopeInfo
 
vertexID - Variable in class org.apache.flink.runtime.metrics.dump.QueryScopeInfo.TaskQueryScopeInfo
 
vertexId - Variable in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
vertexId() - Method in class org.apache.flink.runtime.metrics.groups.TaskMetricGroup
 
vertexIDtoBrokerID - Variable in class org.apache.flink.streaming.api.graph.StreamGraph
 
vertexIDtoLoopTimeout - Variable in class org.apache.flink.streaming.api.graph.StreamGraph
 
VertexInDegree<K,VV,EV> - Class in org.apache.flink.graph.asm.degree.annotate.directed
Annotates vertices of a directed graph with the in-degree.
VertexInDegree() - Constructor for class org.apache.flink.graph.asm.degree.annotate.directed.VertexInDegree
 
vertexJoin(VV, T) - Method in interface org.apache.flink.graph.VertexJoinFunction
Applies a transformation on the current vertex value and the value of the matched tuple of the input DataSet.
VertexJoinFunction<VV,T> - Interface in org.apache.flink.graph
Interface to be implemented by the transformation function applied in Graph.joinWithVertices(DataSet, VertexJoinFunction) method.
VertexLabelUpdater(double) - Constructor for class org.apache.flink.graph.library.CommunityDetection.VertexLabelUpdater
 
VertexMetrics<K extends Comparable<K>,VV,EV> - Class in org.apache.flink.graph.library.metric.directed
Compute the following vertex metrics in a directed graph: - number of vertices - number of edges - number of unidirectional edges - number of bidirectional edges - average degree - number of triplets - maximum degree - maximum out degree - maximum in degree - maximum number of triplets
VertexMetrics() - Constructor for class org.apache.flink.graph.library.metric.directed.VertexMetrics
 
VertexMetrics<K extends Comparable<K>,VV,EV> - Class in org.apache.flink.graph.library.metric.undirected
Compute the following vertex metrics in an undirected graph: - number of vertices - number of edges - average degree - number of triplets - maximum degree - maximum number of triplets
VertexMetrics() - Constructor for class org.apache.flink.graph.library.metric.undirected.VertexMetrics
 
VertexMetrics.Result - Class in org.apache.flink.graph.library.metric.directed
Wraps vertex metrics.
VertexMetrics.Result - Class in org.apache.flink.graph.library.metric.undirected
Wraps vertex metrics.
VertexOutDegree<K,VV,EV> - Class in org.apache.flink.graph.asm.degree.annotate.directed
Annotates vertices of a directed graph with the out-degree.
VertexOutDegree() - Constructor for class org.apache.flink.graph.asm.degree.annotate.directed.VertexOutDegree
 
VertexRankUpdater(double) - Constructor for class org.apache.flink.graph.examples.PageRank.VertexRankUpdater
 
vertexReader - Variable in class org.apache.flink.graph.GraphCsvReader
 
vertexSequence(ExecutionEnvironment, int, long) - Static method in class org.apache.flink.graph.generator.GraphGeneratorUtils
Generates Vertices with sequential, numerical labels.
vertexSet(DataSet<Edge<K, EV>>, int) - Static method in class org.apache.flink.graph.generator.GraphGeneratorUtils
Generates Vertices present in the given set of Edges.
VertexToTuple2Map<K,VV> - Class in org.apache.flink.graph.scala.utils
 
VertexToTuple2Map() - Constructor for class org.apache.flink.graph.scala.utils.VertexToTuple2Map
 
VertexToTuple2Map<K,VV> - Class in org.apache.flink.graph.utils
Create a Tuple2 DataSet from a Vertex DataSet
VertexToTuple2Map() - Constructor for class org.apache.flink.graph.utils.VertexToTuple2Map
 
vertexTypes(Class<K>, Class<VV>) - Method in class org.apache.flink.graph.GraphCsvReader
Creates a Graph from CSV input without edge values.
VertexValue() - Constructor for class org.apache.flink.graph.library.Summarization.VertexValue
 
VertexWithRepresentative() - Constructor for class org.apache.flink.graph.library.Summarization.VertexWithRepresentative
 
VERTICES - Static variable in class org.apache.flink.examples.java.graph.util.ConnectedComponentsData
 
vertices() - Method in class org.apache.flink.examples.scala.graph.EnumTriangles.TriadBuilder
 
VERTICES - Static variable in class org.apache.flink.graph.examples.data.EuclideanGraphData
 
VERTICES - Static variable in class org.apache.flink.graph.examples.data.IncrementalSSSPData
 
VERTICES - Static variable in class org.apache.flink.test.testdata.PageRankData
 
VERTICES_WITH_MIN_ID - Static variable in class org.apache.flink.graph.examples.data.ConnectedComponentsDefaultData
 
View - Interface in org.apache.flink.metrics
An interface for metrics which should be updated in regular intervals by a background thread.
viewExpander - Variable in class org.apache.calcite.sql2rel.SqlToRelConverter
 
ViewExpanderImpl() - Constructor for class org.apache.flink.table.calcite.FlinkPlannerImpl.ViewExpanderImpl
 
ViewUpdater - Class in org.apache.flink.runtime.metrics
The ViewUpdater is responsible for updating all metrics that implement the View interface.
ViewUpdater(ScheduledExecutorService) - Constructor for class org.apache.flink.runtime.metrics.ViewUpdater
 
VirtualFileServerHandler(Path) - Constructor for class org.apache.flink.mesos.util.MesosArtifactServer.VirtualFileServerHandler
 
VisibleForTesting - Annotation Type in org.apache.flink.annotation
This annotations declares that a function, field, constructor, or entire type, is only visible for testing purposes.
visit(SqlIdentifier) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
 
visit(SqlNodeList) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
 
visit(SqlLiteral) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
 
visit(SqlDataTypeSpec) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
 
visit(SqlDynamicParam) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
 
visit(SqlIntervalQualifier) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
 
visit(SqlCall) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.AggConverter
 
visit(SqlLiteral) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
 
visit(SqlCall) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
 
visit(SqlNodeList) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
 
visit(SqlIdentifier) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
 
visit(SqlDataTypeSpec) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
 
visit(SqlDynamicParam) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
 
visit(SqlIntervalQualifier) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.Blackboard
 
visit(int, int, String, String, String, String[]) - Method in class org.apache.flink.api.scala.InnerClosureFinder
 
visit(String, Object) - Method in class org.apache.flink.runtime.util.DependencyVisitor.AnnotationVisitorImpl
 
visit(int, int, String, String, String, String[]) - Method in class org.apache.flink.runtime.util.DependencyVisitor
 
visit(LogicalIntersect) - Method in class org.apache.flink.table.calcite.RelTimeIndicatorConverter
 
visit(LogicalUnion) - Method in class org.apache.flink.table.calcite.RelTimeIndicatorConverter
 
visit(LogicalAggregate) - Method in class org.apache.flink.table.calcite.RelTimeIndicatorConverter
 
visit(LogicalMinus) - Method in class org.apache.flink.table.calcite.RelTimeIndicatorConverter
 
visit(LogicalSort) - Method in class org.apache.flink.table.calcite.RelTimeIndicatorConverter
 
visit(LogicalMatch) - Method in class org.apache.flink.table.calcite.RelTimeIndicatorConverter
 
visit(RelNode) - Method in class org.apache.flink.table.calcite.RelTimeIndicatorConverter
 
visit(LogicalExchange) - Method in class org.apache.flink.table.calcite.RelTimeIndicatorConverter
 
visit(TableScan) - Method in class org.apache.flink.table.calcite.RelTimeIndicatorConverter
 
visit(TableFunctionScan) - Method in class org.apache.flink.table.calcite.RelTimeIndicatorConverter
 
visit(LogicalValues) - Method in class org.apache.flink.table.calcite.RelTimeIndicatorConverter
 
visit(LogicalFilter) - Method in class org.apache.flink.table.calcite.RelTimeIndicatorConverter
 
visit(LogicalProject) - Method in class org.apache.flink.table.calcite.RelTimeIndicatorConverter
 
visit(LogicalJoin) - Method in class org.apache.flink.table.calcite.RelTimeIndicatorConverter
 
visit(LogicalCorrelate) - Method in class org.apache.flink.table.calcite.RelTimeIndicatorConverter
 
Visitable<T extends Visitable<T>> - Interface in org.apache.flink.util
This interface marks types as visitable during a traversal.
visitAnnotation(String, String) - Method in class org.apache.flink.runtime.util.DependencyVisitor.AnnotationVisitorImpl
 
visitAnnotation(String, boolean) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
visitAnnotation(String, boolean) - Method in class org.apache.flink.runtime.util.DependencyVisitor
 
visitAnnotationDefault() - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
visitArray(String) - Method in class org.apache.flink.runtime.util.DependencyVisitor.AnnotationVisitorImpl
 
visitCall(RexCall) - Method in class org.apache.flink.table.calcite.RelTimeIndicatorConverter.RexTimeIndicatorMaterializer
 
visitCall(RexCall) - Method in class org.apache.flink.table.codegen.CodeGenerator
 
visitCall(RexCall) - Method in class org.apache.flink.table.plan.util.InputRefVisitor
 
visitCall(RexCall) - Method in class org.apache.flink.table.plan.util.RefFieldAccessorVisitor
 
visitCall(RexCall) - Method in class org.apache.flink.table.plan.util.RexNodeToExpressionConverter
 
visitClassType(String) - Method in class org.apache.flink.runtime.util.DependencyVisitor.SignatureVisitorImpl
 
visitCorrelVariable(RexCorrelVariable) - Method in class org.apache.flink.table.codegen.CodeGenerator
 
visitCorrelVariable(RexCorrelVariable) - Method in class org.apache.flink.table.plan.util.RexNodeToExpressionConverter
 
visitDynamicParam(RexDynamicParam) - Method in class org.apache.flink.table.codegen.CodeGenerator
 
visitDynamicParam(RexDynamicParam) - Method in class org.apache.flink.table.plan.util.RexNodeToExpressionConverter
 
visitEnum(String, String, String) - Method in class org.apache.flink.runtime.util.DependencyVisitor.AnnotationVisitorImpl
 
visitField(int, String, String, String, Object) - Method in class org.apache.flink.runtime.util.DependencyVisitor
 
visitFieldAccess(RexFieldAccess) - Method in class org.apache.flink.table.codegen.CodeGenerator
 
visitFieldAccess(RexFieldAccess) - Method in class org.apache.flink.table.plan.util.RefFieldAccessorVisitor
 
visitFieldAccess(RexFieldAccess) - Method in class org.apache.flink.table.plan.util.RexNodeToExpressionConverter
 
visitFieldInsn(int, String, String, String) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
visitInnerClassType(String) - Method in class org.apache.flink.runtime.util.DependencyVisitor.SignatureVisitorImpl
 
visitInputRef(RexInputRef) - Method in class org.apache.flink.table.calcite.RelTimeIndicatorConverter.RexTimeIndicatorMaterializer
 
visitInputRef(RexInputRef) - Method in class org.apache.flink.table.codegen.CodeGenerator
 
visitInputRef(RexInputRef) - Method in class org.apache.flink.table.plan.util.InputRefVisitor
 
visitInputRef(RexInputRef) - Method in class org.apache.flink.table.plan.util.InputRewriter
 
visitInputRef(RexInputRef) - Method in class org.apache.flink.table.plan.util.RefFieldAccessorVisitor
 
visitInputRef(RexInputRef) - Method in class org.apache.flink.table.plan.util.RexNodeToExpressionConverter
 
visitLdcInsn(Object) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
visitLiteral(RexLiteral) - Method in class org.apache.flink.table.codegen.CodeGenerator
 
visitLiteral(RexLiteral) - Method in class org.apache.flink.table.plan.util.RexNodeToExpressionConverter
 
visitLocalRef(RexLocalRef) - Method in class org.apache.flink.table.codegen.CodeGenerator
 
visitLocalRef(RexLocalRef) - Method in class org.apache.flink.table.plan.util.InputRewriter
 
visitLocalRef(RexLocalRef) - Method in class org.apache.flink.table.plan.util.RexNodeToExpressionConverter
 
visitLocalVariable(String, String, String, Label, Label, int) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
visitMethod(int, String, String, String, String[]) - Method in class org.apache.flink.api.scala.FieldAccessFinder
 
visitMethod(int, String, String, String, String[]) - Method in class org.apache.flink.api.scala.InnerClosureFinder
 
visitMethod(int, String, String, String, String[]) - Method in class org.apache.flink.api.scala.ReturnStatementFinder
 
visitMethod(int, String, String, String, String[]) - Method in class org.apache.flink.runtime.util.DependencyVisitor
 
visitMethodInsn(int, String, String, String) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
visitMethodInsn(int, String, String, String, boolean) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
visitMultiANewArrayInsn(String, int) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
Visitor<T extends Visitable<T>> - Interface in org.apache.flink.util
A visitor encapsulates functionality that is applied to each node in the process of a traversal of a tree or DAD.
visitOver(RexOver) - Method in class org.apache.flink.table.codegen.CodeGenerator
 
visitOver(RexOver) - Method in class org.apache.flink.table.plan.util.RexNodeToExpressionConverter
 
visitParameterAnnotation(int, String, boolean) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
visitParameterType() - Method in class org.apache.flink.runtime.util.DependencyVisitor.SignatureVisitorImpl
 
visitPatternFieldRef(RexPatternFieldRef) - Method in class org.apache.flink.table.codegen.CodeGenerator
 
visitPatternFieldRef(RexPatternFieldRef) - Method in class org.apache.flink.table.plan.util.RexNodeToExpressionConverter
 
visitRangeRef(RexRangeRef) - Method in class org.apache.flink.table.codegen.CodeGenerator
 
visitRangeRef(RexRangeRef) - Method in class org.apache.flink.table.plan.util.RexNodeToExpressionConverter
 
visitReturnType() - Method in class org.apache.flink.runtime.util.DependencyVisitor.SignatureVisitorImpl
 
VISITS - Static variable in class org.apache.flink.examples.java.relational.util.WebLogData
 
VISITS - Static variable in class org.apache.flink.test.testdata.WebLogAnalysisData
 
visitSubQuery(RexSubQuery) - Method in class org.apache.flink.table.codegen.CodeGenerator
 
visitSubQuery(RexSubQuery) - Method in class org.apache.flink.table.plan.util.RexNodeToExpressionConverter
 
visitTryCatchBlock(Label, Label, Label, String) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
visitTypeAnnotation(int, TypePath, String, boolean) - Method in class org.apache.flink.runtime.util.DependencyVisitor.FieldVisitorImpl
 
visitTypeInsn(int, String) - Method in class org.apache.flink.runtime.util.DependencyVisitor.MethodVisitorImpl
 
VOID_TYPE_INFO - Static variable in class org.apache.flink.api.common.typeinfo.BasicTypeInfo
 
VoidBlobStore - Class in org.apache.flink.runtime.blob
A blob store doing nothing.
VoidBlobStore() - Constructor for class org.apache.flink.runtime.blob.VoidBlobStore
 
VoidNamespace - Class in org.apache.flink.runtime.state
Singleton placeholder class for state without a namespace.
VoidNamespaceSerializer - Class in org.apache.flink.runtime.state
Serializer for VoidNamespace.
VoidNamespaceSerializer() - Constructor for class org.apache.flink.runtime.state.VoidNamespaceSerializer
 
VoidSerializer - Class in org.apache.flink.api.common.typeutils.base
 
VoidSerializer() - Constructor for class org.apache.flink.api.common.typeutils.base.VoidSerializer
 

W

WAIT_FOR_YARN_INTERVAL() - Method in class org.apache.flink.yarn.ApplicationClient
 
waitForAll(Collection<? extends Future<?>>) - Static method in class org.apache.flink.runtime.concurrent.FutureUtils
Creates a future that is complete once all of the given futures have completed.
waitForClusterToBeReady() - Method in class org.apache.flink.client.program.ClusterClient
Blocks until the client has determined that the cluster is ready for Job submission.
waitForClusterToBeReady() - Method in class org.apache.flink.client.program.StandaloneClusterClient
 
waitForClusterToBeReady() - Method in class org.apache.flink.yarn.YarnClusterClient
Blocks until all TaskManagers are connected to the JobManager.
waitForClusterToBeReady() - Method in class org.apache.flink.yarn.YarnClusterClientV2
 
waitForCompletion() - Method in class org.apache.flink.api.common.io.FileInputFormat.InputSplitOpenThread
 
waitForFirstBlock() - Method in class org.apache.flink.runtime.io.disk.iomanager.ChannelReaderInputView
 
waitForOtherWorkers() - Method in class org.apache.flink.runtime.iterative.concurrent.SuperstepBarrier
wait on the barrier
waitForSolutionSetUpdate() - Method in class org.apache.flink.runtime.iterative.concurrent.SolutionSetUpdateBarrier
Waits (blocking) on barrier.
waitForTaskManagersToBeRegistered() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
Waits with the default timeout until all task managers have registered at the job manager
waitForTaskManagersToBeRegistered(FiniteDuration) - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
Waits until all task managers have registered at the job manager until the timeout is reached.
waitUntilTaskManagerRegistrationsComplete() - Method in class org.apache.flink.runtime.minicluster.MiniCluster
 
waitUntilTerminal() - Method in class org.apache.flink.runtime.executiongraph.ExecutionGraph
 
WakeupException() - Constructor for exception org.apache.flink.streaming.connectors.kafka.internal.Handover.WakeupException
 
wakeupProducer() - Method in class org.apache.flink.streaming.connectors.kafka.internal.Handover
Wakes the producer thread up.
wasQuarantinedBy(String, ActorSystem) - Method in class org.apache.flink.runtime.akka.DefaultQuarantineHandler
 
wasQuarantinedBy(String, ActorSystem) - Method in interface org.apache.flink.runtime.akka.QuarantineHandler
Callback when the given actor system was quarantined by the given remote actor system.
watchman - Variable in class org.apache.flink.util.TestLogger
 
Watermark - Class in org.apache.flink.streaming.api.watermark
A Watermark tells operators that receive it that no elements with a timestamp older or equal to the watermark timestamp should arrive at the operator.
Watermark(long) - Constructor for class org.apache.flink.streaming.api.watermark.Watermark
Creates a new watermark with the given timestamp in milliseconds.
watermark - Variable in class org.apache.flink.streaming.runtime.streamstatus.StatusWatermarkValve.InputChannelStatus
 
WatermarkQueueEntry - Class in org.apache.flink.streaming.api.operators.async.queue
StreamElementQueueEntry implementation for the Watermark.
WatermarkQueueEntry(Watermark) - Constructor for class org.apache.flink.streaming.api.operators.async.queue.WatermarkQueueEntry
 
WC() - Constructor for class org.apache.flink.table.examples.java.WordCountSQL.WC
 
WC(String, long) - Constructor for class org.apache.flink.table.examples.java.WordCountSQL.WC
 
WC() - Constructor for class org.apache.flink.table.examples.java.WordCountTable.WC
 
WC(String, long) - Constructor for class org.apache.flink.table.examples.java.WordCountTable.WC
 
WC(String, long) - Constructor for class org.apache.flink.table.examples.scala.WordCountSQL.WC
 
WC(String, long) - Constructor for class org.apache.flink.table.examples.scala.WordCountTable.WC
 
WC$() - Constructor for class org.apache.flink.table.examples.scala.WordCountSQL.WC$
 
WC$() - Constructor for class org.apache.flink.table.examples.scala.WordCountTable.WC$
 
WEB_ACCESS_CONTROL_ALLOW_ORIGIN - Static variable in class org.apache.flink.configuration.JobManagerOptions
The config parameter defining the Access-Control-Allow-Origin header for all responses from the web-frontend.
WEB_ARCHIVE_COUNT - Static variable in class org.apache.flink.configuration.JobManagerOptions
The config parameter defining the number of archived jobs for the jobmanager.
WEB_BACKPRESSURE_CLEANUP_INTERVAL - Static variable in class org.apache.flink.configuration.JobManagerOptions
Time after which cached stats are cleaned up if not accessed.
WEB_BACKPRESSURE_DELAY - Static variable in class org.apache.flink.configuration.JobManagerOptions
Delay between stack trace samples to determine back pressure.
WEB_BACKPRESSURE_NUM_SAMPLES - Static variable in class org.apache.flink.configuration.JobManagerOptions
Number of stack trace samples to take to determine back pressure.
WEB_BACKPRESSURE_REFRESH_INTERVAL - Static variable in class org.apache.flink.configuration.JobManagerOptions
Time after which available stats are deprecated and need to be refreshed (by resampling).
WEB_CHECKPOINTS_HISTORY_SIZE - Static variable in class org.apache.flink.configuration.JobManagerOptions
Config parameter defining the number of checkpoints to remember for recent history.
WEB_LOG_PATH - Static variable in class org.apache.flink.configuration.JobManagerOptions
The log file location (may be in /log for standalone but under log directory when using YARN).
WEB_MONITOR_ADDRESS_KEY - Static variable in class org.apache.flink.runtime.webmonitor.RuntimeMonitorHandler
 
WEB_PORT - Static variable in class org.apache.flink.configuration.JobManagerOptions
The port for the runtime monitor web-frontend server.
WEB_SSL_ENABLED - Static variable in class org.apache.flink.configuration.JobManagerOptions
Config parameter to override SSL support for the JobManager Web UI
WEB_SUBMIT_ENABLE - Static variable in class org.apache.flink.configuration.JobManagerOptions
Config parameter indicating whether jobs can be uploaded and run from the web-frontend.
WEB_TMP_DIR - Static variable in class org.apache.flink.configuration.JobManagerOptions
The config parameter defining the flink web directory to be used by the webmonitor.
WEB_UPLOAD_DIR - Static variable in class org.apache.flink.configuration.JobManagerOptions
The config parameter defining the directory for uploading the job jars.
WebFrontendBootstrap - Class in org.apache.flink.runtime.webmonitor.utils
This classes encapsulates the boot-strapping of netty for the web-frontend.
WebFrontendBootstrap(Router, Logger, File, SSLContext, String, int, Configuration) - Constructor for class org.apache.flink.runtime.webmonitor.utils.WebFrontendBootstrap
 
WebLogAnalysis - Class in org.apache.flink.examples.java.relational
This program processes web logs and relational data.
WebLogAnalysis() - Constructor for class org.apache.flink.examples.java.relational.WebLogAnalysis
 
WebLogAnalysis - Class in org.apache.flink.examples.scala.relational
This program processes web logs and relational data.
WebLogAnalysis() - Constructor for class org.apache.flink.examples.scala.relational.WebLogAnalysis
 
WebLogAnalysis$ - Class in org.apache.flink.examples.scala.relational
This program processes web logs and relational data.
WebLogAnalysis$() - Constructor for class org.apache.flink.examples.scala.relational.WebLogAnalysis$
 
WebLogAnalysis.AntiJoinVisits - Class in org.apache.flink.examples.java.relational
CoGroupFunction that realizes an anti-join.
WebLogAnalysis.FilterByRank - Class in org.apache.flink.examples.java.relational
MapFunction that filters for records where the rank exceeds a certain threshold.
WebLogAnalysis.FilterDocByKeyWords - Class in org.apache.flink.examples.java.relational
MapFunction that filters for documents that contain a certain set of keywords.
WebLogAnalysis.FilterVisitsByDate - Class in org.apache.flink.examples.java.relational
MapFunction that filters for records of the visits relation where the year (from the date string) is equal to a certain value.
WebLogAnalysisData - Class in org.apache.flink.test.testdata
 
WebLogData - Class in org.apache.flink.examples.java.relational.util
Provides the default data sets used for the Weblog Analysis example program.
WebLogData() - Constructor for class org.apache.flink.examples.java.relational.util.WebLogData
 
WebLogDataGenerator - Class in org.apache.flink.examples.java.relational.util
Data generator for the WebLogAnalysis example program.
WebLogDataGenerator() - Constructor for class org.apache.flink.examples.java.relational.util.WebLogDataGenerator
 
webMonitor() - Method in class org.apache.flink.runtime.minicluster.FlinkMiniCluster
 
WebMonitor - Interface in org.apache.flink.runtime.webmonitor
Interface for web monitors.
WebMonitorConfig - Class in org.apache.flink.runtime.webmonitor
 
WebMonitorConfig(Configuration) - Constructor for class org.apache.flink.runtime.webmonitor.WebMonitorConfig
 
webMonitorPort() - Method in class org.apache.flink.runtime.jobmanager.JobManager
The port of the web monitor as configured.
WebMonitorUtils - Class in org.apache.flink.runtime.webmonitor
Utilities for the web runtime monitor.
WebMonitorUtils.LogFileLocation - Class in org.apache.flink.runtime.webmonitor
Singleton to hold the log and stdout file
WebRuntimeMonitor - Class in org.apache.flink.runtime.webmonitor
The root component of the web runtime monitor.
WebRuntimeMonitor(Configuration, LeaderRetrievalService, BlobView, ActorSystem) - Constructor for class org.apache.flink.runtime.webmonitor.WebRuntimeMonitor
 
webServerPort() - Method in class org.apache.flink.yarn.YarnMessages.StartYarnSession
 
WEEK - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The SQL WEEK operator.
WEEK() - Method in class org.apache.flink.table.expressions.TimePointUnit$
 
WEEK() - Static method in class org.apache.flink.table.expressions.TimePointUnit
 
WEIGHT_VECTOR_BROADCAST_NAME() - Method in class org.apache.flink.ml.classification.SVM$
 
WEIGHT_VECTOR_BROADCAST_NAME() - Static method in class org.apache.flink.ml.classification.SVM
 
weights() - Method in class org.apache.flink.ml.common.WeightVector
 
weightsOption() - Method in class org.apache.flink.ml.classification.SVM
Stores the learned weight vector after the fit operation
weightsOption() - Method in class org.apache.flink.ml.regression.MultipleLinearRegression
 
WeightVector - Class in org.apache.flink.ml.common
This class represents a weight vector with an intercept, as it is required for many supervised learning tasks param: weights The vector of weights param: intercept The intercept (bias) weight
WeightVector(Vector, double) - Constructor for class org.apache.flink.ml.common.WeightVector
 
WeightVector$ - Class in org.apache.flink.ml.common
 
WeightVector$() - Constructor for class org.apache.flink.ml.common.WeightVector$
 
WEIGHTVECTOR_BROADCAST() - Method in class org.apache.flink.ml.regression.MultipleLinearRegression$
 
WEIGHTVECTOR_BROADCAST() - Static method in class org.apache.flink.ml.regression.MultipleLinearRegression
 
when(S, FiniteDuration, PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
when(S, FiniteDuration, PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
when(S, FiniteDuration, PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
when(S, FiniteDuration, PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
when$default$2() - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
when$default$2() - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
when$default$2() - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
when$default$2() - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
whenUnhandled(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class org.apache.flink.mesos.scheduler.ConnectionMonitor
 
whenUnhandled(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class org.apache.flink.mesos.scheduler.LaunchCoordinator
 
whenUnhandled(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class org.apache.flink.mesos.scheduler.ReconciliationCoordinator
 
whenUnhandled(PartialFunction<FSM.Event<D>, FSM.State<S, D>>) - Static method in class org.apache.flink.mesos.scheduler.TaskMonitor
 
where(int...) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets
Continues a CoGroup transformation.
where(String...) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets
Continues a CoGroup transformation.
where(KeySelector<I1, K>) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets
Continues a CoGroup transformation and defines a KeySelector function for the first co-grouped DataSet.
The KeySelector function is called for each element of the first DataSet and extracts a single key value on which the DataSet is grouped.
where(int...) - Method in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
Continues a Join transformation.
where(String...) - Method in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
Continues a Join transformation.
where(KeySelector<I1, K>) - Method in class org.apache.flink.api.java.operators.join.JoinOperatorSetsBase
Continues a Join transformation and defines a KeySelector function for the first join DataSet.
The KeySelector function is called for each element of the first DataSet and extracts a single key value on which the DataSet is joined.
where(int...) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets
Continues a Join transformation.
where(String...) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets
Continues a Join transformation.
where(KeySelector<I1, K>) - Method in class org.apache.flink.api.java.operators.JoinOperator.JoinOperatorSets
Continues a Join transformation and defines a KeySelector function for the first join DataSet.
The KeySelector function is called for each element of the first DataSet and extracts a single key value on which the DataSet is joined.
where(Seq<Object>) - Method in class org.apache.flink.api.scala.UnfinishedKeyPairOperation
Specify the key fields for the left side of the key based operation.
where(String, Seq<String>) - Method in class org.apache.flink.api.scala.UnfinishedKeyPairOperation
Specify the key fields for the left side of the key based operation.
where(Function1<L, K>, TypeInformation<K>) - Method in class org.apache.flink.api.scala.UnfinishedKeyPairOperation
Specify the key selector function for the left side of the key based operation.
where(IterativeCondition<F>) - Method in class org.apache.flink.cep.pattern.Pattern
Adds a condition that has to be satisfied by an event in order to be considered a match.
where(IterativeCondition<F>) - Method in class org.apache.flink.cep.scala.pattern.Pattern
Adds a condition that has to be satisfied by an event in order to be considered a match.
where(Function2<F, Context<F>, Object>) - Method in class org.apache.flink.cep.scala.pattern.Pattern
Adds a condition that has to be satisfied by an event in order to be considered a match.
where(Function1<F, Object>) - Method in class org.apache.flink.cep.scala.pattern.Pattern
Adds a condition that has to be satisfied by an event in order to be considered a match.
where(KeySelector<T1, KEY>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams
Specifies a KeySelector for elements from the first input.
where(KeySelector<T1, KEY>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams
Specifies a KeySelector for elements from the first input.
where(Function1<T1, KEY>, TypeInformation<KEY>) - Method in class org.apache.flink.streaming.api.scala.CoGroupedStreams
Specifies a KeySelector for elements from the first input.
Where(KeySelector<T1, KEY>, TypeInformation<KEY>) - Constructor for class org.apache.flink.streaming.api.scala.CoGroupedStreams.Where
 
where(Function1<T1, KEY>, TypeInformation<KEY>) - Method in class org.apache.flink.streaming.api.scala.JoinedStreams
Specifies a KeySelector for elements from the first input.
Where(KeySelector<T1, KEY>, TypeInformation<KEY>) - Constructor for class org.apache.flink.streaming.api.scala.JoinedStreams.Where
 
where(Expression) - Method in class org.apache.flink.table.api.Table
Filters out elements that don't pass the filter predicate.
where(String) - Method in class org.apache.flink.table.api.Table
Filters out elements that don't pass the filter predicate.
whereClause(Function1<L, K>, TypeInformation<K>) - Method in class org.apache.flink.api.scala.extensions.impl.acceptPartialFunctions.OnUnfinishedKeyPairOperation
Initiates a join or co-group operation, defining the first half of the where clause with the items of the left data set that will be checked for equality with the ones provided by the second half.
whichChild(Vector) - Method in class org.apache.flink.ml.nn.QuadTree.Node
Finds which child queryPoint lies in.
whiteSpace() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
WhitespaceTokenizer() - Constructor for class org.apache.flink.util.StringValueUtils.WhitespaceTokenizer
Creates a new tokenizer with an undefined internal state.
wholeNumber() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
widerTypeOf(TypeInformation<?>, TypeInformation<?>) - Method in class org.apache.flink.table.typeutils.TypeCoercion$
 
widerTypeOf(TypeInformation<?>, TypeInformation<?>) - Static method in class org.apache.flink.table.typeutils.TypeCoercion
 
WikipediaEditEvent - Class in org.apache.flink.streaming.connectors.wikiedits
 
WikipediaEditEvent(long, String, String, String, String, int, String, boolean, boolean, boolean, boolean, boolean, boolean) - Constructor for class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditEvent
 
WikipediaEditsSource - Class in org.apache.flink.streaming.connectors.wikiedits
 
WikipediaEditsSource() - Constructor for class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditsSource
Creates a source reading WikipediaEditEvent instances from the IRC channel #en.wikipedia.
WikipediaEditsSource(String, int, String) - Constructor for class org.apache.flink.streaming.connectors.wikiedits.WikipediaEditsSource
Creates a source reading WikipediaEditEvent instances from the specified IRC channel.
window(WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1, T2>, W>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.Where.EqualTo
Specifies the window on which the co-group operation works.
window(WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1, T2>, W>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.Where.EqualTo
Specifies the window on which the join operation works.
window(WindowAssigner<? super T, W>) - Method in class org.apache.flink.streaming.api.datastream.KeyedStream
Windows this data stream to a WindowedStream, which evaluates windows over a key grouped stream.
window() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyAllWindowContext
 
window() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
 
window() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction.Context
 
window() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
Returns the window that is being evaluated.
window(WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1, T2>, W>) - Method in class org.apache.flink.streaming.api.scala.CoGroupedStreams.Where.EqualTo
Specifies the window on which the co-group operation works.
window() - Method in class org.apache.flink.streaming.api.scala.function.ProcessAllWindowFunction.Context
 
window() - Method in class org.apache.flink.streaming.api.scala.function.ProcessWindowFunction.Context
Returns the window that is being evaluated.
window(WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1, T2>, W>) - Method in class org.apache.flink.streaming.api.scala.JoinedStreams.Where.EqualTo
Specifies the window on which the join operation works.
window(WindowAssigner<? super T, W>) - Method in class org.apache.flink.streaming.api.scala.KeyedStream
Windows this data stream to a WindowedStream, which evaluates windows over a key grouped stream.
Window - Class in org.apache.flink.streaming.api.windowing.windows
A Window is a grouping of elements into finite buckets.
Window() - Constructor for class org.apache.flink.streaming.api.windowing.windows.Window
 
window() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessAllWindowContext
 
window() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
 
window - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.AbstractPerWindowStateStore
 
window - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Context
 
window - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.Timer
 
window - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
 
window(OverWindow...) - Method in class org.apache.flink.table.api.Table
Defines over-windows on the records of a table.
window(Window) - Method in class org.apache.flink.table.api.Table
Groups the records of a table by assigning them to windows defined by a time or row interval.
window(Seq<OverWindow>) - Method in class org.apache.flink.table.api.Table
Defines over-windows on the records of a table.
Window - Class in org.apache.flink.table.api
A window specification.
Window(Expression, Expression) - Constructor for class org.apache.flink.table.api.Window
 
window() - Method in class org.apache.flink.table.api.WindowedTable
 
window() - Method in class org.apache.flink.table.api.WindowGroupedTable
 
window() - Method in class org.apache.flink.table.plan.logical.WindowAggregate
 
WindowAggregate - Class in org.apache.flink.table.plan.logical
 
WindowAggregate(Seq<Expression>, LogicalWindow, Seq<NamedExpression>, Seq<NamedExpression>, LogicalNode) - Constructor for class org.apache.flink.table.plan.logical.WindowAggregate
 
WindowAggregate$ - Class in org.apache.flink.table.plan.logical
 
WindowAggregate$() - Constructor for class org.apache.flink.table.plan.logical.WindowAggregate$
 
windowAll(WindowAssigner<? super T, W>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Windows this data stream to a KeyedTriggerWindowDataStream, which evaluates windows over a key grouped stream.
windowAll(WindowAssigner<? super T, W>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Windows this data stream to a AllWindowedStream, which evaluates windows over a key grouped stream.
WindowAssigner<T,W extends Window> - Class in org.apache.flink.streaming.api.windowing.assigners
A WindowAssigner assigns zero or more Windows to an element.
WindowAssigner() - Constructor for class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner
 
windowAssigner - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
WindowAssigner.WindowAssignerContext - Class in org.apache.flink.streaming.api.windowing.assigners
A context provided to the WindowAssigner that allows it to query the current processing time.
WindowAssignerContext() - Constructor for class org.apache.flink.streaming.api.windowing.assigners.WindowAssigner.WindowAssignerContext
 
windowAssignerContext - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
 
WindowContext(W) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
 
WindowedStream<T,K,W extends Window> - Class in org.apache.flink.streaming.api.datastream
A WindowedStream represents a data stream where elements are grouped by key, and for each key, the stream of elements is split into windows based on a WindowAssigner.
WindowedStream(KeyedStream<T, K>, WindowAssigner<? super T, W>) - Constructor for class org.apache.flink.streaming.api.datastream.WindowedStream
 
WindowedStream<T,K,W extends Window> - Class in org.apache.flink.streaming.api.scala
A WindowedStream represents a data stream where elements are grouped by key, and for each key, the stream of elements is split into windows based on a WindowAssigner.
WindowedStream(WindowedStream<T, K, W>) - Constructor for class org.apache.flink.streaming.api.scala.WindowedStream
 
WindowedTable - Class in org.apache.flink.table.api
 
WindowedTable(Table, Window) - Constructor for class org.apache.flink.table.api.WindowedTable
 
WindowEnd - Class in org.apache.flink.table.expressions
 
WindowEnd(Expression) - Constructor for class org.apache.flink.table.expressions.WindowEnd
 
windowEnd() - Method in class org.apache.flink.table.runtime.aggregate.TimeWindowPropertyCollector
 
WindowEnd$ - Class in org.apache.flink.table.expressions
 
WindowEnd$() - Constructor for class org.apache.flink.table.expressions.WindowEnd$
 
WindowFunction<IN,OUT,KEY,W extends Window> - Interface in org.apache.flink.streaming.api.functions.windowing
Base interface for functions that are evaluated over keyed (grouped) windows.
WindowFunction<IN,OUT,KEY,W extends Window> - Interface in org.apache.flink.streaming.api.scala.function
Base interface for functions that are evaluated over keyed (grouped) windows.
WindowGroupedTable - Class in org.apache.flink.table.api
 
WindowGroupedTable(Table, Seq<Expression>, Window) - Constructor for class org.apache.flink.table.api.WindowGroupedTable
 
WindowJoin - Class in org.apache.flink.streaming.examples.join
Example illustrating a windowed stream join between two data streams.
WindowJoin() - Constructor for class org.apache.flink.streaming.examples.join.WindowJoin
 
WindowJoin - Class in org.apache.flink.streaming.scala.examples.join
Example illustrating a windowed stream join between two data streams.
WindowJoin() - Constructor for class org.apache.flink.streaming.scala.examples.join.WindowJoin
 
WindowJoin$ - Class in org.apache.flink.streaming.scala.examples.join
Example illustrating a windowed stream join between two data streams.
WindowJoin$() - Constructor for class org.apache.flink.streaming.scala.examples.join.WindowJoin$
 
WindowJoin.Grade - Class in org.apache.flink.streaming.scala.examples.join
 
WindowJoin.Grade$ - Class in org.apache.flink.streaming.scala.examples.join
 
WindowJoin.Person - Class in org.apache.flink.streaming.scala.examples.join
 
WindowJoin.Person$ - Class in org.apache.flink.streaming.scala.examples.join
 
WindowJoin.Salary - Class in org.apache.flink.streaming.scala.examples.join
 
WindowJoin.Salary$ - Class in org.apache.flink.streaming.scala.examples.join
 
WindowJoinSampleData - Class in org.apache.flink.streaming.examples.join
Sample data for the WindowJoin example.
WindowJoinSampleData() - Constructor for class org.apache.flink.streaming.examples.join.WindowJoinSampleData
 
WindowJoinSampleData - Class in org.apache.flink.streaming.scala.examples.join
Sample data for the WindowJoin example.
WindowJoinSampleData() - Constructor for class org.apache.flink.streaming.scala.examples.join.WindowJoinSampleData
 
WindowJoinSampleData$ - Class in org.apache.flink.streaming.scala.examples.join
Sample data for the WindowJoin example.
WindowJoinSampleData$() - Constructor for class org.apache.flink.streaming.scala.examples.join.WindowJoinSampleData$
 
WindowJoinSampleData.GradeSource - Class in org.apache.flink.streaming.examples.join
Continuously generates (name, grade).
WindowJoinSampleData.GradeSource - Class in org.apache.flink.streaming.scala.examples.join
 
WindowJoinSampleData.SalarySource - Class in org.apache.flink.streaming.examples.join
Continuously generates (name, salary).
WindowJoinSampleData.SalarySource - Class in org.apache.flink.streaming.scala.examples.join
 
WindowOperator<K,IN,ACC,OUT,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing
An operator that implements the logic for windowing based on a WindowAssigner and Trigger.
WindowOperator(WindowAssigner<? super IN, W>, TypeSerializer<W>, KeySelector<IN, K>, TypeSerializer<K>, StateDescriptor<? extends AppendingState<IN, ACC>, ?>, InternalWindowFunction<ACC, OUT, K, W>, Trigger<? super IN, ? super W>, long, OutputTag<IN>) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
Creates a new WindowOperator based on the given policies and user functions.
WindowOperator(WindowAssigner<? super IN, W>, TypeSerializer<W>, KeySelector<IN, K>, TypeSerializer<K>, StateDescriptor<? extends AppendingState<IN, ACC>, ?>, InternalWindowFunction<ACC, OUT, K, W>, Trigger<? super IN, ? super W>, long, OutputTag<IN>, LegacyWindowOperatorType) - Constructor for class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
Creates a new WindowOperator based on the given policies and user functions.
WindowOperator.AbstractPerWindowStateStore - Class in org.apache.flink.streaming.runtime.operators.windowing
Base class for per-window KeyedStateStores.
WindowOperator.Context - Class in org.apache.flink.streaming.runtime.operators.windowing
Context is a utility for handling Trigger invocations.
WindowOperator.MergingWindowStateStore - Class in org.apache.flink.streaming.runtime.operators.windowing
Special WindowOperator.AbstractPerWindowStateStore that doesn't allow access to per-window state.
WindowOperator.PerWindowStateStore - Class in org.apache.flink.streaming.runtime.operators.windowing
Regular per-window state store for use with ProcessWindowFunction.
WindowOperator.Timer<K,W extends Window> - Class in org.apache.flink.streaming.runtime.operators.windowing
Internal class for keeping track of in-flight timers.
WindowOperator.WindowContext - Class in org.apache.flink.streaming.runtime.operators.windowing
A utility class for handling ProcessWindowFunction invocations.
WindowProperty - Interface in org.apache.flink.table.expressions
 
windowRange(Window, Window.Group, RelNode) - Method in interface org.apache.flink.table.plan.nodes.OverAggregate
 
WindowReference - Class in org.apache.flink.table.expressions
 
WindowReference(String, Option<TypeInformation<?>>) - Constructor for class org.apache.flink.table.expressions.WindowReference
 
WindowReference$ - Class in org.apache.flink.table.expressions
 
WindowReference$() - Constructor for class org.apache.flink.table.expressions.WindowReference$
 
windowSerializer - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator
For serializing the window in checkpoints.
WindowStart - Class in org.apache.flink.table.expressions
 
WindowStart(Expression) - Constructor for class org.apache.flink.table.expressions.WindowStart
 
windowStart() - Method in class org.apache.flink.table.runtime.aggregate.TimeWindowPropertyCollector
 
WindowStart$ - Class in org.apache.flink.table.expressions
 
WindowStart$() - Constructor for class org.apache.flink.table.expressions.WindowStart$
 
WindowStartEndPropertiesBaseRule - Class in org.apache.flink.table.plan.rules.common
 
WindowStartEndPropertiesBaseRule(RelOptRuleOperand, String) - Constructor for class org.apache.flink.table.plan.rules.common.WindowStartEndPropertiesBaseRule
 
WindowStartEndPropertiesHavingRule - Class in org.apache.flink.table.plan.rules.common
 
WindowStartEndPropertiesHavingRule() - Constructor for class org.apache.flink.table.plan.rules.common.WindowStartEndPropertiesHavingRule
 
WindowStartEndPropertiesHavingRule$ - Class in org.apache.flink.table.plan.rules.common
 
WindowStartEndPropertiesHavingRule$() - Constructor for class org.apache.flink.table.plan.rules.common.WindowStartEndPropertiesHavingRule$
 
WindowStartEndPropertiesRule - Class in org.apache.flink.table.plan.rules.common
 
WindowStartEndPropertiesRule() - Constructor for class org.apache.flink.table.plan.rules.common.WindowStartEndPropertiesRule
 
WindowStartEndPropertiesRule$ - Class in org.apache.flink.table.plan.rules.common
 
WindowStartEndPropertiesRule$() - Constructor for class org.apache.flink.table.plan.rules.common.WindowStartEndPropertiesRule$
 
windowStartPos() - Method in class org.apache.flink.table.runtime.aggregate.DataSetSlideWindowAggReduceGroupFunction
 
windowState() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyAllWindowContext
 
windowState() - Method in class org.apache.flink.streaming.api.functions.windowing.InternalProcessApplyWindowContext
 
windowState() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessAllWindowFunction.Context
State accessor for per-key and per-window state.
windowState() - Method in class org.apache.flink.streaming.api.functions.windowing.ProcessWindowFunction.Context
State accessor for per-key and per-window state.
windowState() - Method in class org.apache.flink.streaming.api.scala.function.ProcessAllWindowFunction.Context
State accessor for per-key and per-window state.
windowState() - Method in class org.apache.flink.streaming.api.scala.function.ProcessWindowFunction.Context
State accessor for per-key and per-window state.
windowState() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessAllWindowContext
 
windowState() - Method in class org.apache.flink.streaming.runtime.operators.windowing.functions.InternalProcessWindowContext
 
windowState() - Method in interface org.apache.flink.streaming.runtime.operators.windowing.functions.InternalWindowFunction.InternalWindowContext
 
windowState - Variable in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
 
windowState() - Method in class org.apache.flink.streaming.runtime.operators.windowing.WindowOperator.WindowContext
 
WindowWordCount - Class in org.apache.flink.streaming.examples.windowing
Implements a windowed version of the streaming "WordCount" program.
WindowWordCount() - Constructor for class org.apache.flink.streaming.examples.windowing.WindowWordCount
 
with(CoGroupFunction<I1, I2, R>) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
Finalizes a CoGroup transformation by applying a RichCoGroupFunction to groups of elements with identical keys.
Each CoGroupFunction call returns an arbitrary number of keys.
with(CrossFunction<I1, I2, R>) - Method in class org.apache.flink.api.java.operators.CrossOperator.DefaultCross
Finalizes a Cross transformation by applying a CrossFunction to each pair of crossed elements.
Each CrossFunction call returns exactly one element.
with(JoinFunction<I1, I2, R>) - Method in interface org.apache.flink.api.java.operators.join.JoinFunctionAssigner
 
with(FlatJoinFunction<I1, I2, R>) - Method in interface org.apache.flink.api.java.operators.join.JoinFunctionAssigner
 
with(FlatJoinFunction<I1, I2, R>) - Method in class org.apache.flink.api.java.operators.JoinOperator.DefaultJoin
Finalizes a Join transformation by applying a RichFlatJoinFunction to each pair of joined elements.
Each JoinFunction call returns exactly one element.
with(JoinFunction<I1, I2, R>) - Method in class org.apache.flink.api.java.operators.JoinOperator.DefaultJoin
 
with(CoGroupFunction<T1, T2, T>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
Deprecated.
This method will be removed once the CoGroupedStreams.WithWindow.apply(CoGroupFunction) method is fixed in the next major version of Flink (2.0).
with(CoGroupFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
Deprecated.
This method will be removed once the CoGroupedStreams.WithWindow.apply(CoGroupFunction, TypeInformation) method is fixed in the next major version of Flink (2.0).
with(JoinFunction<T1, T2, T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
Deprecated.
This method will be removed once the JoinedStreams.WithWindow.apply(JoinFunction) method is fixed in the next major version of Flink (2.0).
with(FlatJoinFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
with(FlatJoinFunction<T1, T2, T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
Deprecated.
This method will be removed once the JoinedStreams.WithWindow.apply(FlatJoinFunction) method is fixed in the next major version of Flink (2.0).
with(JoinFunction<T1, T2, T>, TypeInformation<T>) - Method in class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
Deprecated.
This method will be removed once the JoinedStreams.WithWindow.apply(JoinFunction, TypeInformation) method is fixed in the next major version of Flink (2.0).
withBroadcastSet(DataSet<?>, String) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
 
withBroadcastSet(DataSet<?>, String) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
 
withBroadcastSet(DataSet<?>, String) - Method in interface org.apache.flink.api.java.operators.UdfOperator
Adds a certain data set as a broadcast set to this operator.
withBroadcastSet(DataSet<?>, String) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
withBroadcastSet(DataSet<?>, String) - Method in class org.apache.flink.api.scala.DataSet
Adds a certain data set as a broadcast set to this operator.
withBuiltIns() - Method in class org.apache.flink.table.validate.FunctionCatalog$
Create a new function catalog with built-in functions.
withBuiltIns() - Static method in class org.apache.flink.table.validate.FunctionCatalog
Create a new function catalog with built-in functions.
withConfig(SqlToRelConverter.Config) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
Sets configuration identical to a given SqlToRelConverter.Config.
withConvertTableAccess(boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
 
withCreateValuesRel(boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
 
withDecorrelationEnabled(boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
 
withDeprecatedKeys(String...) - Method in class org.apache.flink.configuration.ConfigOption
Creates a new config option, using this option's key and default value, and adding the given deprecated keys.
withEdges(DataSet<Edge<K, EV>>, GatherFunction<VV, EV, M>, SumFunction<VV, EV, M>, ApplyFunction<K, VV, M>, int) - Static method in class org.apache.flink.graph.gsa.GatherSumApplyIteration
Creates a new gather-sum-apply iteration operator for graphs
withEdges(DataSet<Edge<K, EV>>, ComputeFunction<K, VV, EV, Message>, int) - Static method in class org.apache.flink.graph.pregel.VertexCentricIteration
Creates a new vertex-centric iteration operator.
withEdges(DataSet<Edge<K, EV>>, ComputeFunction<K, VV, EV, Message>, MessageCombiner<K, Message>, int) - Static method in class org.apache.flink.graph.pregel.VertexCentricIteration
Creates a new vertex-centric iteration operator for graphs where the edges are associated with a value (such as a weight or distance).
withEdges(DataSet<Edge<K, EV>>, ScatterFunction<K, VV, Message, EV>, GatherFunction<K, VV, Message>, int) - Static method in class org.apache.flink.graph.spargel.ScatterGatherIteration
Creates a new scatter-gather iteration operator for graphs where the edges are associated with a value (such as a weight or distance).
withExpand(boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
 
withExplain(boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
 
withFeedbackType(String) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream
Changes the feedback type of the iteration and allows the user to apply co-transformations on the input and feedback stream, as in a ConnectedStreams.
withFeedbackType(Class<F>) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream
Changes the feedback type of the iteration and allows the user to apply co-transformations on the input and feedback stream, as in a ConnectedStreams.
withFeedbackType(TypeInformation<F>) - Method in class org.apache.flink.streaming.api.datastream.IterativeStream
Changes the feedback type of the iteration and allows the user to apply co-transformations on the input and feedback stream, as in a ConnectedStreams.
withFilter(String) - Method in class org.apache.flink.hcatalog.HCatInputFormatBase
Specifies a SQL-like filter condition on the table's partition columns.
withForwardedFields(String...) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
Adds semantic information about forwarded fields of the user-defined function.
withForwardedFields(Seq<String>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
withForwardedFields(Seq<String>) - Method in class org.apache.flink.api.scala.DataSet
 
withForwardedFieldsFirst(String...) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
 
withForwardedFieldsFirst(String...) - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
 
withForwardedFieldsFirst(String...) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
Adds semantic information about forwarded fields of the first input of the user-defined function.
withForwardedFieldsFirst(Seq<String>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
withForwardedFieldsFirst(Seq<String>) - Method in class org.apache.flink.api.scala.DataSet
 
withForwardedFieldsSecond(String...) - Method in class org.apache.flink.api.java.operators.CrossOperator.ProjectCross
 
withForwardedFieldsSecond(String...) - Method in class org.apache.flink.api.java.operators.JoinOperator.ProjectJoin
 
withForwardedFieldsSecond(String...) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
Adds semantic information about forwarded fields of the second input of the user-defined function.
withForwardedFieldsSecond(Seq<String>) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
withForwardedFieldsSecond(Seq<String>) - Method in class org.apache.flink.api.scala.DataSet
 
withFrameworkInfo(Protos.FrameworkInfo.Builder) - Method in class org.apache.flink.mesos.util.MesosConfiguration
Revise the configuration with updated framework info.
withGap(Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.EventTimeSessionWindows
Creates a new SessionWindows WindowAssigner that assigns elements to sessions based on the element timestamp.
withGap(Time) - Static method in class org.apache.flink.streaming.api.windowing.assigners.ProcessingTimeSessionWindows
Creates a new SessionWindows WindowAssigner that assigns elements to sessions based on the element timestamp.
withGap(String) - Method in class org.apache.flink.table.api.java.Session$
Creates a session window.
withGap(String) - Static method in class org.apache.flink.table.api.java.Session
Creates a session window.
withGap(Expression) - Method in class org.apache.flink.table.api.scala.Session$
Creates a session window.
withGap(Expression) - Static method in class org.apache.flink.table.api.scala.Session
Creates a session window.
withIdleStateRetentionTime(Time) - Method in class org.apache.flink.table.api.StreamQueryConfig
Specifies the time interval for how long idle state, i.e., state which was not updated, will be retained.
withIdleStateRetentionTime(Time, Time) - Method in class org.apache.flink.table.api.StreamQueryConfig
Specifies a minimum and a maximum time interval for how long idle state, i.e., state which was not updated, will be retained.
within(Time) - Method in class org.apache.flink.cep.pattern.Pattern
Defines the maximum time interval in which a matching pattern has to be completed in order to be considered valid.
within(Time) - Method in class org.apache.flink.cep.scala.pattern.Pattern
Defines the maximum time interval in which a matching pattern has to be completed in order to be considered valid.
withInSubqueryThreshold(int) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
Deprecated.
withInSubQueryThreshold(int) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
 
withLeaseRejectAction(Action1<VirtualMachineLease>) - Method in interface org.apache.flink.mesos.scheduler.TaskSchedulerBuilder
Set the callback action for rejecting a lease.
WithMasterCheckpointHook<E> - Interface in org.apache.flink.streaming.api.checkpoint
This interface can be implemented by streaming functions that need to trigger a "global action" on the master (in the checkpoint coordinator) as part of every checkpoint and restore operation.
withName(String) - Method in class org.apache.flink.table.expressions.Attribute
 
withName(String) - Method in class org.apache.flink.table.expressions.ResolvedFieldReference
 
withName(String) - Static method in class org.apache.flink.table.expressions.TimeIntervalUnit
 
withName(String) - Static method in class org.apache.flink.table.expressions.TimePointUnit
 
withName(String) - Static method in class org.apache.flink.table.expressions.TrimMode
 
withName(String) - Method in class org.apache.flink.table.expressions.UnresolvedFieldReference
 
withName(String) - Method in class org.apache.flink.table.expressions.WindowReference
 
withName(String) - Static method in class org.apache.flink.table.plan.nodes.datastream.AccMode
 
WithOperations(Expression) - Constructor for class org.apache.flink.table.api.scala.ImplicitExpressionConversions.WithOperations
 
withOrders(Order...) - Method in class org.apache.flink.api.java.operators.PartitionOperator
Sets the order of keys for range partitioning.
withParameters(Configuration) - Method in class org.apache.flink.api.java.operators.DataSink
Pass a configuration to the OutputFormat
withParameters(Configuration) - Method in class org.apache.flink.api.java.operators.DataSource
Pass a configuration to the InputFormat
withParameters(Configuration) - Method in class org.apache.flink.api.java.operators.SingleInputUdfOperator
 
withParameters(Configuration) - Method in class org.apache.flink.api.java.operators.TwoInputUdfOperator
 
withParameters(Configuration) - Method in interface org.apache.flink.api.java.operators.UdfOperator
Sets the configuration parameters for the UDF.
withParameters(Configuration) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
withParameters(Configuration) - Method in class org.apache.flink.api.scala.DataSet
 
WithParameters - Interface in org.apache.flink.ml.common
Adds a ParameterMap which can be used to store configuration values
withPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.java.operators.CoGroupOperator.CoGroupOperatorSets.CoGroupOperatorSetsPredicate.CoGroupOperatorWithoutFunction
Sets a custom partitioner for the CoGroup operation.
withPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.java.operators.CoGroupOperator
Sets a custom partitioner for the CoGroup operation.
withPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.java.operators.JoinOperator
Sets a custom partitioner for this join.
withPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.java.operators.SortedGrouping
Uses a custom partitioner for the grouping.
withPartitioner(Partitioner<?>) - Method in class org.apache.flink.api.java.operators.UnsortedGrouping
Uses a custom partitioner for the grouping.
withPartitioner(Partitioner<K>, TypeInformation<K>) - Method in class org.apache.flink.api.scala.CoGroupDataSet
 
withPartitioner(Partitioner<K>, TypeInformation<K>) - Method in class org.apache.flink.api.scala.GroupedDataSet
Sets a custom partitioner for the grouping.
withPartitioner(Partitioner<K>, TypeInformation<K>) - Method in class org.apache.flink.api.scala.JoinDataSet
 
withPartitioner(Partitioner<K>, TypeInformation<K>) - Method in interface org.apache.flink.api.scala.JoinFunctionAssigner
 
withTrimUnusedFields(boolean) - Method in class org.apache.calcite.sql2rel.SqlToRelConverter.ConfigBuilder
 
withViolationHandler(AscendingTimestampExtractor.MonotonyViolationHandler) - Method in class org.apache.flink.streaming.api.functions.timestamps.AscendingTimestampExtractor
Sets the handler for violations to the ascending timestamp order.
WithWindow(DataStream<T1>, DataStream<T2>, KeySelector<T1, KEY>, KeySelector<T2, KEY>, TypeInformation<KEY>, WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1, T2>, W>, Trigger<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>, Evictor<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>) - Constructor for class org.apache.flink.streaming.api.datastream.CoGroupedStreams.WithWindow
 
WithWindow(DataStream<T1>, DataStream<T2>, KeySelector<T1, KEY>, KeySelector<T2, KEY>, TypeInformation<KEY>, WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1, T2>, W>, Trigger<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>, Evictor<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>) - Constructor for class org.apache.flink.streaming.api.datastream.JoinedStreams.WithWindow
 
WithWindow(WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1, T2>, W>, Trigger<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>, Evictor<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>) - Constructor for class org.apache.flink.streaming.api.scala.CoGroupedStreams.Where.EqualTo.WithWindow
 
WithWindow(WindowAssigner<? super CoGroupedStreams.TaggedUnion<T1, T2>, W>, Trigger<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>, Evictor<? super CoGroupedStreams.TaggedUnion<T1, T2>, ? super W>) - Constructor for class org.apache.flink.streaming.api.scala.JoinedStreams.Where.EqualTo.WithWindow
 
Word() - Constructor for class org.apache.flink.examples.java.wordcount.WordCountPojo.Word
 
Word(String, int) - Constructor for class org.apache.flink.examples.java.wordcount.WordCountPojo.Word
 
word - Variable in class org.apache.flink.streaming.examples.socket.SocketWindowWordCount.WordWithCount
 
Word() - Constructor for class org.apache.flink.streaming.examples.wordcount.PojoExample.Word
 
Word(String, int) - Constructor for class org.apache.flink.streaming.examples.wordcount.PojoExample.Word
 
word() - Method in class org.apache.flink.streaming.scala.examples.socket.SocketWindowWordCount.WordWithCount
 
word - Variable in class org.apache.flink.table.examples.java.WordCountSQL.WC
 
word - Variable in class org.apache.flink.table.examples.java.WordCountTable.WC
 
word() - Method in class org.apache.flink.table.examples.scala.WordCountSQL.WC
 
word() - Method in class org.apache.flink.table.examples.scala.WordCountTable.WC
 
WordCount - Class in org.apache.flink.examples.java.wordcount
Implements the "WordCount" program that computes a simple word occurrence histogram over text files.
WordCount() - Constructor for class org.apache.flink.examples.java.wordcount.WordCount
 
WordCount - Class in org.apache.flink.examples.scala.wordcount
Implements the "WordCount" program that computes a simple word occurrence histogram over text files.
WordCount() - Constructor for class org.apache.flink.examples.scala.wordcount.WordCount
 
WordCount - Class in org.apache.flink.streaming.examples.wordcount
Implements the "WordCount" program that computes a simple word occurrence histogram over text files in a streaming fashion.
WordCount() - Constructor for class org.apache.flink.streaming.examples.wordcount.WordCount
 
WordCount$ - Class in org.apache.flink.examples.scala.wordcount
Implements the "WordCount" program that computes a simple word occurrence histogram over text files.
WordCount$() - Constructor for class org.apache.flink.examples.scala.wordcount.WordCount$
 
WordCount.Tokenizer - Class in org.apache.flink.examples.java.wordcount
Implements the string tokenizer that splits sentences into words as a user-defined FlatMapFunction.
WordCount.Tokenizer - Class in org.apache.flink.streaming.examples.wordcount
Implements the string tokenizer that splits sentences into words as a user-defined FlatMapFunction.
WordCountData - Class in org.apache.flink.examples.java.wordcount.util
Provides the default data sets used for the WordCount example program.
WordCountData() - Constructor for class org.apache.flink.examples.java.wordcount.util.WordCountData
 
WordCountData - Class in org.apache.flink.test.testdata
 
WordCountDataPojos - Class in org.apache.flink.storm.wordcount.operators
 
WordCountDataPojos() - Constructor for class org.apache.flink.storm.wordcount.operators.WordCountDataPojos
 
WordCountDataPojos.Sentence - Class in org.apache.flink.storm.wordcount.operators
 
WordCountDataTuple - Class in org.apache.flink.storm.wordcount.operators
 
WordCountDataTuple() - Constructor for class org.apache.flink.storm.wordcount.operators.WordCountDataTuple
 
WordCountFileSpout - Class in org.apache.flink.storm.wordcount.operators
Implements a Spout that reads data from a given local file.
WordCountFileSpout(String) - Constructor for class org.apache.flink.storm.wordcount.operators.WordCountFileSpout
 
WordCountInMemorySpout - Class in org.apache.flink.storm.wordcount.operators
Implements a Spout that reads data from WordCountData.WORDS.
WordCountInMemorySpout() - Constructor for class org.apache.flink.storm.wordcount.operators.WordCountInMemorySpout
 
WordCountLocal - Class in org.apache.flink.storm.wordcount
Implements the "WordCount" program that computes a simple word occurrence histogram over text files in a streaming fashion.
WordCountLocal() - Constructor for class org.apache.flink.storm.wordcount.WordCountLocal
 
WordCountLocalByName - Class in org.apache.flink.storm.wordcount
Implements the "WordCount" program that computes a simple word occurrence histogram over text files in a streaming fashion.
WordCountLocalByName() - Constructor for class org.apache.flink.storm.wordcount.WordCountLocalByName
 
WordCountPojo - Class in org.apache.flink.examples.java.wordcount
This example shows an implementation of WordCount without using the Tuple2 type, but a custom class.
WordCountPojo() - Constructor for class org.apache.flink.examples.java.wordcount.WordCountPojo
 
WordCountPojo.Tokenizer - Class in org.apache.flink.examples.java.wordcount
Implements the string tokenizer that splits sentences into words as a user-defined FlatMapFunction.
WordCountPojo.Word - Class in org.apache.flink.examples.java.wordcount
This is the POJO (Plain Old Java Object) that is being used for all the operations.
WordCountRemoteByClient - Class in org.apache.flink.storm.wordcount
Implements the "WordCount" program that computes a simple word occurrence histogram over text files in a streaming fashion.
WordCountRemoteByClient() - Constructor for class org.apache.flink.storm.wordcount.WordCountRemoteByClient
 
WordCountRemoteBySubmitter - Class in org.apache.flink.storm.wordcount
Implements the "WordCount" program that computes a simple word occurrence histogram over text files in a streaming fashion.
WordCountRemoteBySubmitter() - Constructor for class org.apache.flink.storm.wordcount.WordCountRemoteBySubmitter
 
WordCountSQL - Class in org.apache.flink.table.examples.java
Simple example that shows how the Batch SQL API is used in Java.
WordCountSQL() - Constructor for class org.apache.flink.table.examples.java.WordCountSQL
 
WordCountSQL - Class in org.apache.flink.table.examples.scala
Simple example that shows how the Batch SQL API is used in Scala.
WordCountSQL() - Constructor for class org.apache.flink.table.examples.scala.WordCountSQL
 
WordCountSQL$ - Class in org.apache.flink.table.examples.scala
Simple example that shows how the Batch SQL API is used in Scala.
WordCountSQL$() - Constructor for class org.apache.flink.table.examples.scala.WordCountSQL$
 
WordCountSQL.WC - Class in org.apache.flink.table.examples.java
 
WordCountSQL.WC - Class in org.apache.flink.table.examples.scala
 
WordCountSQL.WC$ - Class in org.apache.flink.table.examples.scala
 
WordCountTable - Class in org.apache.flink.table.examples.java
Simple example for demonstrating the use of the Table API for a Word Count in Java.
WordCountTable() - Constructor for class org.apache.flink.table.examples.java.WordCountTable
 
WordCountTable - Class in org.apache.flink.table.examples.scala
Simple example for demonstrating the use of the Table API for a Word Count in Scala.
WordCountTable() - Constructor for class org.apache.flink.table.examples.scala.WordCountTable
 
WordCountTable$ - Class in org.apache.flink.table.examples.scala
Simple example for demonstrating the use of the Table API for a Word Count in Scala.
WordCountTable$() - Constructor for class org.apache.flink.table.examples.scala.WordCountTable$
 
WordCountTable.WC - Class in org.apache.flink.table.examples.java
 
WordCountTable.WC - Class in org.apache.flink.table.examples.scala
 
WordCountTable.WC$ - Class in org.apache.flink.table.examples.scala
 
WordCountTopology - Class in org.apache.flink.storm.wordcount
Implements the "WordCount" program that computes a simple word occurrence histogram over text files in a streaming fashion.
WordCountTopology() - Constructor for class org.apache.flink.storm.wordcount.WordCountTopology
 
WORDS - Static variable in class org.apache.flink.examples.java.wordcount.util.WordCountData
 
WordWithCount() - Constructor for class org.apache.flink.streaming.examples.socket.SocketWindowWordCount.WordWithCount
 
WordWithCount(String, long) - Constructor for class org.apache.flink.streaming.examples.socket.SocketWindowWordCount.WordWithCount
 
WordWithCount(String, long) - Constructor for class org.apache.flink.streaming.scala.examples.socket.SocketWindowWordCount.WordWithCount
 
WordWithCount$() - Constructor for class org.apache.flink.streaming.scala.examples.socket.SocketWindowWordCount.WordWithCount$
 
WorkerDoneEvent - Class in org.apache.flink.runtime.iterative.event
 
WorkerDoneEvent() - Constructor for class org.apache.flink.runtime.iterative.event.WorkerDoneEvent
 
WorkerDoneEvent(int, String, Value) - Constructor for class org.apache.flink.runtime.iterative.event.WorkerDoneEvent
 
WorkerDoneEvent(int, Map<String, Aggregator<?>>) - Constructor for class org.apache.flink.runtime.iterative.event.WorkerDoneEvent
 
WorkerRegistration<WorkerType extends Serializable> - Class in org.apache.flink.runtime.resourcemanager.registration
This class extends the TaskExecutorConnection, adding the worker information.
WorkerRegistration(TaskExecutorGateway, WorkerType) - Constructor for class org.apache.flink.runtime.resourcemanager.registration.WorkerRegistration
 
workerStarted(ResourceID) - Method in class org.apache.flink.mesos.runtime.clusterframework.MesosFlinkResourceManager
Accept the given started worker into the internal state.
workerStarted(ResourceID) - Method in class org.apache.flink.runtime.clusterframework.FlinkResourceManager
Callback when a worker was started.
workerStarted(ResourceID) - Method in class org.apache.flink.runtime.clusterframework.standalone.StandaloneResourceManager
 
workerStarted(ResourceID) - Method in class org.apache.flink.runtime.resourcemanager.ResourceManager
Callback when a worker was started.
workerStarted(ResourceID) - Method in class org.apache.flink.runtime.resourcemanager.StandaloneResourceManager
 
workerStarted(ResourceID) - Method in class org.apache.flink.yarn.YarnFlinkResourceManager
 
workerStarted(ResourceID) - Method in class org.apache.flink.yarn.YarnResourceManager
 
workingDirectory - Variable in class org.apache.flink.yarn.highavailability.YarnHighAvailabilityServices
The working directory of this YARN application.
worksetAggregator - Variable in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
worksetBackChannel - Variable in class org.apache.flink.runtime.iterative.task.AbstractIterativeTask
 
WorksetEmptyConvergenceCriterion - Class in org.apache.flink.runtime.iterative.convergence
A workset iteration is by definition converged if no records have been updated in the solutionset
WorksetEmptyConvergenceCriterion() - Constructor for class org.apache.flink.runtime.iterative.convergence.WorksetEmptyConvergenceCriterion
 
WorksetIterationNode - Class in org.apache.flink.optimizer.dag
A node in the optimizer's program representation for a workset iteration.
WorksetIterationNode(DeltaIterationBase<?, ?>) - Constructor for class org.apache.flink.optimizer.dag.WorksetIterationNode
Creates a new node with a single input for the optimizer plan.
WorksetIterationNode.SingleRootJoiner - Class in org.apache.flink.optimizer.dag
 
WorksetIterationPlanNode - Class in org.apache.flink.optimizer.plan
A node in the execution, representing a workset iteration (delta iteration).
WorksetIterationPlanNode(WorksetIterationNode, String, Channel, Channel, SolutionSetPlanNode, WorksetPlanNode, PlanNode, PlanNode) - Constructor for class org.apache.flink.optimizer.plan.WorksetIterationPlanNode
 
WorksetNode - Class in org.apache.flink.optimizer.dag
The optimizer's internal representation of the partial solution that is input to a bulk iteration.
WorksetNode(DeltaIterationBase.WorksetPlaceHolder<?>, WorksetIterationNode) - Constructor for class org.apache.flink.optimizer.dag.WorksetNode
 
WorksetPlaceHolder(DeltaIterationBase<?, WT>, OperatorInformation<WT>) - Constructor for class org.apache.flink.api.common.operators.base.DeltaIterationBase.WorksetPlaceHolder
 
WorksetPlanNode - Class in org.apache.flink.optimizer.plan
Plan candidate node for partial solution of a bulk iteration.
WorksetPlanNode(WorksetNode, String, GlobalProperties, LocalProperties, Channel) - Constructor for class org.apache.flink.optimizer.plan.WorksetPlanNode
 
WorksetUpdateOutputCollector<T> - Class in org.apache.flink.runtime.iterative.io
A Collector to update the iteration workset (partial solution for bulk iterations).
WorksetUpdateOutputCollector(DataOutputView, TypeSerializer<T>) - Constructor for class org.apache.flink.runtime.iterative.io.WorksetUpdateOutputCollector
 
WorksetUpdateOutputCollector(DataOutputView, TypeSerializer<T>, Collector<T>) - Constructor for class org.apache.flink.runtime.iterative.io.WorksetUpdateOutputCollector
 
wrap(byte[]) - Method in class org.apache.flink.core.memory.HeapMemorySegment.HeapMemorySegmentFactory
 
wrap(int, int) - Method in class org.apache.flink.core.memory.HeapMemorySegment
 
wrap(byte[]) - Method in class org.apache.flink.core.memory.HybridMemorySegment.HybridMemorySegmentFactory
 
wrap(int, int) - Method in class org.apache.flink.core.memory.HybridMemorySegment
 
wrap(int, int) - Method in class org.apache.flink.core.memory.MemorySegment
Wraps the chunk of the underlying memory located between offset and length in a NIO ByteBuffer.
wrap(byte[]) - Method in interface org.apache.flink.core.memory.MemorySegmentFactory.Factory
Creates a new memory segment that targets the given heap memory region.
wrap(byte[]) - Static method in class org.apache.flink.core.memory.MemorySegmentFactory
Creates a new memory segment that targets the given heap memory region.
wrapAsByteBuffer() - Method in class org.apache.flink.runtime.util.DataOutputSerializer
 
wrapHook(MasterTriggerRestoreHook<T>, ClassLoader) - Static method in class org.apache.flink.runtime.checkpoint.hooks.MasterHooks
Wraps a hook such that the user-code classloader is applied when the hook is invoked.
wrappedCollector() - Method in class org.apache.flink.table.runtime.aggregate.TimeWindowPropertyCollector
 
wrappedFunction - Variable in class org.apache.flink.api.java.operators.translation.WrappingFunction
 
wrappedPattern() - Method in class org.apache.flink.cep.scala.pattern.Pattern
 
wrappedPatternStream() - Method in class org.apache.flink.cep.scala.PatternStream
 
wrapper() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.BoxedPrimitiveDescriptor
 
wrapper() - Method in class org.apache.flink.api.scala.codegen.TypeDescriptors.PrimitiveDescriptor
 
WrappingFlatJoinFunction(JoinFunction<IN1, IN2, OUT>) - Constructor for class org.apache.flink.api.java.operators.JoinOperator.DefaultJoin.WrappingFlatJoinFunction
 
WrappingFunction<T extends Function> - Class in org.apache.flink.api.java.operators.translation
 
WrappingFunction(T) - Constructor for class org.apache.flink.api.java.operators.translation.WrappingFunction
 
WrappingProxy<T> - Interface in org.apache.flink.util
 
WrappingProxyCloseable<T extends Closeable> - Interface in org.apache.flink.core.fs
WrappingProxy for Closeable that is also closeable.
WrappingProxyUtil - Class in org.apache.flink.util
 
WrappingRuntimeException - Exception in org.apache.flink.util
A runtime exception that is explicitly used to wrap non-runtime exceptions.
WrappingRuntimeException(Throwable) - Constructor for exception org.apache.flink.util.WrappingRuntimeException
 
WrappingRuntimeException(String, Throwable) - Constructor for exception org.apache.flink.util.WrappingRuntimeException
 
wrapPooledHeapMemory(byte[], Object) - Method in class org.apache.flink.core.memory.HeapMemorySegment.HeapMemorySegmentFactory
 
wrapPooledHeapMemory(byte[], Object) - Method in class org.apache.flink.core.memory.HybridMemorySegment.HybridMemorySegmentFactory
 
wrapPooledHeapMemory(byte[], Object) - Method in interface org.apache.flink.core.memory.MemorySegmentFactory.Factory
Creates a memory segment that wraps the given byte array.
wrapPooledHeapMemory(byte[], Object) - Static method in class org.apache.flink.core.memory.MemorySegmentFactory
Creates a memory segment that wraps the given byte array.
wrapPooledOffHeapMemory(ByteBuffer, Object) - Method in class org.apache.flink.core.memory.HeapMemorySegment.HeapMemorySegmentFactory
 
wrapPooledOffHeapMemory(ByteBuffer, Object) - Method in class org.apache.flink.core.memory.HybridMemorySegment.HybridMemorySegmentFactory
 
wrapPooledOffHeapMemory(ByteBuffer, Object) - Method in interface org.apache.flink.core.memory.MemorySegmentFactory.Factory
Creates a memory segment that wraps the off-heap memory backing the given ByteBuffer.
wrapPooledOffHeapMemory(ByteBuffer, Object) - Static method in class org.apache.flink.core.memory.MemorySegmentFactory
Creates a memory segment that wraps the off-heap memory backing the given ByteBuffer.
wrapSafe(FSDataInputStream, SafetyNetCloseableRegistry) - Static method in class org.apache.flink.core.fs.ClosingFSDataInputStream
 
wrapSafe(FSDataInputStream, SafetyNetCloseableRegistry, String) - Static method in class org.apache.flink.core.fs.ClosingFSDataInputStream
 
wrapSafe(FSDataOutputStream, SafetyNetCloseableRegistry) - Static method in class org.apache.flink.core.fs.ClosingFSDataOutputStream
 
wrapSafe(FSDataOutputStream, SafetyNetCloseableRegistry, String) - Static method in class org.apache.flink.core.fs.ClosingFSDataOutputStream
 
wrapSingleHandle(T) - Static method in class org.apache.flink.runtime.state.ChainedStateHandle
 
WritableComparator<T extends org.apache.hadoop.io.Writable & Comparable<T>> - Class in org.apache.flink.api.java.typeutils.runtime
 
WritableComparator(boolean, Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.WritableComparator
 
WritableDescriptor(int, scala.reflect.macros.Context.universe) - Constructor for class org.apache.flink.api.scala.codegen.TypeDescriptors.WritableDescriptor
 
WritableSerializer<T extends org.apache.hadoop.io.Writable> - Class in org.apache.flink.api.java.typeutils.runtime
 
WritableSerializer(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.WritableSerializer
 
WritableSerializer - Class in org.apache.flink.runtime.akka.serialization
 
WritableSerializer() - Constructor for class org.apache.flink.runtime.akka.serialization.WritableSerializer
 
WritableSerializer.WritableSerializerConfigSnapshot<T extends org.apache.hadoop.io.Writable> - Class in org.apache.flink.api.java.typeutils.runtime
 
WritableSerializerConfigSnapshot() - Constructor for class org.apache.flink.api.java.typeutils.runtime.WritableSerializer.WritableSerializerConfigSnapshot
This empty nullary constructor is required for deserializing the configuration.
WritableSerializerConfigSnapshot(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.runtime.WritableSerializer.WritableSerializerConfigSnapshot
 
WritableTypeInfo<T extends org.apache.hadoop.io.Writable> - Class in org.apache.flink.api.java.typeutils
Type information for data types that extend Hadoop's Writable interface.
WritableTypeInfo(Class<T>) - Constructor for class org.apache.flink.api.java.typeutils.WritableTypeInfo
 
write(byte[]) - Method in class org.apache.flink.api.common.io.BinaryOutputFormat.BlockBasedOutput
 
write(byte[], int, int) - Method in class org.apache.flink.api.common.io.BinaryOutputFormat.BlockBasedOutput
 
write(int) - Method in class org.apache.flink.api.common.io.BinaryOutputFormat.BlockBasedOutput
 
write(DataOutputView) - Method in class org.apache.flink.api.common.io.BlockInfo
 
write(DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.EnumSerializer.EnumSerializerConfigSnapshot
 
write(DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.GenericArraySerializerConfigSnapshot
 
write(DataOutputView) - Method in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerConfigSnapshot
 
write(DataOutputView) - Method in class org.apache.flink.api.common.typeutils.GenericTypeSerializerConfigSnapshot
 
write(DataOutputView) - Method in class org.apache.flink.api.common.typeutils.ParameterlessTypeSerializerConfig
 
write(DataOutputView) - Method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil.TypeSerializerSerializationProxy
 
write(FileOutputFormat<T>, String) - Method in class org.apache.flink.api.java.DataSet
Writes a DataSet using a FileOutputFormat to a specified location.
write(FileOutputFormat<T>, String, FileSystem.WriteMode) - Method in class org.apache.flink.api.java.DataSet
Writes a DataSet using a FileOutputFormat to a specified location.
write(ObjectOutputStream) - Method in class org.apache.flink.api.java.hadoop.common.HadoopInputFormatCommonBase
 
write(ObjectOutputStream) - Method in class org.apache.flink.api.java.hadoop.common.HadoopOutputFormatCommonBase
 
write(DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.AvroSerializer.AvroSerializerConfigSnapshot
 
write(int) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputViewStream
 
write(byte[], int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputViewStream
 
write(Kryo, Output, T) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.JavaSerializer
 
write(Kryo, Output, Schema) - Method in class org.apache.flink.api.java.typeutils.runtime.kryo.Serializers.AvroSchemaSerializer
 
write(Kryo, Output, Object) - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot.DummyKryoSerializerClass
 
write(DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.KryoRegistrationSerializerConfigSnapshot
 
write(DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoSerializer.PojoSerializerConfigSnapshot
 
write(DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleSerializerConfigSnapshot
 
write(FileOutputFormat<T>, String, FileSystem.WriteMode) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
write(FileOutputFormat<T>, String, FileSystem.WriteMode) - Method in class org.apache.flink.api.scala.DataSet
Writes this DataSet to the specified location using a custom FileOutputFormat.
write(DataOutputView) - Method in class org.apache.flink.api.scala.typeutils.EnumValueSerializer.ScalaEnumSerializerConfigSnapshot
 
write(DataOutputView) - Method in class org.apache.flink.configuration.Configuration
 
write(DataOutputView) - Method in class org.apache.flink.configuration.DelegatingConfiguration
 
write(int) - Method in class org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
write(byte[]) - Method in class org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
write(byte[], int, int) - Method in class org.apache.flink.core.fs.FSDataOutputStreamWrapper
 
write(int) - Method in class org.apache.flink.core.fs.local.LocalDataOutputStream
 
write(byte[], int, int) - Method in class org.apache.flink.core.fs.local.LocalDataOutputStream
 
write(DataOutputView) - Method in class org.apache.flink.core.fs.Path
 
write(DataOutputView) - Method in interface org.apache.flink.core.io.IOReadableWritable
Writes the object's internal data to the given data output view.
write(DataOutputView) - Method in class org.apache.flink.core.io.VersionedIOReadableWritable
 
write(int) - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
write(byte[], int, int) - Method in class org.apache.flink.core.memory.ByteArrayOutputStreamWithPos
 
write(DataInputView, int) - Method in interface org.apache.flink.core.memory.DataOutputView
Copies numBytes bytes from the source to this view.
write(DataInputView, int) - Method in class org.apache.flink.core.memory.DataOutputViewStreamWrapper
 
write(DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.IntValueArray
 
write(DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.LongValueArray
 
write(DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.NullValueArray
 
write(DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.StringValueArray
 
write(DataOutputView) - Method in class org.apache.flink.ml.recommendation.ALS.OutLinks
 
write(int) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataOutputStream
 
write(byte[], int, int) - Method in class org.apache.flink.runtime.fs.hdfs.HadoopDataOutputStream
 
write(DataOutputView) - Method in class org.apache.flink.runtime.io.network.api.CancelCheckpointMarker
 
write(DataOutputView) - Method in class org.apache.flink.runtime.io.network.api.CheckpointBarrier
 
write(DataOutputView) - Method in class org.apache.flink.runtime.io.network.api.EndOfPartitionEvent
 
write(DataOutputView) - Method in class org.apache.flink.runtime.io.network.api.EndOfSuperstepEvent
 
write(DataOutputView) - Method in class org.apache.flink.runtime.iterative.event.IterationEventWithAggregators
 
write(DataOutputView) - Method in class org.apache.flink.runtime.iterative.event.TerminationEvent
 
write(DataOutputView) - Method in class org.apache.flink.runtime.iterative.event.WorkerDoneEvent
 
write(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
 
write(byte[]) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
 
write(byte[], int, int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
 
write(DataInputView, int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
 
write(T) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
Writes a given record to this sort buffer.
write(T) - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
Writes a given record to this sort buffer.
write(T) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
Writes a given record to this sort buffer.
write(DataOutputView) - Method in class org.apache.flink.runtime.plugable.NonReusingDeserializationDelegate
 
write(DataOutputView) - Method in class org.apache.flink.runtime.plugable.ReusingDeserializationDelegate
 
write(DataOutputView) - Method in class org.apache.flink.runtime.plugable.SerializationDelegate
 
write(int) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
 
write(byte[], int, int) - Method in class org.apache.flink.runtime.state.filesystem.FsCheckpointStreamFactory.FsCheckpointStateOutputStream
 
write(DataOutputView) - Method in class org.apache.flink.runtime.state.KeyedBackendSerializationProxy
 
write(int) - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
 
write(byte[], int, int) - Method in class org.apache.flink.runtime.state.memory.MemCheckpointStreamFactory.MemoryCheckpointOutputStream
 
write(int) - Method in class org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
 
write(byte[]) - Method in class org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
 
write(byte[], int, int) - Method in class org.apache.flink.runtime.state.NonClosingCheckpointOutputStream
 
write(DataOutputView) - Method in class org.apache.flink.runtime.state.OperatorBackendSerializationProxy
 
write(int) - Method in class org.apache.flink.runtime.util.DataOutputSerializer
 
write(byte[]) - Method in class org.apache.flink.runtime.util.DataOutputSerializer
 
write(byte[], int, int) - Method in class org.apache.flink.runtime.util.DataOutputSerializer
 
write(DataInputView, int) - Method in class org.apache.flink.runtime.util.DataOutputSerializer
 
write(String, ArrayList<IN>) - Method in class org.apache.flink.streaming.api.functions.sink.WriteFormat
Writes the contents of tupleList to the file specified by path.
write(String, ArrayList<IN>) - Method in class org.apache.flink.streaming.api.functions.sink.WriteFormatAsCsv
 
write(String, ArrayList<IN>) - Method in class org.apache.flink.streaming.api.functions.sink.WriteFormatAsText
 
write(Tuple2<K, V>) - Method in class org.apache.flink.streaming.connectors.fs.AvroKeyValueSinkWriter
 
write(Tuple2<K, V>) - Method in class org.apache.flink.streaming.connectors.fs.SequenceFileWriter
 
write(T) - Method in class org.apache.flink.streaming.connectors.fs.StringWriter
 
write(T) - Method in interface org.apache.flink.streaming.connectors.fs.Writer
Writes one element to the bucket file.
write(DataOutputView) - Method in class org.apache.flink.types.BooleanValue
 
write(DataOutputView) - Method in class org.apache.flink.types.ByteValue
 
write(DataOutputView) - Method in class org.apache.flink.types.CharValue
 
write(DataOutputView) - Method in class org.apache.flink.types.DoubleValue
 
write(DataOutputView) - Method in class org.apache.flink.types.FloatValue
 
write(DataOutputView) - Method in class org.apache.flink.types.IntValue
 
write(DataOutputView) - Method in class org.apache.flink.types.ListValue
 
write(DataOutputView) - Method in class org.apache.flink.types.LongValue
 
write(DataOutputView) - Method in class org.apache.flink.types.MapValue
 
write(DataOutputView) - Method in class org.apache.flink.types.NullValue
 
write(DataOutputView) - Method in class org.apache.flink.types.Record
 
write(DataOutputView) - Method in class org.apache.flink.types.ShortValue
 
write(DataOutputView) - Method in class org.apache.flink.types.StringValue
 
write$default$3() - Static method in class org.apache.flink.api.scala.CrossDataSet
 
writeArrayEnd() - Method in class org.apache.flink.api.avro.DataOutputEncoder
 
writeArrayEnd() - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeArrayStart() - Method in class org.apache.flink.api.avro.DataOutputEncoder
 
writeArrayStart() - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeAsCsv(String) - Method in class org.apache.flink.api.java.DataSet
Writes a Tuple DataSet as CSV file(s) to the specified location.
Note: Only a Tuple DataSet can written as a CSV file.
For each Tuple field the result of Object.toString() is written.
writeAsCsv(String, FileSystem.WriteMode) - Method in class org.apache.flink.api.java.DataSet
Writes a Tuple DataSet as CSV file(s) to the specified location.
Note: Only a Tuple DataSet can written as a CSV file.
For each Tuple field the result of Object.toString() is written.
writeAsCsv(String, String, String) - Method in class org.apache.flink.api.java.DataSet
Writes a Tuple DataSet as CSV file(s) to the specified location with the specified field and line delimiters.
Note: Only a Tuple DataSet can written as a CSV file.
For each Tuple field the result of Object.toString() is written.
writeAsCsv(String, String, String, FileSystem.WriteMode) - Method in class org.apache.flink.api.java.DataSet
Writes a Tuple DataSet as CSV file(s) to the specified location with the specified field and line delimiters.
Note: Only a Tuple DataSet can written as a CSV file.
§ * For each Tuple field the result of Object.toString() is written.
writeAsCsv(String, String, String, FileSystem.WriteMode) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
writeAsCsv(String, String, String, FileSystem.WriteMode) - Method in class org.apache.flink.api.scala.DataSet
Writes this DataSet to the specified location as CSV file(s).
writeAsCsv(String) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Writes a DataStream to the file specified by the path parameter.
writeAsCsv(String, FileSystem.WriteMode) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Writes a DataStream to the file specified by the path parameter.
writeAsCsv(String, FileSystem.WriteMode, String, String) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Writes a DataStream to the file specified by the path parameter.
writeAsCsv(String) - Method in class org.apache.flink.streaming.api.scala.DataStream
Writes the DataStream in CSV format to the file specified by the path parameter.
writeAsCsv(String, FileSystem.WriteMode) - Method in class org.apache.flink.streaming.api.scala.DataStream
Writes the DataStream in CSV format to the file specified by the path parameter.
writeAsCsv(String, FileSystem.WriteMode, String, String) - Method in class org.apache.flink.streaming.api.scala.DataStream
Writes the DataStream in CSV format to the file specified by the path parameter.
writeAsCsv$default$2() - Static method in class org.apache.flink.api.scala.CrossDataSet
 
writeAsCsv$default$3() - Static method in class org.apache.flink.api.scala.CrossDataSet
 
writeAsCsv$default$4() - Static method in class org.apache.flink.api.scala.CrossDataSet
 
writeAsFormattedText(String, TextOutputFormat.TextFormatter<T>) - Method in class org.apache.flink.api.java.DataSet
Writes a DataSet as text file(s) to the specified location.
For each element of the DataSet the result of TextOutputFormat.TextFormatter.format(Object) is written.
writeAsFormattedText(String, FileSystem.WriteMode, TextOutputFormat.TextFormatter<T>) - Method in class org.apache.flink.api.java.DataSet
Writes a DataSet as text file(s) to the specified location.
For each element of the DataSet the result of TextOutputFormat.TextFormatter.format(Object) is written.
writeAsText(String) - Method in class org.apache.flink.api.java.DataSet
Writes a DataSet as text file(s) to the specified location.
For each element of the DataSet the result of Object.toString() is written.

Output files and directories
What output how writeAsText() method produces is depending on other circumstance A directory is created and multiple files are written underneath.
writeAsText(String, FileSystem.WriteMode) - Method in class org.apache.flink.api.java.DataSet
Writes a DataSet as text file(s) to the specified location.
For each element of the DataSet the result of Object.toString() is written.
writeAsText(String, FileSystem.WriteMode) - Static method in class org.apache.flink.api.scala.CrossDataSet
 
writeAsText(String, FileSystem.WriteMode) - Method in class org.apache.flink.api.scala.DataSet
Writes this DataSet to the specified location.
writeAsText(String) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Writes a DataStream to the file specified by path in text format.
writeAsText(String, FileSystem.WriteMode) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Writes a DataStream to the file specified by path in text format.
writeAsText(String) - Method in class org.apache.flink.streaming.api.scala.DataStream
Writes a DataStream to the file specified by path in text format.
writeAsText(String, FileSystem.WriteMode) - Method in class org.apache.flink.streaming.api.scala.DataStream
Writes a DataStream to the file specified by path in text format.
writeAsText$default$2() - Static method in class org.apache.flink.api.scala.CrossDataSet
 
writeBack(BT) - Method in class org.apache.flink.runtime.operators.hash.MutableHashTable.HashBucketIterator
 
writeBehindBuffers - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
The queue of buffers that can be used for write-behind.
writeBehindBuffersAvailable - Variable in class org.apache.flink.runtime.operators.hash.MutableHashTable
The number of buffers in the write behind queue that are actually not write behind buffers, but regular buffers that only have not yet returned.
writeBigInteger(BigInteger, DataOutputView) - Static method in class org.apache.flink.api.common.typeutils.base.BigIntSerializer
 
writeBlock(MemorySegment) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBlockWriterWithCallback
Issues a asynchronous write request to the writer.
writeBlock(Buffer) - Method in class org.apache.flink.runtime.io.disk.iomanager.AsynchronousBufferFileWriter
 
writeBlock(T) - Method in interface org.apache.flink.runtime.io.disk.iomanager.BlockChannelWriterWithCallback
Writes the given block.
writeBoolean(boolean) - Method in class org.apache.flink.api.avro.DataOutputEncoder
 
writeBoolean(boolean) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeBoolean(boolean) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
 
writeBoolean(boolean) - Method in class org.apache.flink.runtime.util.DataOutputSerializer
 
writeBuffer(Buffer, int) - Method in class org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
 
writeBufferToAllChannels(Buffer) - Method in class org.apache.flink.runtime.io.network.api.writer.ResultPartitionWriter
Writes the given buffer to all available target channels.
writeByte(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
 
writeByte(int) - Method in class org.apache.flink.runtime.util.DataOutputSerializer
 
writeBytes(byte[], int, int) - Method in class org.apache.flink.api.avro.DataOutputEncoder
 
writeBytes(ByteBuffer) - Method in class org.apache.flink.api.avro.DataOutputEncoder
 
writeBytes(byte[], int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeBytes(ByteBuffer) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeBytes(String) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
 
writeBytes(String) - Method in class org.apache.flink.runtime.util.DataOutputSerializer
 
writeChar(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
 
writeChar(int) - Method in class org.apache.flink.runtime.util.DataOutputSerializer
 
writeChars(String) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
 
writeChars(String) - Method in class org.apache.flink.runtime.util.DataOutputSerializer
 
writeConfiguration(Configuration, File) - Static method in class org.apache.flink.runtime.clusterframework.BootstrapTools
Writes a Flink YAML config file from a Flink Configuration object.
writeCSV(String, String, String) - Method in class org.apache.flink.graph.drivers.ClusteringCoefficient
 
writeCSV(String, String, String) - Method in class org.apache.flink.graph.drivers.ConnectedComponents
 
writeCSV(String, String, String) - Method in class org.apache.flink.graph.drivers.EdgeList
 
writeCSV(String, String, String) - Method in interface org.apache.flink.graph.drivers.output.CSV
Write execution results to file using CSV format.
writeCSV(String, String, String) - Method in class org.apache.flink.graph.drivers.SimpleDriver
Write execution results to file using CSV format.
writeCSV(String, String, String) - Method in class org.apache.flink.graph.drivers.TriangleListing
 
writeCurrentKeyWithGroupAndNamespace() - Method in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
 
writeDouble(double) - Method in class org.apache.flink.api.avro.DataOutputEncoder
 
writeDouble(double) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeDouble(double) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
 
writeDouble(double) - Method in class org.apache.flink.runtime.util.DataOutputSerializer
 
writeEnum(int) - Method in class org.apache.flink.api.avro.DataOutputEncoder
 
writeEnum(int) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeExternal(String) - Method in class org.apache.flink.storm.util.AbstractBoltSink
 
writeExternal(String) - Method in class org.apache.flink.storm.util.BoltFileSink
 
writeExternal(String) - Method in class org.apache.flink.storm.util.BoltPrintSink
 
writeFile(File, String, String) - Static method in class org.apache.flink.util.FileUtils
 
writeFileInfoToConfig(String, DistributedCache.DistributedCacheEntry, Configuration) - Static method in class org.apache.flink.api.common.cache.DistributedCache
 
writeFilesToDisk() - Method in class org.apache.flink.api.scala.FlinkILoop
Packages the compiled classes of the current shell session into a Jar file for execution on a Flink cluster.
writeFileUtf8(File, String) - Static method in class org.apache.flink.util.FileUtils
 
writeFixed(byte[], int, int) - Method in class org.apache.flink.api.avro.DataOutputEncoder
 
writeFixed(byte[], int, int) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeFloat(float) - Method in class org.apache.flink.api.avro.DataOutputEncoder
 
writeFloat(float) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeFloat(float) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
 
writeFloat(float) - Method in class org.apache.flink.runtime.util.DataOutputSerializer
 
WriteFormat<IN> - Class in org.apache.flink.streaming.api.functions.sink
Abstract class for formatting the output of the writeAsText and writeAsCsv functions.
WriteFormat() - Constructor for class org.apache.flink.streaming.api.functions.sink.WriteFormat
 
WriteFormatAsCsv<IN> - Class in org.apache.flink.streaming.api.functions.sink
Writes tuples in csv format.
WriteFormatAsCsv() - Constructor for class org.apache.flink.streaming.api.functions.sink.WriteFormatAsCsv
 
WriteFormatAsText<IN> - Class in org.apache.flink.streaming.api.functions.sink
Writes tuples in text format.
WriteFormatAsText() - Constructor for class org.apache.flink.streaming.api.functions.sink.WriteFormatAsText
 
writeIndex(int) - Method in class org.apache.flink.api.avro.DataOutputEncoder
 
writeIndex(int) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeInt(int) - Method in class org.apache.flink.api.avro.DataOutputEncoder
 
writeInt(int) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeInt(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
 
writeInt(int) - Method in class org.apache.flink.runtime.util.DataOutputSerializer
 
WriteIntoKafka - Class in org.apache.flink.streaming.examples.kafka
Generate a String every 500 ms and write it into a Kafka topic Please pass the following arguments to run the example: --topic test --bootstrap.servers localhost:9092
WriteIntoKafka() - Constructor for class org.apache.flink.streaming.examples.kafka.WriteIntoKafka
 
writeIOMetricsAsJson(JsonGenerator) - Method in class org.apache.flink.runtime.webmonitor.utils.MutableIOMetrics
Writes the IO metrics contained in this object to the given JsonGenerator.
writeJobDetailOverviewAsJson(JobDetails, JsonGenerator, long) - Static method in class org.apache.flink.runtime.webmonitor.handlers.CurrentJobsOverviewHandler
 
writeKeyWithGroupAndNamespace(int, K, N, ByteArrayOutputStreamWithPos, DataOutputView) - Method in class org.apache.flink.contrib.streaming.state.AbstractRocksDBState
 
writeLeaderInformation(UUID) - Method in class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
Writes the current leader's address as well the given leader session ID to ZooKeeper.
writeLibSVM(String, DataSet<LabeledVector>) - Method in class org.apache.flink.ml.MLUtils$
Writes a DataSet of LabeledVector to a file using the libSVM/SVMLight format.
writeLibSVM(String, DataSet<LabeledVector>) - Static method in class org.apache.flink.ml.MLUtils
Writes a DataSet of LabeledVector to a file using the libSVM/SVMLight format.
writeLong(long) - Method in class org.apache.flink.api.avro.DataOutputEncoder
 
writeLong(long) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeLong(long) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
 
writeLong(long) - Method in class org.apache.flink.runtime.util.DataOutputSerializer
 
writeMapEnd() - Method in class org.apache.flink.api.avro.DataOutputEncoder
 
writeMapEnd() - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeMappingsInKeyGroup(DataOutputView, int) - Method in class org.apache.flink.runtime.state.heap.CopyOnWriteStateTableSnapshot
 
writeMapStart() - Method in class org.apache.flink.api.avro.DataOutputEncoder
 
writeMapStart() - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeMemory - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger.SpillingThread
 
writeMemory - Variable in class org.apache.flink.runtime.operators.sort.UnilateralSortMerger
The memory segments used to stage data to be written.
writeMode - Variable in class org.apache.flink.python.api.PythonOperationInfo
 
writeNull() - Method in class org.apache.flink.api.avro.DataOutputEncoder
 
writeNull() - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeNullableString(String, DataOutputView) - Static method in class org.apache.flink.util.StringUtils
Writes a String to the given output.
writeNullMask(int, Row, DataOutputView) - Static method in class org.apache.flink.api.java.typeutils.runtime.NullMaskUtils
 
writeObjectToConfig(Object, Configuration, String) - Static method in class org.apache.flink.util.InstantiationUtil
 
writeParametersToConfig(Configuration) - Method in interface org.apache.flink.api.common.typeutils.TypeComparatorFactory
 
writeParametersToConfig(Configuration) - Method in interface org.apache.flink.api.common.typeutils.TypeSerializerFactory
 
writeParametersToConfig(Configuration) - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeComparatorFactory
 
writeParametersToConfig(Configuration) - Method in class org.apache.flink.api.java.typeutils.runtime.RuntimeSerializerFactory
 
Writer<T> - Interface in org.apache.flink.streaming.connectors.fs
An implementation of Writer is used in conjunction with a BucketingSink to perform the actual writing to the bucket files.
writeRecord(T) - Method in class org.apache.flink.api.common.io.BinaryOutputFormat
 
writeRecord(IT) - Method in interface org.apache.flink.api.common.io.OutputFormat
Adds a record to the output.
writeRecord(Tuple2<K, V>) - Method in class org.apache.flink.api.java.hadoop.mapred.HadoopOutputFormat
 
writeRecord(Tuple2<K, V>) - Method in class org.apache.flink.api.java.hadoop.mapreduce.HadoopOutputFormat
 
writeRecord(E) - Method in class org.apache.flink.api.java.io.AvroOutputFormat
 
writeRecord(T) - Method in class org.apache.flink.api.java.io.CsvOutputFormat
 
writeRecord(T) - Method in class org.apache.flink.api.java.io.DiscardingOutputFormat
 
writeRecord(Row) - Method in class org.apache.flink.api.java.io.jdbc.JDBCOutputFormat
Adds a record to the prepared statement.
writeRecord(T) - Method in class org.apache.flink.api.java.io.LocalCollectionOutputFormat
 
writeRecord(T) - Method in class org.apache.flink.api.java.io.PrintingOutputFormat
 
writeRecord(T) - Method in class org.apache.flink.api.java.io.TextOutputFormat
 
writeRecord(T) - Method in class org.apache.flink.api.java.Utils.ChecksumHashCodeHelper
 
writeRecord(T) - Method in class org.apache.flink.api.java.Utils.CollectHelper
 
writeRecord(T) - Method in class org.apache.flink.api.java.Utils.CountHelper
 
writeRecord(Tuple2<K, V>) - Method in class org.apache.flink.api.scala.hadoop.mapred.HadoopOutputFormat
 
writeRecord(Tuple2<K, V>) - Method in class org.apache.flink.api.scala.hadoop.mapreduce.HadoopOutputFormat
 
writeRecord(T) - Method in class org.apache.flink.api.scala.operators.ScalaCsvOutputFormat
 
writeRecord(OUT) - Method in class org.apache.flink.batch.connectors.cassandra.CassandraOutputFormat
 
writeSerializer(DataOutputView, TypeSerializer<T>) - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
Writes a TypeSerializer to the provided data output view.
writeSerializerConfigSnapshot(DataOutputView, TypeSerializerConfigSnapshot) - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
Writes a TypeSerializerConfigSnapshot to the provided data output view.
writeSerializerConfigSnapshots(DataOutputView, TypeSerializerConfigSnapshot...) - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
Writes multiple TypeSerializerConfigSnapshots to the provided data output view.
writeSerializersAndConfigsWithResilience(DataOutputView, List<Tuple2<TypeSerializer<?>, TypeSerializerConfigSnapshot>>) - Static method in class org.apache.flink.api.common.typeutils.TypeSerializerSerializationUtil
Write a list of serializers and their corresponding config snapshots to the provided data output view.
writeShort(int) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
 
writeShort(int) - Method in class org.apache.flink.runtime.util.DataOutputSerializer
 
WriteSinkFunction<IN> - Class in org.apache.flink.streaming.api.functions.sink
Simple implementation of the SinkFunction writing tuples as simple text to the file specified by path.
WriteSinkFunction(String, WriteFormat<IN>) - Constructor for class org.apache.flink.streaming.api.functions.sink.WriteSinkFunction
 
WriteSinkFunctionByMillis<IN> - Class in org.apache.flink.streaming.api.functions.sink
Implementation of WriteSinkFunction.
WriteSinkFunctionByMillis(String, WriteFormat<IN>, long) - Constructor for class org.apache.flink.streaming.api.functions.sink.WriteSinkFunctionByMillis
 
writeStateMetaInfo(DataOutputView) - Method in interface org.apache.flink.runtime.state.KeyedBackendStateMetaInfoSnapshotReaderWriters.KeyedBackendStateMetaInfoWriter
 
writeStateMetaInfo(DataOutputView) - Method in interface org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoWriter
 
writeStateMetaInfo(DataOutputView) - Method in class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoWriterV1
 
writeStateMetaInfo(DataOutputView) - Method in class org.apache.flink.runtime.state.OperatorBackendStateMetaInfoSnapshotReaderWriters.OperatorBackendStateMetaInfoWriterV2
 
writeString(String) - Method in class org.apache.flink.api.avro.DataOutputEncoder
 
writeString(Utf8) - Method in class org.apache.flink.api.avro.DataOutputEncoder
 
writeString(String) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeString(Utf8) - Method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeString(CharSequence, DataOutput) - Static method in class org.apache.flink.types.StringValue
 
writeString(String, DataOutputView) - Static method in class org.apache.flink.util.StringUtils
Writes a String to the given output.
writeTo(ByteBuf) - Method in class org.apache.flink.runtime.executiongraph.ExecutionAttemptID
 
writeTo(ByteBuf) - Method in class org.apache.flink.runtime.io.network.partition.consumer.InputChannelID
 
writeTo(ByteBuf) - Method in class org.apache.flink.runtime.jobgraph.IntermediateResultPartitionID
 
writeToKafkaWithTimestamps(DataStream<T>, String, KeyedSerializationSchema<T>, Properties) - Static method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
Creates a FlinkKafkaProducer for a given topic.
writeToKafkaWithTimestamps(DataStream<T>, String, SerializationSchema<T>, Properties) - Static method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
Creates a FlinkKafkaProducer for a given topic.
writeToKafkaWithTimestamps(DataStream<T>, String, KeyedSerializationSchema<T>, Properties, FlinkKafkaPartitioner<T>) - Static method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
Creates a FlinkKafkaProducer for a given topic.
writeToKafkaWithTimestamps(DataStream<T>, String, KeyedSerializationSchema<T>, Properties, KafkaPartitioner<T>) - Static method in class org.apache.flink.streaming.connectors.kafka.FlinkKafkaProducer010
Deprecated.
This is a deprecated since it does not correctly handle partitioning when producing to multiple topics. Use FlinkKafkaProducer010.FlinkKafkaProducer010(String, SerializationSchema, Properties, FlinkKafkaPartitioner) instead.
writeToOutput(ChannelWriterOutputView) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
Writes the records in this buffer in their logical order to the given output.
writeToOutput(ChannelWriterOutputView, LargeRecordHandler<T>) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
 
writeToOutput(ChannelWriterOutputView, int, int) - Method in class org.apache.flink.runtime.operators.sort.FixedLengthRecordSorter
Writes a subset of the records in this buffer in their logical order to the given output.
writeToOutput(ChannelWriterOutputView) - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
Writes the records in this buffer in their logical order to the given output.
writeToOutput(ChannelWriterOutputView, LargeRecordHandler<T>) - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
 
writeToOutput(ChannelWriterOutputView, int, int) - Method in interface org.apache.flink.runtime.operators.sort.InMemorySorter
Writes a subset of the records in this buffer in their logical order to the given output.
writeToOutput(ChannelWriterOutputView) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
Writes the records in this buffer in their logical order to the given output.
writeToOutput(ChannelWriterOutputView, LargeRecordHandler<T>) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
 
writeToOutput(ChannelWriterOutputView, int, int) - Method in class org.apache.flink.runtime.operators.sort.NormalizedKeySorter
Writes a subset of the records in this buffer in their logical order to the given output.
writeToOutput(DataOutputView, TypeSerializer<Key>, TypeSerializer<Aggregate>) - Method in class org.apache.flink.streaming.runtime.operators.windowing.AbstractKeyedTimePanes
 
writeToSink(Table, TableSink<T>, QueryConfig) - Method in class org.apache.flink.table.api.BatchTableEnvironment
Writes a Table to a TableSink.
writeToSink(Table, TableSink<T>, QueryConfig) - Method in class org.apache.flink.table.api.StreamTableEnvironment
Writes a Table to a TableSink.
writeToSink(TableSink<T>) - Method in class org.apache.flink.table.api.Table
Writes the Table to a TableSink.
writeToSink(TableSink<T>, QueryConfig) - Method in class org.apache.flink.table.api.Table
Writes the Table to a TableSink.
writeToSink(Table, TableSink<T>, QueryConfig) - Method in class org.apache.flink.table.api.TableEnvironment
Writes a Table to a TableSink.
writeToSocket(String, int, SerializationSchema<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Writes the DataStream to a socket as a byte array.
writeToSocket(String, Integer, SerializationSchema<T>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Writes the DataStream to a socket as a byte array.
writeUsingOutputFormat(OutputFormat<T>) - Method in class org.apache.flink.streaming.api.datastream.DataStream
Writes the dataStream into an output, described by an OutputFormat.
writeUsingOutputFormat(OutputFormat<T>) - Method in class org.apache.flink.streaming.api.scala.DataStream
Writes a DataStream using the given OutputFormat.
writeUTF(String) - Method in class org.apache.flink.runtime.memory.AbstractPagedOutputView
 
writeUTF(String) - Method in class org.apache.flink.runtime.util.DataOutputSerializer
 
writeVarLongCount(DataOutput, long) - Static method in class org.apache.flink.api.avro.DataOutputEncoder
 
writeVarLongCount(DataOutput, long) - Static method in class org.apache.flink.api.java.typeutils.runtime.DataOutputEncoder
 
writeWithKeyNormalization(T, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.array.PrimitiveArrayComparator
 
writeWithKeyNormalization(T, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BasicTypeComparator
 
writeWithKeyNormalization(BooleanValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.BooleanValueComparator
 
writeWithKeyNormalization(ByteValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ByteValueComparator
 
writeWithKeyNormalization(CharValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.CharValueComparator
 
writeWithKeyNormalization(DoubleValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.DoubleValueComparator
 
writeWithKeyNormalization(FloatValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.FloatValueComparator
 
writeWithKeyNormalization(IntValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.IntValueComparator
 
writeWithKeyNormalization(LongValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.LongValueComparator
 
writeWithKeyNormalization(NullValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.NullValueComparator
 
writeWithKeyNormalization(ShortValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.ShortValueComparator
 
writeWithKeyNormalization(StringValue, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.base.StringValueComparator
 
writeWithKeyNormalization(T, DataOutputView) - Method in class org.apache.flink.api.common.typeutils.TypeComparator
Writes the record in such a fashion that all keys are normalizing and at the beginning of the serialized data.
writeWithKeyNormalization(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.CopyableValueComparator
 
writeWithKeyNormalization(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.GenericTypeComparator
 
writeWithKeyNormalization(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.NullAwareComparator
 
writeWithKeyNormalization(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.PojoComparator
 
writeWithKeyNormalization(Row, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.RowComparator
 
writeWithKeyNormalization(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.TupleComparatorBase
 
writeWithKeyNormalization(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.ValueComparator
 
writeWithKeyNormalization(T, DataOutputView) - Method in class org.apache.flink.api.java.typeutils.runtime.WritableComparator
 
writeWithKeyNormalization(Enumeration.Value, DataOutputView) - Method in class org.apache.flink.api.scala.typeutils.EnumValueComparator
 
writeWithKeyNormalization(Option<A>, DataOutputView) - Method in class org.apache.flink.api.scala.typeutils.OptionTypeComparator
 
writeWithKeyNormalization(IntValueArray, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.IntValueArrayComparator
 
writeWithKeyNormalization(LongValueArray, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.LongValueArrayComparator
 
writeWithKeyNormalization(NullValueArray, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.NullValueArrayComparator
 
writeWithKeyNormalization(StringValueArray, DataOutputView) - Method in class org.apache.flink.graph.types.valuearray.StringValueArrayComparator
 
writeWithKeyNormalization(CRow, DataOutputView) - Method in class org.apache.flink.table.runtime.types.CRowComparator
 

X

x - Variable in class org.apache.flink.examples.java.clustering.KMeans.Point
 
x - Variable in class org.apache.flink.examples.java.ml.LinearRegression.Data
 
x() - Method in class org.apache.flink.examples.scala.clustering.KMeans.Centroid
 
x() - Method in interface org.apache.flink.examples.scala.clustering.KMeans.Coordinate
 
x() - Method in class org.apache.flink.examples.scala.clustering.KMeans.Point
 
x() - Method in class org.apache.flink.examples.scala.ml.LinearRegression.Data
 
x - Variable in class org.apache.flink.graph.examples.EuclideanGraphWeighing.Point
 
XORShiftRandom - Class in org.apache.flink.util
Implement a random number generator based on the XORShift algorithm discovered by George Marsaglia.
XORShiftRandom() - Constructor for class org.apache.flink.util.XORShiftRandom
 
XORShiftRandom(long) - Constructor for class org.apache.flink.util.XORShiftRandom
 
Xu(double) - Constructor for class org.apache.flink.ml.optimization.LearningRateMethod.Xu
 
Xu$() - Constructor for class org.apache.flink.ml.optimization.LearningRateMethod.Xu$
 
XZInputStreamFactory - Class in org.apache.flink.api.common.io.compression
 
XZInputStreamFactory() - Constructor for class org.apache.flink.api.common.io.compression.XZInputStreamFactory
 

Y

y - Variable in class org.apache.flink.examples.java.clustering.KMeans.Point
 
y - Variable in class org.apache.flink.examples.java.ml.LinearRegression.Data
 
y() - Method in class org.apache.flink.examples.scala.clustering.KMeans.Centroid
 
y() - Method in interface org.apache.flink.examples.scala.clustering.KMeans.Coordinate
 
y() - Method in class org.apache.flink.examples.scala.clustering.KMeans.Point
 
y() - Method in class org.apache.flink.examples.scala.ml.LinearRegression.Data
 
y - Variable in class org.apache.flink.graph.examples.EuclideanGraphWeighing.Point
 
YARN() - Method in class org.apache.flink.api.scala.FlinkShell.ExecutionMode$
 
YARN_APPLICATION_ATTEMPTS - Static variable in class org.apache.flink.configuration.ConfigConstants
Set the number of retries for failed YARN ApplicationMasters/JobManagers in high availability mode.
YARN_APPLICATION_MASTER_ENV_PREFIX - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Please use CONTAINERIZED_MASTER_ENV_PREFIX.
YARN_APPLICATION_MASTER_PORT - Static variable in class org.apache.flink.configuration.ConfigConstants
The config parameter defining the Akka actor system port for the ApplicationMaster and JobManager The port can either be a port, such as "9123", a range of ports: "50100-50200" or a list of ranges and or points: "50100-50200,50300-50400,51234" Setting the port to 0 will let the OS choose an available port.
YARN_APPLICATION_TAGS - Static variable in class org.apache.flink.configuration.ConfigConstants
A comma-separated list of strings to use as YARN application tags.
YARN_CONTAINER_START_COMMAND_TEMPLATE - Static variable in class org.apache.flink.configuration.ConfigConstants
Template for the YARN container start incovation.
YARN_HEAP_CUTOFF_MIN - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
in favor of #CONTAINERIZED_HEAP_CUTOFF_MIN
YARN_HEAP_CUTOFF_RATIO - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
in favor of #CONTAINERIZED_HEAP_CUTOFF_RATIO
YARN_HEARTBEAT_DELAY() - Method in class org.apache.flink.yarn.YarnJobManager
 
YARN_HEARTBEAT_DELAY_SECONDS - Static variable in class org.apache.flink.configuration.ConfigConstants
The heartbeat interval between the Application Master and the YARN Resource Manager.
YARN_MAX_FAILED_CONTAINERS - Static variable in class org.apache.flink.configuration.ConfigConstants
The maximum number of failed YARN containers before entirely stopping the YARN session / job on YARN.
YARN_PROPERTIES_FILE_LOCATION - Static variable in class org.apache.flink.configuration.ConfigConstants
When a Flink job is submitted to YARN, the JobManager's host and the number of available processing slots is written into a properties file, so that the Flink client is able to pick those details up.
YARN_REALLOCATE_FAILED_CONTAINERS - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Not used anymore
YARN_SITE_FILE_NAME - Static variable in class org.apache.flink.yarn.Utils
Yarn site xml file name populated in YARN container for secure IT run
YARN_TASK_MANAGER_ENV_PREFIX - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Please use CONTAINERIZED_TASK_MANAGER_ENV_PREFIX.
YARN_VCORES - Static variable in class org.apache.flink.configuration.ConfigConstants
The vcores exposed by YARN.
YarnApplicationMasterRunner - Class in org.apache.flink.yarn
This class is the executable entry point for the YARN application master.
YarnApplicationMasterRunner() - Constructor for class org.apache.flink.yarn.YarnApplicationMasterRunner
 
YarnClusterClient - Class in org.apache.flink.yarn
Java representation of a running Flink cluster within YARN.
YarnClusterClient(AbstractYarnClusterDescriptor, YarnClient, ApplicationReport, Configuration, boolean) - Constructor for class org.apache.flink.yarn.YarnClusterClient
Create a new Flink on YARN cluster.
YarnClusterClientV2 - Class in org.apache.flink.yarn
Java representation of a running Flink job on YARN.
YarnClusterClientV2(AbstractYarnClusterDescriptor, Configuration) - Constructor for class org.apache.flink.yarn.YarnClusterClientV2
Create a client to communicate with YARN cluster.
YarnClusterDescriptor - Class in org.apache.flink.yarn
Default implementation of AbstractYarnClusterDescriptor which starts an YarnApplicationMasterRunner.
YarnClusterDescriptor() - Constructor for class org.apache.flink.yarn.YarnClusterDescriptor
 
YarnClusterDescriptorV2 - Class in org.apache.flink.yarn
Implementation of AbstractYarnClusterDescriptor which is used to start the new application master for a job under flip-6.
YarnClusterDescriptorV2() - Constructor for class org.apache.flink.yarn.YarnClusterDescriptorV2
 
yarnConfig() - Method in class org.apache.flink.api.scala.FlinkShell.Config
 
YarnConfig(Option<Object>, Option<Object>, Option<String>, Option<String>, Option<Object>, Option<Object>) - Constructor for class org.apache.flink.api.scala.FlinkShell.YarnConfig
 
YarnConfig$() - Constructor for class org.apache.flink.api.scala.FlinkShell.YarnConfig$
 
YarnConfigKeys - Class in org.apache.flink.yarn
The Yarn environment variables used for settings of the containers.
YarnConfigOptions - Class in org.apache.flink.yarn.configuration
This class holds configuration constants used by Flink's YARN runners.
YarnConfigOptions.UserJarInclusion - Enum in org.apache.flink.yarn.configuration
 
yarnContainer() - Method in class org.apache.flink.yarn.RegisteredYarnWorkerNode
 
YarnContainerInLaunch - Class in org.apache.flink.yarn
This class describes a container in which a TaskManager is being launched (or has been launched) but where the TaskManager has not properly registered, yet.
YarnContainerInLaunch(Container) - Constructor for class org.apache.flink.yarn.YarnContainerInLaunch
 
YarnContainerInLaunch(Container, long) - Constructor for class org.apache.flink.yarn.YarnContainerInLaunch
 
YarnContainersAllocated(List<Container>) - Constructor for class org.apache.flink.yarn.YarnMessages.YarnContainersAllocated
 
YarnContainersAllocated$() - Constructor for class org.apache.flink.yarn.YarnMessages.YarnContainersAllocated$
 
YarnContainersCompleted(List<ContainerStatus>) - Constructor for class org.apache.flink.yarn.YarnMessages.YarnContainersCompleted
 
YarnContainersCompleted$() - Constructor for class org.apache.flink.yarn.YarnMessages.YarnContainersCompleted$
 
yarnFilesPath() - Method in class org.apache.flink.yarn.YarnJobManager
 
YarnFlinkApplicationMasterRunner - Class in org.apache.flink.yarn
This class is the executable entry point for the YARN Application Master that executes a single Flink job and then shuts the YARN application down.
YarnFlinkApplicationMasterRunner() - Constructor for class org.apache.flink.yarn.YarnFlinkApplicationMasterRunner
 
YarnFlinkResourceManager - Class in org.apache.flink.yarn
Specialized Flink Resource Manager implementation for YARN clusters.
YarnFlinkResourceManager(Configuration, YarnConfiguration, LeaderRetrievalService, String, String, ContaineredTaskManagerParameters, ContainerLaunchContext, int, int, int) - Constructor for class org.apache.flink.yarn.YarnFlinkResourceManager
 
YarnFlinkResourceManager(Configuration, YarnConfiguration, LeaderRetrievalService, String, String, ContaineredTaskManagerParameters, ContainerLaunchContext, int, int, int, YarnResourceManagerCallbackHandler) - Constructor for class org.apache.flink.yarn.YarnFlinkResourceManager
 
YarnFlinkResourceManager(Configuration, YarnConfiguration, LeaderRetrievalService, String, String, ContaineredTaskManagerParameters, ContainerLaunchContext, int, int, int, YarnResourceManagerCallbackHandler, AMRMClientAsync<AMRMClient.ContainerRequest>, NMClient) - Constructor for class org.apache.flink.yarn.YarnFlinkResourceManager
 
YarnHighAvailabilityServices - Class in org.apache.flink.yarn.highavailability
The basis of HighAvailabilityServices for YARN setups.
YarnHighAvailabilityServices(Configuration, Configuration) - Constructor for class org.apache.flink.yarn.highavailability.YarnHighAvailabilityServices
Creates new YARN high-availability services, configuring the file system and recovery data directory based on the working directory in the given Hadoop configuration.
YarnIntraNonHaMasterServices - Class in org.apache.flink.yarn.highavailability
These YarnHighAvailabilityServices are for the Application Master in setups where there is one ResourceManager that is statically configured in the Flink configuration.
YarnIntraNonHaMasterServices(Configuration, Configuration) - Constructor for class org.apache.flink.yarn.highavailability.YarnIntraNonHaMasterServices
Creates new YarnIntraNonHaMasterServices for the given Flink and YARN configuration.
yarnJobManager() - Method in class org.apache.flink.yarn.ApplicationClient
 
YarnJobManager - Class in org.apache.flink.yarn
JobManager actor for execution on Yarn.
YarnJobManager(Configuration, ScheduledExecutorService, Executor, InstanceManager, Scheduler, BlobLibraryCacheManager, ActorRef, RestartStrategyFactory, FiniteDuration, LeaderElectionService, SubmittedJobGraphStore, CheckpointRecoveryFactory, FiniteDuration, Option<MetricRegistry>) - Constructor for class org.apache.flink.yarn.YarnJobManager
 
YarnMessages - Class in org.apache.flink.yarn
 
YarnMessages() - Constructor for class org.apache.flink.yarn.YarnMessages
 
YarnMessages$ - Class in org.apache.flink.yarn
 
YarnMessages$() - Constructor for class org.apache.flink.yarn.YarnMessages$
 
YarnMessages.AcknowledgeApplicationClientRegistration$ - Class in org.apache.flink.yarn
Response to a RegisterApplicationClient message which led to a successful registration of the ApplicationClient
YarnMessages.ApplicationMasterStatus - Class in org.apache.flink.yarn
 
YarnMessages.ApplicationMasterStatus$ - Class in org.apache.flink.yarn
 
YarnMessages.CheckForUserCommand$ - Class in org.apache.flink.yarn
 
YarnMessages.HeartbeatWithYarn$ - Class in org.apache.flink.yarn
 
YarnMessages.JobManagerLeaderAddress - Class in org.apache.flink.yarn
Notification message that a new leader has been found.
YarnMessages.JobManagerLeaderAddress$ - Class in org.apache.flink.yarn
 
YarnMessages.LocalGetYarnMessage$ - Class in org.apache.flink.yarn
 
YarnMessages.LocalStopYarnSession - Class in org.apache.flink.yarn
 
YarnMessages.LocalStopYarnSession$ - Class in org.apache.flink.yarn
 
YarnMessages.RegisterApplicationClient$ - Class in org.apache.flink.yarn
Registration message sent from the ApplicationClient to the YarnFlinkResourceManager.
YarnMessages.StartYarnSession - Class in org.apache.flink.yarn
Entry point to start a new YarnSession.
YarnMessages.StartYarnSession$ - Class in org.apache.flink.yarn
 
YarnMessages.TriggerApplicationClientRegistration - Class in org.apache.flink.yarn
Triggers the registration of the ApplicationClient to the YarnJobManager
YarnMessages.TriggerApplicationClientRegistration$ - Class in org.apache.flink.yarn
 
YarnMessages.YarnContainersAllocated - Class in org.apache.flink.yarn
Callback from the async ResourceManager client when containers were allocated.
YarnMessages.YarnContainersAllocated$ - Class in org.apache.flink.yarn
 
YarnMessages.YarnContainersCompleted - Class in org.apache.flink.yarn
Callback from the async ResourceManager client when containers were completed.
YarnMessages.YarnContainersCompleted$ - Class in org.apache.flink.yarn
 
YarnPreConfiguredMasterNonHaServices - Class in org.apache.flink.yarn.highavailability
These YarnHighAvailabilityServices are for use by the TaskManager in setups, where there is one ResourceManager that is statically configured in the Flink configuration.
YarnPreConfiguredMasterNonHaServices(Configuration, Configuration, HighAvailabilityServicesUtils.AddressResolution) - Constructor for class org.apache.flink.yarn.highavailability.YarnPreConfiguredMasterNonHaServices
Creates new YarnPreConfiguredMasterHaServices for the given Flink and YARN configuration.
YarnResourceManager - Class in org.apache.flink.yarn
The yarn implementation of the resource manager.
YarnResourceManager(RpcService, String, ResourceID, Configuration, Map<String, String>, ResourceManagerConfiguration, HighAvailabilityServices, HeartbeatServices, SlotManager, MetricRegistry, JobLeaderIdService, FatalErrorHandler) - Constructor for class org.apache.flink.yarn.YarnResourceManager
 
YarnResourceManagerCallbackHandler - Class in org.apache.flink.yarn
This class reacts to callbacks from the YARN Resource Manager.
YarnResourceManagerCallbackHandler() - Constructor for class org.apache.flink.yarn.YarnResourceManagerCallbackHandler
 
YarnResourceManagerCallbackHandler(ActorRef) - Constructor for class org.apache.flink.yarn.YarnResourceManagerCallbackHandler
 
YarnTaskExecutorRunner - Class in org.apache.flink.yarn
This class is the executable entry point for running a TaskExecutor in a YARN container.
YarnTaskExecutorRunner() - Constructor for class org.apache.flink.yarn.YarnTaskExecutorRunner
 
YarnTaskManager - Class in org.apache.flink.yarn
An extension of the TaskManager that listens for additional YARN related messages.
YarnTaskManager(TaskManagerConfiguration, ResourceID, TaskManagerLocation, MemoryManager, IOManager, NetworkEnvironment, int, HighAvailabilityServices, MetricRegistry) - Constructor for class org.apache.flink.yarn.YarnTaskManager
 
YarnTaskManager$ - Class in org.apache.flink.yarn
 
YarnTaskManager$() - Constructor for class org.apache.flink.yarn.YarnTaskManager$
 
YarnTaskManagerRunner - Class in org.apache.flink.yarn
The entry point for running a TaskManager in a YARN container.
YarnTaskManagerRunner() - Constructor for class org.apache.flink.yarn.YarnTaskManagerRunner
 
YEAR - Static variable in class org.apache.calcite.sql.fun.SqlStdOperatorTable
The SQL YEAR operator.
year() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Creates an interval of the given number of years.
YEAR() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
YEAR() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 
YEAR() - Method in class org.apache.flink.table.expressions.TimeIntervalUnit$
 
YEAR() - Static method in class org.apache.flink.table.expressions.TimeIntervalUnit
 
YEAR() - Method in class org.apache.flink.table.expressions.TimePointUnit$
 
YEAR() - Static method in class org.apache.flink.table.expressions.TimePointUnit
 
YEAR_TO_MONTH() - Method in class org.apache.flink.table.expressions.TimeIntervalUnit$
 
YEAR_TO_MONTH() - Static method in class org.apache.flink.table.expressions.TimeIntervalUnit
 
years() - Method in interface org.apache.flink.table.api.scala.ImplicitExpressionOperations
Creates an interval of the given number of years.
YEARS() - Method in class org.apache.flink.table.expressions.ExpressionParser$
 
YEARS() - Static method in class org.apache.flink.table.expressions.ExpressionParser
 

Z

ZERO - Static variable in class org.apache.flink.api.java.summarize.aggregation.CompensatedSum
 
Zero() - Method in class org.apache.flink.table.plan.cost.DataSetCost$
 
Zero() - Static method in class org.apache.flink.table.plan.cost.DataSetCost
 
ZeroInByte() - Method in class org.apache.flink.api.scala.typeutils.OptionTypeComparator$
 
ZeroInByte() - Static method in class org.apache.flink.api.scala.typeutils.OptionTypeComparator
 
zeros(int, int) - Method in class org.apache.flink.ml.math.DenseMatrix$
 
zeros(int, int) - Static method in class org.apache.flink.ml.math.DenseMatrix
 
zeros(int) - Method in class org.apache.flink.ml.math.DenseVector$
 
zeros(int) - Static method in class org.apache.flink.ml.math.DenseVector
 
zipWithIndex(DataSet<T>) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Method that assigns a unique Long value to all elements in the input data set.
zipWithUniqueId(DataSet<T>) - Static method in class org.apache.flink.api.java.utils.DataSetUtils
Method that assigns a unique Long value to all elements in the input data set in the following way: a map function is applied to the input data set each map task holds a counter c which is increased for each record c is shifted by n bits where n = log2(number of parallel tasks) to create a unique ID among all tasks, the task id is added to the counter for each record, the resulting counter is collected
ZOOKEEPER_CHECKPOINT_COUNTER_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
ZOOKEEPER_CHECKPOINTS_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
ZOOKEEPER_CONNECTION_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
ZOOKEEPER_CONNECTION_TIMEOUT - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
 
ZOOKEEPER_DIR_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
Deprecated in favour of ConfigConstants.HA_ZOOKEEPER_DIR_KEY.
ZOOKEEPER_JOBGRAPHS_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
ZOOKEEPER_LATCH_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
ZOOKEEPER_LEADER_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
ZOOKEEPER_MAX_RETRY_ATTEMPTS - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
ZOOKEEPER_MAX_RETRY_ATTEMPTS - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
 
ZOOKEEPER_MESOS_WORKERS_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
ZOOKEEPER_NAMESPACE_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
ZOOKEEPER_QUORUM_KEY - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
ZOOKEEPER_RECOVERY_PATH - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
ZOOKEEPER_RETRY_WAIT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
ZOOKEEPER_RETRY_WAIT - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
 
ZOOKEEPER_RUNNING_JOB_REGISTRY_PATH - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
 
ZOOKEEPER_SASL_DISABLE - Static variable in class org.apache.flink.configuration.ConfigConstants
 
ZOOKEEPER_SASL_DISABLE - Static variable in class org.apache.flink.configuration.SecurityOptions
 
ZOOKEEPER_SASL_LOGIN_CONTEXT_NAME - Static variable in class org.apache.flink.configuration.SecurityOptions
 
ZOOKEEPER_SASL_SERVICE_NAME - Static variable in class org.apache.flink.configuration.ConfigConstants
 
ZOOKEEPER_SASL_SERVICE_NAME - Static variable in class org.apache.flink.configuration.SecurityOptions
 
ZOOKEEPER_SESSION_TIMEOUT - Static variable in class org.apache.flink.configuration.ConfigConstants
Deprecated.
ZOOKEEPER_SESSION_TIMEOUT - Static variable in class org.apache.flink.configuration.HighAvailabilityOptions
 
ZooKeeperCheckpointIDCounter - Class in org.apache.flink.runtime.checkpoint
CheckpointIDCounter instances for JobManagers running in HighAvailabilityMode.ZOOKEEPER.
ZooKeeperCheckpointIDCounter(CuratorFramework, String) - Constructor for class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointIDCounter
Creates a ZooKeeperCheckpointIDCounter instance.
ZooKeeperCheckpointRecoveryFactory - Class in org.apache.flink.runtime.checkpoint
ZooKeeperCheckpointRecoveryFactory(CuratorFramework, Configuration, Executor) - Constructor for class org.apache.flink.runtime.checkpoint.ZooKeeperCheckpointRecoveryFactory
 
ZooKeeperCompletedCheckpointStore - Class in org.apache.flink.runtime.checkpoint
ZooKeeperCompletedCheckpointStore(int, CuratorFramework, String, RetrievableStateStorageHelper<CompletedCheckpoint>, Executor) - Constructor for class org.apache.flink.runtime.checkpoint.ZooKeeperCompletedCheckpointStore
ZooKeeperHaServices - Class in org.apache.flink.runtime.highavailability.zookeeper
An implementation of the HighAvailabilityServices using Apache ZooKeeper.
ZooKeeperHaServices(CuratorFramework, Executor, Configuration, BlobStoreService) - Constructor for class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperHaServices
 
ZooKeeperLeaderElectionService - Class in org.apache.flink.runtime.leaderelection
Leader election service for multiple JobManager.
ZooKeeperLeaderElectionService(CuratorFramework, String, String) - Constructor for class org.apache.flink.runtime.leaderelection.ZooKeeperLeaderElectionService
Creates a ZooKeeperLeaderElectionService object.
ZooKeeperLeaderRetrievalService - Class in org.apache.flink.runtime.leaderretrieval
The counterpart to the ZooKeeperLeaderElectionService.
ZooKeeperLeaderRetrievalService(CuratorFramework, String) - Constructor for class org.apache.flink.runtime.leaderretrieval.ZooKeeperLeaderRetrievalService
Creates a leader retrieval service which uses ZooKeeper to retrieve the leader information.
ZooKeeperMesosServices - Class in org.apache.flink.mesos.runtime.clusterframework.services
MesosServices implementation for the ZooKeeper high availability based mode.
ZooKeeperMesosServices(ZooKeeperUtilityFactory) - Constructor for class org.apache.flink.mesos.runtime.clusterframework.services.ZooKeeperMesosServices
 
ZooKeeperMesosWorkerStore - Class in org.apache.flink.mesos.runtime.clusterframework.store
A ZooKeeper-backed Mesos worker store.
ZooKeeperMesosWorkerStore(ZooKeeperStateHandleStore<MesosWorkerStore.Worker>, ZooKeeperSharedValue, ZooKeeperSharedCount) - Constructor for class org.apache.flink.mesos.runtime.clusterframework.store.ZooKeeperMesosWorkerStore
 
ZooKeeperModule - Class in org.apache.flink.runtime.security.modules
Responsible for installing a process-wide ZooKeeper security configuration.
ZooKeeperModule() - Constructor for class org.apache.flink.runtime.security.modules.ZooKeeperModule
 
ZookeeperOffsetHandler - Class in org.apache.flink.streaming.connectors.kafka.internals
Handler for committing Kafka offsets to Zookeeper and to retrieve them again.
ZookeeperOffsetHandler(Properties) - Constructor for class org.apache.flink.streaming.connectors.kafka.internals.ZookeeperOffsetHandler
 
ZooKeeperRunningJobsRegistry - Class in org.apache.flink.runtime.highavailability.zookeeper
A zookeeper based registry for running jobs, highly available.
ZooKeeperRunningJobsRegistry(CuratorFramework, Configuration) - Constructor for class org.apache.flink.runtime.highavailability.zookeeper.ZooKeeperRunningJobsRegistry
 
ZooKeeperSharedCount - Class in org.apache.flink.runtime.zookeeper
Wrapper class for a SharedCount so that we don't expose a curator dependency in our internal APIs.
ZooKeeperSharedCount(SharedCount) - Constructor for class org.apache.flink.runtime.zookeeper.ZooKeeperSharedCount
 
ZooKeeperSharedValue - Class in org.apache.flink.runtime.zookeeper
Wrapper class for a SharedValue so that we don't expose a curator dependency in our internal APIs.
ZooKeeperSharedValue(SharedValue) - Constructor for class org.apache.flink.runtime.zookeeper.ZooKeeperSharedValue
 
ZooKeeperStateHandleStore<T extends Serializable> - Class in org.apache.flink.runtime.zookeeper
Class which stores state via the provided RetrievableStateStorageHelper and writes the returned state handle to ZooKeeper.
ZooKeeperStateHandleStore(CuratorFramework, RetrievableStateStorageHelper<T>, Executor) - Constructor for class org.apache.flink.runtime.zookeeper.ZooKeeperStateHandleStore
ZooKeeperStateHandleStore.RemoveCallback<T extends Serializable> - Interface in org.apache.flink.runtime.zookeeper
Callback interface for remove calls
ZooKeeperSubmittedJobGraphStore - Class in org.apache.flink.runtime.jobmanager
SubmittedJobGraph instances for JobManagers running in HighAvailabilityMode.ZOOKEEPER.
ZooKeeperSubmittedJobGraphStore(CuratorFramework, String, RetrievableStateStorageHelper<SubmittedJobGraph>, Executor) - Constructor for class org.apache.flink.runtime.jobmanager.ZooKeeperSubmittedJobGraphStore
Submitted job graph store backed by ZooKeeper
ZooKeeperUtilityFactory - Class in org.apache.flink.runtime.zookeeper
Creates ZooKeeper utility classes without exposing the CuratorFramework dependency.
ZooKeeperUtilityFactory(Configuration, String) - Constructor for class org.apache.flink.runtime.zookeeper.ZooKeeperUtilityFactory
 
ZooKeeperUtils - Class in org.apache.flink.mesos.util
 
ZooKeeperUtils() - Constructor for class org.apache.flink.mesos.util.ZooKeeperUtils
 
ZooKeeperUtils - Class in org.apache.flink.runtime.util
 
ZooKeeperUtils.SecureAclProvider - Class in org.apache.flink.runtime.util
 
ZooKeeperUtils.ZkClientACLMode - Enum in org.apache.flink.runtime.util
 
ZooKeeperVersionedValue<T> - Class in org.apache.flink.runtime.zookeeper
Wrapper class for a VersionedValue so that we don't expose a curator dependency in our internal APIs.
ZooKeeperVersionedValue(VersionedValue<T>) - Constructor for class org.apache.flink.runtime.zookeeper.ZooKeeperVersionedValue
 
$ A B C D E F G H I J K L M N O P Q R S T U V W X Y Z 
Skip navigation links

Back to Flink Website

Copyright © 2014–2018 The Apache Software Foundation. All rights reserved.